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 _ 
All Classes All Packages

A

aboutToDelete(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
aboutToDelete(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised before an object is deleted from the database.
AboutToDeleteEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
aboutToInsert(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
aboutToInsert(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised before a new object is inserted to the database.
AboutToInsertEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
aboutToUpdate(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
aboutToUpdate(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised before an object is updated in the database.
AboutToUpdateEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
abs() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
abs(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Abs - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
ABSENT_NODE - org.eclipse.persistence.oxm.annotations.XmlMarshalNullRepresentation
 
ABSENT_NODE - org.eclipse.persistence.oxm.mappings.nullpolicy.XMLNullRepresentationType
Do not write out anything (default optional policy behavior).
absolute(int) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
Moves the cursor to the given row number in the result set
absolute(int) - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Moves the cursor to the given row number in the result set
absOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
AbstractColumnMapping - Class in org.eclipse.persistence.mappings.foundation
Purpose: Maps an attribute or some other property to the corresponding database field type.
AbstractColumnMapping() - Constructor for class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
Default constructor.
AbstractCompositeCollectionMapping - Class in org.eclipse.persistence.mappings.foundation
Define an embedded collection of objects.
AbstractCompositeCollectionMapping() - Constructor for class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
Default constructor.
AbstractCompositeDirectCollectionMapping - Class in org.eclipse.persistence.mappings.foundation
AbstractCompositeDirectCollectionMapping consolidates the behavior of mappings that map collections of "native" data objects (e.g.
AbstractCompositeDirectCollectionMapping() - Constructor for class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
Default constructor.
AbstractCompositeObjectMapping - Class in org.eclipse.persistence.mappings.foundation
Chunks of data from non-relational data sources can have an embedded component objects.
AbstractCompositeObjectMapping() - Constructor for class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
Default constructor.
AbstractCopyPolicy - Class in org.eclipse.persistence.descriptors.copying
Purpose: Allows customization of how an object is cloned.
AbstractCopyPolicy() - Constructor for class org.eclipse.persistence.descriptors.copying.AbstractCopyPolicy
 
AbstractDirectMapping - Class in org.eclipse.persistence.mappings.foundation
Purpose: Maps an attribute to the corresponding database field type.
AbstractDirectMapping() - Constructor for class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
Default constructor.
AbstractIdentityMap - Class in org.eclipse.persistence.internal.identitymaps
Purpose: Caches objects, and allows their retrieval by their primary key.
AbstractIdentityMap() - Constructor for class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
 
AbstractIdentityMap(int, ClassDescriptor, AbstractSession, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Instantiate an new IdentityMap with it's maximum size.
AbstractIdentityMapEnumeration<T> - Class in org.eclipse.persistence.internal.identitymaps
Abstract Enumeration interface implementation for IdentityMap interface.
AbstractIdentityMapEnumeration(Collection<CacheKey>, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMapEnumeration
Creates an instance of CacheKey content enumeration.
AbstractMarshalRecord<ABSTRACT_SESSION extends CoreAbstractSession,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​NAMESPACE_RESOLVER extends NamespaceResolver> - Interface in org.eclipse.persistence.internal.oxm.record
This class represents marshal record behaviour that is common to all XML platforms.
AbstractMarshalRecordImpl<ABSTRACT_SESSION extends CoreAbstractSession,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​NAMESPACE_RESOLVER extends NamespaceResolver> - Class in org.eclipse.persistence.internal.oxm.record
 
AbstractMarshalRecordImpl(AbstractMarshalRecord) - Constructor for class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
AbstractNullPolicy - Class in org.eclipse.persistence.oxm.mappings.nullpolicy
PUBLIC: Description: This node null policy allows for the handling of various representations of null in XML documents.
AbstractNullPolicy() - Constructor for class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
Default constructor.
AbstractRecord - Class in org.eclipse.persistence.internal.sessions
Purpose: Define the abstract definition of a record for internal use.
AbstractRecord() - Constructor for class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: converts JDBC results to collections of rows.
AbstractRecord(int) - Constructor for class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: converts JDBC results to collections of rows.
AbstractRecord(Vector, Vector) - Constructor for class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: converts JDBC results to collections of rows.
AbstractRecord(Vector, Vector, int) - Constructor for class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: converts JDBC results to collections of rows.
AbstractRecord.EntrySet - Class in org.eclipse.persistence.internal.sessions
Defines the virtual entrySet.
AbstractRecord.KeySet - Class in org.eclipse.persistence.internal.sessions
Defines the virtual keySet.
AbstractRecord.NoEntry - Class in org.eclipse.persistence.internal.sessions
INTERNAL: NoEntry: This is used to differentiate between the two kinds of nulls: no entry exists, and the field is actually mapped to null.
AbstractRecord.RecordEntry - Class in org.eclipse.persistence.internal.sessions
Entry class for implementing Map interface.
AbstractRecord.RecordEntryIterator - Class in org.eclipse.persistence.internal.sessions
Defines the virtual entrySet iterator.
AbstractRecord.RecordKeyIterator - Class in org.eclipse.persistence.internal.sessions
Defines the virtual keySet iterator.
AbstractRecord.RecordValuesIterator - Class in org.eclipse.persistence.internal.sessions
Defines the virtual valuesSet iterator.
AbstractRecord.ValuesSet - Class in org.eclipse.persistence.internal.sessions
Defines the virtual valuesSet.
AbstractSerializedObjectPolicy - Class in org.eclipse.persistence.internal.descriptors
The base class for SerializedObjectPolicy.
AbstractSerializedObjectPolicy() - Constructor for class org.eclipse.persistence.internal.descriptors.AbstractSerializedObjectPolicy
 
AbstractSerializer - Class in org.eclipse.persistence.sessions.serializers
Abstract Serializer class.
AbstractSerializer() - Constructor for class org.eclipse.persistence.sessions.serializers.AbstractSerializer
 
AbstractSession - Class in org.eclipse.persistence.internal.sessions
Implementation of org.eclipse.persistence.sessions.Session The public interface should be used.
AbstractSession() - Constructor for class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Create and return a new session.
AbstractSession(int) - Constructor for class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Create a blank session, used for proxy session.
AbstractSession(Login) - Constructor for class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Create and return a new session.
AbstractSession(Project) - Constructor for class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Create and return a new session.
AbstractSessionLog - Class in org.eclipse.persistence.logging
Represents the abstract log that implements all the generic logging functions.
AbstractSessionLog() - Constructor for class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC: Create a new AbstractSessionLog
AbstractSynchronizationListener - Class in org.eclipse.persistence.transaction
Purpose: Abstract Synchronization Listener class Description: This abstract class is paired with the AbstractTransactionController class.
AbstractSynchronizationListener() - Constructor for class org.eclipse.persistence.transaction.AbstractSynchronizationListener
INTERNAL:
AbstractSynchronizationListener(UnitOfWorkImpl, AbstractSession, Object, AbstractTransactionController) - Constructor for class org.eclipse.persistence.transaction.AbstractSynchronizationListener
INTERNAL:
AbstractTransactionController - Class in org.eclipse.persistence.transaction
Purpose: Abstract implementation of an ExternalTransactionController.
AbstractTransactionController() - Constructor for class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return a new controller.
AbstractTransformationMapping - Class in org.eclipse.persistence.mappings.foundation
Purpose: A transformation mapping is used for a specialized translation between how a value is represented in Java and its representation on the databae.
AbstractTransformationMapping() - Constructor for class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Default constructor.
AbstractUnmarshalRecord<ABSTRACT_SESSION extends CoreAbstractSession,​FIELD extends CoreField,​UNMARSHALLER extends Unmarshaller> - Interface in org.eclipse.persistence.internal.oxm.record
This class represents unmarshal record behaviour that is common to all XML platforms.
ABYTE - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
accept() - Method in interface org.eclipse.persistence.internal.security.PrivilegedAccessHelper.PrivilegedExceptionConsumer
 
ACCESS_EXTERNAL_DTD - Static variable in class org.eclipse.persistence.internal.helper.XMLHelper
 
ACCESS_EXTERNAL_SCHEMA - Static variable in class org.eclipse.persistence.internal.helper.XMLHelper
 
accessLevel - Variable in class org.eclipse.persistence.internal.codegen.CodeDefinition
 
AccessLevel - Class in org.eclipse.persistence.internal.codegen
INTERNAL:
AccessLevel() - Constructor for class org.eclipse.persistence.internal.codegen.AccessLevel
 
AccessLevel(int) - Constructor for class org.eclipse.persistence.internal.codegen.AccessLevel
 
accessor - Variable in class org.eclipse.persistence.eis.EISMappedRecord
 
accessor - Variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
accessor - Variable in class org.eclipse.persistence.internal.databaseaccess.ConnectionCustomizer
 
accessor - Variable in class org.eclipse.persistence.internal.sessions.ResultSetRecord
 
Accessor - Interface in org.eclipse.persistence.internal.databaseaccess
INTERNAL: Accessor defines the interface used primarily by the assorted TopLink Sessions to interact with a data store.
Accessor_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
accessors - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
The connection to the data store.
accessors - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Connection to use for database access, required for server session connection pooling.
accessorTree - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
A list of AttributeAccessors in order of access from root to leaf to arrive at current AggregateDescriptor.
AccessPlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides Microsoft Access specific behavior.
AccessPlatform() - Constructor for class org.eclipse.persistence.platform.database.AccessPlatform
Default constructor.
ACHAR - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
acos() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
acos(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Acos - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
acquire() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Wait for all threads except the active thread.
acquire() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Acquire the lock on the cache key object.
acquire() - Method in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
Avoid acquiring locks for unit of work.
acquire() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
Acquire the lock on the cache key object.
acquire(boolean) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Wait for all threads except the active thread.
acquire(boolean) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Acquire the lock on the cache key object.
acquire(boolean) - Method in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
Avoid acquiring locks for unit of work.
acquire(boolean) - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
Acquire the lock on the cache key object.
acquireAccessor(String, ServerSession, DatabaseQuery, boolean) - Method in class org.eclipse.persistence.descriptors.partitioning.PartitioningPolicy
INTERNAL: Return an accessor from the pool.
acquireClientConnection(ClientSession) - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Allocate the client's connection resource.
acquireClientSession() - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Return a client session for this server session.
acquireClientSession() - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return a client session for this server session.
acquireClientSession(String) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Return a client session for this server session.
acquireClientSession(String) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return a client session for this server session.
acquireClientSession(String, Map) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return a client session for this server session.
acquireClientSession(Map) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return a client session for this server session.
acquireClientSession(Login) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Return a client session for this server session.
acquireClientSession(Login) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return a client session for this server session.
acquireClientSession(Login, Map) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return a client session for this server session.
acquireClientSession(ConnectionPolicy) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Return a client session for this server session.
acquireClientSession(ConnectionPolicy) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return a client session for this server session.
acquireClientSession(ConnectionPolicy, Map) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return a client session for this server session.
acquireClientSessionBroker() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Return a session broker that behaves as a client session broker.
acquireClientSessionBroker(Map<String, ConnectionPolicy>, Map) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Return a session broker that behaves as a client session broker.
acquireConnection() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: Wait until a connection is available and allocate the connection for the client.
acquireConnection() - Method in class org.eclipse.persistence.sessions.server.ExternalConnectionPool
INTERNAL: When we acquire a connection from an ExternalConnectionPool we build a new connection (retrieve it from the external pool).
acquireConnection() - Method in class org.eclipse.persistence.sessions.server.ReadConnectionPool
INTERNAL: Wait until a connection is available and allocate the connection for the client.
acquireDeferredLock() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Add deferred lock into a hashtable to avoid deadlock
acquireDeferredLock() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Acquire the deferred lock.
acquireDeferredLock() - Method in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
Avoid acquiring locks for unit of work.
acquireDeferredLock() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
Acquire the deferred lock.
acquireDeferredLock(Object, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Acquire a deferred lock on the object.
acquireDeferredLock(Object, boolean) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Acquire a deferred lock on the object.
acquireDeferredLock(Object, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
Avoid acquiring any lock as uow is single threaded.
acquireDeferredLock(Object, boolean) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Acquire a deferred lock on the object.
acquireDeferredLock(Object, Class<?>, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Provides access for setting a deferred lock on an object in the IdentityMap.
acquireDeferredLock(Object, Class<?>, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Deferred lock the identity map for the object, this is used for avoiding deadlock The return cacheKey should be used to release the deferred lock.
acquireDeferredLock(Object, Class<?>, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Deferred lock the identity map for the object, this is used for avoiding deadlock The return cacheKey should be used to release the deferred lock
acquiredLocks - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
Used to store the list of locks that this merge manager has acquired for this merge
acquireHistoricalSession(AsOfClause) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Constructs a HistoricalSession given a valid AsOfClause.
acquireHistoricalSession(AsOfClause) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Acquires a special historical session for reading objects as of a past time.
acquireHistoricalSession(AsOfClause) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Acquires a special historical session for reading objects as of a past time.
acquireHistoricalSession(AsOfClause) - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
INTERNAL: Acquires a special historical session for reading objects as of a past time.
acquireHistoricalSession(AsOfClause) - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Acquires a special historical session for reading objects as of a past time.
acquireHistoricalSession(AsOfClause) - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Returns a light weight read-only session where all objects are automatically read as of the specified past time.
acquireIfUnownedNoWait() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Acquire the lock on the cache key object.
acquireIfUnownedNoWait() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
Acquire the lock on the cache key object.
acquireIfUnownedNoWait(boolean) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
If the activeThread is not set, acquire it and return true.
acquireLock(Object, boolean, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Acquire an active lock on the object.
acquireLock(Object, boolean, boolean) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Acquire an active lock on the object.
acquireLock(Object, boolean, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
Avoid acquiring any lock as uow is single threaded.
acquireLock(Object, boolean, boolean) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Acquire an active lock on the object.
acquireLock(Object, Class<?>, boolean, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Provides access for setting a concurrency lock on an object in the IdentityMap.
acquireLock(Object, Class<?>, boolean, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Provides access for setting a concurrency lock on an object in the IdentityMap.
acquireLock(Object, Class<?>, boolean, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Provides access for setting a concurrency lock on an object in the IdentityMap.
acquireLock(Object, Class<?>, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Lock the identity map for the object, this must be done when building objects.
acquireLock(ObjectBuildingQuery) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
acquireLockAndRelatedLocks(Object, Map, Map, CacheKey, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.helper.WriteLockManager
INTERNAL: This is a recursive method used to acquire read locks on all objects that will be cloned.
acquireLockNoWait(Object, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Acquire an active lock on the object, if not already locked.
acquireLockNoWait(Object, boolean) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Acquire an active lock on the object, if not already locked.
acquireLockNoWait(Object, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
Avoid acquiring any lock as uow is single threaded.
acquireLockNoWait(Object, boolean) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Acquire an active lock on the object, if not already locked.
acquireLockNoWait(Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Provides access for setting a concurrency lock on an object in the IdentityMap.
acquireLockNoWait(Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Provides access for setting a concurrency lock on an object in the IdentityMap.
acquireLockNoWait(Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Provides access for setting a concurrency lock on an object in the IdentityMap.
acquireLocks() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Set the query to lock, this will also turn refreshCache on.
acquireLocksForClone(Object, ClassDescriptor, CacheKey, AbstractSession) - Method in class org.eclipse.persistence.internal.helper.WriteLockManager
INTERNAL: This method will return once the object is locked and all non-indirect related objects are also locked.
acquireLocksWithoutWaiting() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Set the query to lock without waiting (blocking), this will also turn refreshCache on.
acquireLockWithWait(Object, boolean, int) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Acquire an active lock on the object, if not already locked.
acquireLockWithWait(Object, boolean, int) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Acquire an active lock on the object, if not already locked.
acquireLockWithWait(Object, boolean, int) - Method in class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
Avoid acquiring any lock as uow is single threaded.
acquireLockWithWait(Object, boolean, int) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Acquire an active lock on the object, if not already locked.
acquireLockWithWait(Object, Class<?>, boolean, ClassDescriptor, int) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Provides access for setting a concurrency lock on an object in the IdentityMap.
acquireLockWithWait(Object, Class<?>, boolean, ClassDescriptor, int) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Provides access for setting a concurrency lock on an object in the IdentityMap.
acquireLockWithWait(Object, Class<?>, boolean, ClassDescriptor, int) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Provides access for setting a concurrency lock on an object in the IdentityMap.
acquireNonSynchronizedUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return a unit of work for this session not registered with the JTS transaction.
acquireNonSynchronizedUnitOfWork(ReferenceMode) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return a unit of work for this session not registered with the JTS transaction.
acquireNoWait() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
If the lock is not acquired already acquire it and return true.
acquireNoWait() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Acquire the lock on the cache key object.
acquireNoWait() - Method in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
Avoid acquiring locks for unit of work.
acquireNoWait() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
Acquire the lock on the cache key object.
acquireNoWait(boolean) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
If the lock is not acquired already acquire it and return true.
acquireNoWait(boolean) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Acquire the lock on the cache key object.
acquireNoWait(boolean) - Method in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
Avoid acquiring locks for unit of work.
acquireNoWait(boolean) - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
Acquire the lock on the cache key object.
acquireReadLock() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Wait on any writer.
acquireReadLock() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Acquire the read lock on the cache key object.
acquireReadLock() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Provides access for setting a concurrency lock on an IdentityMap.
acquireReadLock() - Method in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
Avoid acquiring locks for unit of work.
acquireReadLock() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
Acquire the read lock on the cache key object.
acquireReadLockNoWait() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
If this is acquired return false otherwise acquire readlock and return true
acquireReadLockNoWait() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Acquire the read lock on the cache key object.
acquireReadLockNoWait() - Method in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
Avoid acquiring locks for unit of work.
acquireReadLockNoWait() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
Acquire the read lock on the cache key object.
acquireReadLockOnCacheKey(Object) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Acquire a read lock on the object.
acquireReadLockOnCacheKey(Object) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Acquire a read lock on the object.
acquireReadLockOnCacheKey(Object) - Method in class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
Avoid acquiring any lock as uow is single threaded.
acquireReadLockOnCacheKey(Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Acquire a read lock on the object.
acquireReadLockOnCacheKey(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
INTERNAL: Find the cachekey for the provided primary key and place a readlock on it.
acquireReadLockOnCacheKey(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Find the cachekey for the provided primary key and place a readlock on it.
acquireReadLockOnCacheKey(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Find the cachekey for the provided primary key and place a readlock on it.
acquireReadLockOnCacheKeyNoWait(Object) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Acquire a read lock on the object, if not already locked.
acquireReadLockOnCacheKeyNoWait(Object) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Acquire a read lock on the object, if not already locked.
acquireReadLockOnCacheKeyNoWait(Object) - Method in class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
Avoid acquiring any lock as uow is single threaded.
acquireReadLockOnCacheKeyNoWait(Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Acquire a read lock on the object, if not already locked.
acquireReadLockOnCacheKeyNoWait(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
INTERNAL: Find the cachekey for the provided primary key and place a readlock on it.
acquireReadLockOnCacheKeyNoWait(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Find the cachekey for the provided primary key and place a readlock on it.
acquireReadLockOnCacheKeyNoWait(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Find the cachekey for the provided primary key and place a readlock on it.
acquireRepeatableWriteUnitOfWork(ReferenceMode) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return a repeatable write unit of work for this session.
acquireRepeatableWriteUnitOfWork(ReferenceMode) - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
PUBLIC: Return a repeatable write unit of work for this session.
acquireRequiredLocks(MergeManager, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.helper.WriteLockManager
INTERNAL: This method will be the entry point for threads attempting to acquire locks for all objects that have a changeset.
acquireSemaphoreIfAppropriate(boolean) - Method in class org.eclipse.persistence.internal.helper.ConcurrencySemaphore
Do nothing if the semaphore has already been acquired by this thread in a higher recursive call or if the configuration to acquire the slow down semaphore is not active.
acquireSession() - Method in class org.eclipse.persistence.sessions.factories.SessionFactory
Returns the Session active for this specified helper.
acquireTransactionManager() - Method in class org.eclipse.persistence.transaction.glassfish.GlassfishTransactionController
INTERNAL: Obtain and return the JTA TransactionManager on this platform
acquireTransactionManager() - Method in class org.eclipse.persistence.transaction.glassfish.GlassfishTransactionController11
INTERNAL: Obtain and return the JTA TransactionManager on this platform
acquireTransactionManager() - Method in class org.eclipse.persistence.transaction.jboss.JBossTransactionController
INTERNAL: Obtain and return the JTA TransactionManager on this platform
acquireTransactionManager() - Method in class org.eclipse.persistence.transaction.jboss.JBossTransactionController11
INTERNAL: Obtain and return the JTA TransactionManager on this platform
acquireTransactionManager() - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Obtain and return the JTA TransactionManager on this platform.
acquireTransactionManager() - Method in class org.eclipse.persistence.transaction.sap.SAPNetWeaverTransactionController
 
acquireTransactionManager() - Method in class org.eclipse.persistence.transaction.was.WebSphereTransactionController
INTERNAL: Obtain and return the JTA TransactionManager on this platform.
acquireTransactionManager() - Method in class org.eclipse.persistence.transaction.wls.WebLogicTransactionController
INTERNAL: Obtain and return the JTA TransactionManager on this platform
acquireTransactionManager() - Method in class org.eclipse.persistence.transaction.wls.WebLogicTransactionController11
INTERNAL: Obtain and return the JTA TransactionManager on this platform
acquireTransactionSynchronizationRegistry() - Method in class org.eclipse.persistence.transaction.glassfish.GlassfishTransactionController11
INTERNAL: Obtain and return the JTA 1.1 TransactionSynchronizationRegistry on this platform.
acquireTransactionSynchronizationRegistry() - Method in class org.eclipse.persistence.transaction.jboss.JBossTransactionController11
INTERNAL: Obtain and return the JTA 1.1 TransactionSynchronizationRegistry on this platform.
acquireTransactionSynchronizationRegistry() - Method in class org.eclipse.persistence.transaction.JTA11TransactionController
INTERNAL: Obtain and return the JTA 1.1 TransactionSynchronizationRegistry on this platform.
acquireTransactionSynchronizationRegistry() - Method in class org.eclipse.persistence.transaction.wls.WebLogicTransactionController11
INTERNAL: Obtain and return the JTA 1.1 TransactionSynchronizationRegistry on this platform.
acquireUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return a unit of work for this session.
acquireUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
The nested unit of work must also be remote.
acquireUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Return a nested unit of work for this unit of work.
acquireUnitOfWork() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Return a unit of work for this session broker.
acquireUnitOfWork() - Method in class org.eclipse.persistence.sessions.factories.SessionFactory
Looks up the active UnitOfWork using either the global JTA TX or acquires a new one from the active session.
acquireUnitOfWork() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Return a unit of work for this session.
acquireUnitOfWork() - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
PUBLIC: Return a unit of work for this session.
acquireUnitOfWork() - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return a unit of work for this session.
acquireUnitOfWork() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return a unit of work for this session.
acquireUnitOfWork(ReferenceMode) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return a unit of work for this session.
acquireUnitOfWork(ReferenceMode) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
The nested unit of work must also be remote.
acquireUnitOfWork(ReferenceMode) - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
PUBLIC: Return a unit of work for this session.
acquireUnitOfWork(ReferenceMode) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return a unit of work for this session.
acquireUnitOfWork(Session) - Method in class org.eclipse.persistence.sessions.factories.SessionFactory
Looks up the active UnitOfWork using either the global JTA TX or acquires a new one from the active session.
acquireWithWait(boolean, int) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
If the lock is not acquired already acquire it and return true.
acquireWithWait(boolean, int) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Acquire the lock on the cache key object.
acquireWriteLock() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Lock the entire cache if the cache isolation requires.
acquireWriteLock() - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Lock the entire cache if the cache isolation requires.
acquireWriteLock() - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Lock the entire cache if the cache isolation requires.
acquireWriteLocks() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Acquire the unit of work cache write locks, if required.
ACTIVE_LOCK_ALREADY_TRANSITIONED - Static variable in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
activeBatchWritingMechanism - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
This attribute will be used to store the currently active Batch Mechanism
activeCacheKey - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
PERF: Cache the session cacheKey during the merge to avoid duplicate lookups.
activeCommandThreads - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
List of active command threads.
activeLockAlreadyTransitioned(Thread) - Static method in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
activeLocks - Variable in class org.eclipse.persistence.internal.helper.DeferredLockManager
 
activeThread - Variable in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
activeUnitOfWorkThreadLocal - Variable in class org.eclipse.persistence.transaction.AbstractTransactionController
PERF: Cache the active uow in a thread local.
actualTypeClassName - Variable in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
Stores the actual type of the mapping if different from the reference type.
ADAPTER_CLASS_COULD_NOT_BE_INSTANTIATED - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
ADAPTER_CLASS_METHOD_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
ADAPTER_CLASS_NOT_LOADED - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
adapterClassCouldNotBeInstantiated(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: An exception occurred while attempting to get a new instance of the adapter class.
adapterClassMethodsCouldNotBeAccessed(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: An exception occurred while attempting to get the declared methods from the adapter class.
adapterClassNotLoaded(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: The adapter class set on XMLJavaTypeConverter could not be loaded.
add() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
add(int, E) - Method in class org.eclipse.persistence.indirection.IndirectList
 
add(int, E) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
add(int, E) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Add and notify any waiters that there are new elements.
add(int, Object) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
add(E) - Method in class org.eclipse.persistence.indirection.IndirectList
 
add(E) - Method in class org.eclipse.persistence.indirection.IndirectSet
 
add(E) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
add(E) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Add and notify any waiters that there are new elements.
add(FIELD, Object) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
add(Object) - Method in class org.eclipse.persistence.internal.helper.IdentityHashSet
Adds the given object to this IdentityHashSet.
add(Object) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
add(Object) - Method in class org.eclipse.persistence.internal.identitymaps.CacheId
Append the value to the end of the primary key values.
add(Object) - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Add is not support for scrollable cursors.
add(Expression, int) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
add(Expression, Object) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
add(CoreField, Object) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
INTERNAL: Add the field-value pair to the document.
add(CoreField, Object) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
add(DatabaseField, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: Add the field-value pair to the row.
add(DatabaseField, Object) - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
INTERNAL: Add the field-value pair to the row.
add(DatabaseField, Object) - Method in class org.eclipse.persistence.internal.sessions.EmptyRecord
 
add(DatabaseField, Object) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Add the field-value pair to the document.
add(FieldResult) - Method in class org.eclipse.persistence.queries.FieldResult
INTERNAL: This method is used to support mapping multiple fields, fields are concatenated/added to one fieldResult.
add(Node) - Method in class org.eclipse.persistence.platform.xml.XMLNodeList
 
Add - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
ADD - Static variable in class org.eclipse.persistence.descriptors.changetracking.CollectionChangeEvent
 
ADD_ARGS_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
addAbstractQueryKey(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This method should only be used for interface descriptors.
addActiveLock(Object) - Method in class org.eclipse.persistence.internal.helper.DeferredLockManager
add a concurrency manager as active locks to the DLM
addAddedChangeSet(Object) - Method in class org.eclipse.persistence.eis.EISCollectionChangeRecord
Add an added change set.
addAddedChangeSet(Object, int) - Method in class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
Add an added change set.
addAdditionalExpression(Expression) - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
 
addAdditionalExpressionsWithinCurrrentExpressionContext - Variable in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
Used to trigger adding additional join operations etc to the expression being processed instead of at the end of the where clause.
addAdditionalField(Expression) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Additional fields can be added to a query.
addAdditionalField(DatabaseField) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Additional fields can be added to a query.
addAdditionalFieldsToQuery(ReadQuery, Expression) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Called when the selection query is being initialized to add any required additional fields to the query.
addAdditionalFieldsToQuery(ReadQuery, Expression) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Called when the selection query is being initialize to add the fields for the key to the query
addAdditionalFieldsToQuery(ReadQuery, Expression) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Add the index field to the query.
addAdditionalFieldsToQuery(ReadQuery, Expression) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Used when initializing queries for mappings that use a Map Called when the selection query is being initialized to add the fields for the map key to the query
addAdditionalFieldsToQuery(ReadQuery, Expression) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Used when initializing queries for mappings that use a Map.
addAdditionalFieldsToQuery(ReadQuery, Expression) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Used when initializing queries for mappings that use a Map Called when the selection query is being initialized to add the fields for the map key to the query
addAdditionalFieldsToQuery(ReadQuery, Expression) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Used when initializing queries for mappings that use a Map.
addAdditionalLocalExpression(Expression) - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
Similar to addAdditionalExpression, this keeps a running expression used for joins so that they can be added locally within 'OR' predicates rather than to the entire where clause.
addAdditionChange(Object, Integer) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
This method takes a single addition value and records it.
addAdditionChange(Object, Object) - Method in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
Adds the items that were added to the collection.
addAdditionChange(HashMap) - Method in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
Adds the items that were added to the collection.
addAdditionChange(HashMap, HashMap) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
This method takes a map of primitive objects and adds them to the add list.
addAdditionChange(Map, ContainerPolicy, UnitOfWorkChangeSet, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This method takes a Map of objects, converts these into ObjectChangeSets.
addAggregateCollectionMappingLines(NonreflectiveMethodDefinition, String, AggregateCollectionMapping) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addAggregateObjectMapping(String, DynamicType, boolean) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Add a AggregateObjectMapping (Embeddable in JPA) to the DynamicTypeBuilder.entityType being built or extended.
addAggregateObjectMappingLines(NonreflectiveMethodDefinition, String, AggregateObjectMapping) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addAggregateOrderBy(String, String, boolean) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Provide order support for queryKeyName in ascending or descending order.
addAlias(String, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Add an alias for the descriptor
addAlias(String, ClassDescriptor) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Add an alias for the descriptor.
addAll(int, Collection) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
addAll(int, Collection<? extends E>) - Method in class org.eclipse.persistence.indirection.IndirectList
 
addAll(int, Collection<? extends E>) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
addAll(int, Collection<? extends E>) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
addAll(int, Collection<? extends E>) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Add and notify any waiters that there are new elements.
addAll(Collection) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
addAll(Collection<? extends E>) - Method in class org.eclipse.persistence.indirection.IndirectList
 
addAll(Collection<? extends E>) - Method in class org.eclipse.persistence.indirection.IndirectSet
 
addAll(Collection<? extends E>) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
addAll(Collection<? extends E>) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
addAll(Collection<? extends E>) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Add and notify any waiters that there are new elements.
addAll(List, Object, AbstractSession, List<AbstractRecord>, DataReadQuery, CacheKey, boolean) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: This is used for ordered List containers to add all of the elements to the collection in the order of the index field in the row.
addAll(List, Object, AbstractSession, List<AbstractRecord>, DataReadQuery, CacheKey, boolean) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Add a list of elements to container.
addAll(List, Object, AbstractSession, List<AbstractRecord>, ObjectBuildingQuery, CacheKey, boolean) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: This is used for ordered List containers to add all of the elements to the collection in the order of the index field in the row.
addAll(List, Object, AbstractSession, List<AbstractRecord>, ObjectBuildingQuery, CacheKey, boolean) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Add a list of elements to container.
addAll(List, Object, AbstractSession, List<AbstractRecord>, ReadQuery, CacheKey) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
 
addAll(NodeList) - Method in class org.eclipse.persistence.platform.xml.XMLNodeList
 
addAllObjectsForAbstractClass(Class<?>, AbstractSession, Vector<Object>) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Add all of the objects of the class and all of its subclasses.
addAllObjectsForAbstractClass(Class<?>, Session, Vector<Object>) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Add all of the objects of the class and all of its subclasses.
addAllObjectsForClass(Class<?>, List<Object>) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Add all of the objects of the class.
addAllToVector(Vector<E>, Vector<? extends E>) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
addAllUniqueToList(List<T>, List<T>) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
addAllUniqueToVector(Vector<T>, List<T>) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
addAndPrepareJoinedMapping(ForeignReferenceMapping, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Add the mapping for join fetch, prepare and return the join expression being used.
addAny(Any) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
addAny(Any) - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
addAny(Any) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
addArgument(Class<?>, String) - Method in class org.eclipse.persistence.internal.codegen.ReflectiveMethodDefinition
 
addArgument(String) - Method in class org.eclipse.persistence.eis.interactions.IndexedInteraction
PUBLIC: Define the argument to the interaction for the index argument.
addArgument(String) - Method in class org.eclipse.persistence.eis.interactions.MappedInteraction
PUBLIC: Define the argument to the interaction and the field/argument name to be substitute for it.
addArgument(String) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Add the argument named argumentName.
addArgument(String, Class<?>) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Add the argument named argumentName and its class type.
addArgument(String, Class<?>) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The arguments are the names of the parameters to the procedure.
addArgument(String, Class<?>, boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Add the argument named argumentName and its class type.
addArgument(String, Class<?>, int) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The arguments are the names of the parameters to the procedure.
addArgument(String, Class<?>, DatabaseQuery.ParameterType) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Add the argument named argumentName.
addArgument(String, Class<?>, DatabaseQuery.ParameterType, boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Add the argument named argumentName.
addArgument(String, String) - Method in class org.eclipse.persistence.eis.interactions.MappedInteraction
PUBLIC: Define the argument to the interaction and the field/argument name to be substitute for it.
addArgument(String, String) - Method in class org.eclipse.persistence.internal.codegen.NonreflectiveMethodDefinition
 
addArgument(String, String) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Add the argument named argumentName and its class type.
addArgument(String, String) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The arguments are the names of the parameters to the procedure.
addArgument(FieldDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The arguments are the names of the parameters to the procedure.
addArgumentByTypeName(String, String) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Add an argument to the query, but do not resolve the class yet.
addArgumentsNotSupported(String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
addArgumentValue(Object) - Method in class org.eclipse.persistence.eis.interactions.IndexedInteraction
PUBLIC: Define the argument to the interaction for the index argument.
addArgumentValue(Object) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Add the argumentValue.
addArgumentValue(String, Object) - Method in class org.eclipse.persistence.eis.interactions.MappedInteraction
PUBLIC: Define the argument to the interaction and the value name to be input for it.
addArgumentValues(List) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Add the argumentValues to the query.
addAscendingOrdering() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Provide ascending order support for this direct collection mapping.
addAscendingOrdering(String) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Provide order support for queryKeyName in ascending order
addAscendingOrdering(String) - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Order the query results by the object's attribute or query key name.
addAttribute(String) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Add a basic attribute or nested attribute with each String representing an attribute on the path to what needs to be included in the AttributeGroup.
addAttribute(String) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the attribute from the reference class to be included in the result.
addAttribute(String, Collection<? extends CoreAttributeGroup>) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Add an attribute and the corresponding list of AttributeGroups.
addAttribute(String, Collection<? extends CoreAttributeGroup>) - Method in class org.eclipse.persistence.queries.FetchGroup
 
addAttribute(String, CoreAttributeGroup) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Add a basic attribute or nested attribute with each String representing an attribute on the path to what needs to be included in the AttributeGroup.
addAttribute(String, CoreAttributeGroup) - Method in class org.eclipse.persistence.internal.queries.EntityFetchGroup
 
addAttribute(String, CoreAttributeGroup) - Method in class org.eclipse.persistence.queries.FetchGroup
 
addAttribute(String, CoreAttributeGroup) - Method in class org.eclipse.persistence.queries.LoadGroup
 
addAttribute(String, CoreAttributeGroup) - Method in class org.eclipse.persistence.sessions.CopyGroup
 
addAttribute(String, Expression) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the attribute to be included in the result.
addAttribute(String, Expression, Class<?>) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the attribute to be included in the result.
addAttribute(String, Expression, List) - Method in class org.eclipse.persistence.queries.ConstructorReportItem
Add the attribute with joining.
addAttribute(String, AttributeGroup) - Method in class org.eclipse.persistence.queries.AttributeGroup
Add a basic attribute or nested attribute with each String representing an attribute on the path to what needs to be included in the AttributeGroup.
addAttribute(String, LoadGroup) - Method in class org.eclipse.persistence.queries.LoadGroup
 
addAttribute(String, CopyGroup) - Method in class org.eclipse.persistence.sessions.CopyGroup
 
addAttribute(Expression) - Method in class org.eclipse.persistence.queries.ConstructorReportItem
Method to add an expression to be used to return the parameter that is then passed into the constructor method.
addAttribute(AttributeDefinition) - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
addAttribute(Attr) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
addAttributeGroup(ATTRIBUTE_GROUP) - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
Adds the attribute group to this descriptor.
addAttributeKey(String, CoreAttributeGroup) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Add a basic attribute or nested attribute with each String representing the key of an attribute of type Map on the path to what needs to be included in the AttributeGroup.
addAttributeKey(String, CoreAttributeGroup) - Method in class org.eclipse.persistence.queries.FetchGroup
 
addAttributes(Collection<String>) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Add a set of attributes to the group.
addAttributeValue(ContainerValue, Object) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
addAttributeValue(ContainerValue, Object) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
addAttributeValue(ContainerValue, Object) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
addAttributeValue(ContainerValue, Object, Object) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
addAttributeValue(ContainerValue, Object, Object) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
addAttributeValue(ContainerValue, Object, Object) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
addAttributeValue(UnmarshalRecord, ContainerValue, Object) - Method in class org.eclipse.persistence.internal.oxm.ChoiceUnmarshalContext
 
addAttributeValue(UnmarshalRecord, ContainerValue, Object) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectUnmarshalContext
 
addAttributeValue(UnmarshalRecord, ContainerValue, Object) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedUnmarshalContext
 
addAttributeValue(UnmarshalRecord, ContainerValue, Object) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalContext
When a collection mapping is processed the UnmarshalContext is responsible for handling the values one at a time.
addAttributeValue(UnmarshalRecord, ContainerValue, Object, Object) - Method in class org.eclipse.persistence.internal.oxm.ChoiceUnmarshalContext
 
addAttributeValue(UnmarshalRecord, ContainerValue, Object, Object) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectUnmarshalContext
 
addAttributeValue(UnmarshalRecord, ContainerValue, Object, Object) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedUnmarshalContext
 
addAttributeValue(UnmarshalRecord, ContainerValue, Object, Object) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalContext
When a collection mapping is processed the UnmarshalContext is responsible for handling the values one at a time.
addAverage(String) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the average value of the attribute to be included in the result.
addAverage(String, Class<?>) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the average value of the attribute to be included in the result and return it as the specified resultType.
addAverage(String, Expression) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the average value of the attribute to be included in the result.
addAverage(String, Expression, Class<?>) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the average value of the attribute to be included in the result and return it as the specified resultType.
addBatch(PreparedStatement) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: This gets called on each iteration to add parameters to the batch Needs to be implemented so that it returns the number of rows successfully modified by this statement for optimistic locking purposes (if useNativeBatchWriting is enabled, and the call uses optimistic locking).
addBatchReadAttribute(String) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Specify the foreign-reference mapped attribute to be optimized in this query.
addBatchReadAttribute(Expression) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Specify the foreign-reference mapped attribute to be optimized in this query.
addCacheIndex(String...) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Add the cache index to the descriptor's cache settings.
addCacheIndex(CacheIndex) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Add the cache index to the descriptor's cache settings.
addCacheIndex(DatabaseField[]) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Add the cache index to the descriptor's cache settings.
addCacheInvalidationPolicyLines(NonreflectiveMethodDefinition, ClassDescriptor) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addCacheKeyToMapWriteLockManagerToCacheKeysThatCouldNotBeAcquired(Thread, ConcurrencyManager, long) - Static method in class org.eclipse.persistence.internal.helper.WriteLockManager
The thread was doing its while loop to acquire all required locks to proceed with the commmit and it realized there was one cache key it is unable to acquire
addCall(DatasourceCall) - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Add the call.
addCall(Call) - Method in class org.eclipse.persistence.internal.helper.LOBValueWriter
Add original (insert or update) call to the collection
addCall(Call) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Used to define a store procedure or SQL query.
addCascadeLockingPolicy(CascadeLockingPolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Add the cascade locking policy to all children that have a relationship to this descriptor either by inheritance or by encapsulation/aggregation.
addChange(ChangeRecord) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Add the attribute change record.
addChangedMapKeyChangeSet(Object) - Method in class org.eclipse.persistence.eis.EISCollectionChangeRecord
Add an changed key change set.
addChild(Expression) - Method in class org.eclipse.persistence.internal.expressions.ArgumentListFunctionExpression
INTERNAL: Add a new Expression to the list of arguments.
addChild(Expression) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
addChild(HierarchyNode) - Method in class org.eclipse.persistence.internal.codegen.HierarchyNode
 
addChild(XPathFragment, NodeValue, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
addChild(Setting) - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
addChildDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Add child descriptor to the parent descriptor.
addChildDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Add child descriptor to the parent descriptor.
addChildTableJoinExpression(DatabaseTable, Expression) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: childrenTablesJoinExpressions, childrenTables, allTables and childrenJoinExpression are created simultaneously and kept in sync.
addChildTableJoinExpressionToAllParents(DatabaseTable, Expression) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: call addChildTableJoinExpression on all parents
addChoice(Choice) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
addChoice(Choice) - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
addChoice(Choice) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
addChoiceElement(String, Class<?>) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
addChoiceElement(String, Class<?>) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
addChoiceElement(String, Class<?>, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
addChoiceElement(String, Class<?>, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
addChoiceElement(String, String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
addChoiceElement(String, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
addChoiceElement(String, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
addChoiceElement(String, String, boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
addChoiceElement(String, String, String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
addChoiceElement(String, String, String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
addChoiceElement(String, String, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
addChoiceElement(String, String, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
addChoiceElement(List<XMLField>, Class<?>, List<XMLField>) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
addChoiceElement(List<XMLField>, Class<?>, List<XMLField>) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
addChoiceElement(List<XMLField>, String, List<XMLField>) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
addChoiceElement(List<XMLField>, String, List<XMLField>) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
addChoiceElement(List<XML_FIELD>, String, List<XML_FIELD>) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
addChoiceElement(List<XML_FIELD>, String, List<XML_FIELD>) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
addChoiceElement(XMLField, Class<?>) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
addChoiceElement(XMLField, Class<?>) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
addChoiceElement(XMLField, Class<?>, XMLField) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
addChoiceElement(XMLField, Class<?>, XMLField) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
addChoiceElement(XMLField, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
addChoiceElement(XMLField, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
addChoiceElement(XMLField, String, XMLField) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
addChoiceElement(XML_FIELD, String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
addChoiceElement(XML_FIELD, String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
addClass(String) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
Register a class to be dynamically created using the default DynamicClassWriter.
addClass(String, Class<?>) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
Register a class to be dynamically created using a copy of default DynamicClassWriter but specifying a different parent class.
addClass(String, EclipseLinkClassWriter) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
Register a class to be dynamically created using the provided DynamicClassWriter.
addClassIndicator(Class<?>, Object) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Add a class indicator for the root classes subclass.
addClassIndicator(Class<?>, Object) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
PUBLIC: Add a type indicator conversion to this mapping.
addClassIndicator(XMLDescriptor, String) - Method in class org.eclipse.persistence.internal.sessions.factories.DirectToXMLTypeMappingHelper
Add the XMLType mapping indicator to the DatabaseMapping descriptor.
addClassIndicator(XMLDescriptor, String) - Method in class org.eclipse.persistence.sessions.factories.OracleDirectToXMLTypeMappingHelper
Add the XMLType mapping indicator to the DatabaseMapping descriptor.
addClassIndicatorFieldToInsertRow(AbstractRecord) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Add abstract class indicator information to the database row.
addClassIndicatorFieldToRow(ABSTRACT_RECORD) - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL: Add abstract class indicator information to the database row.
addClassIndicatorFieldToRow(AbstractMarshalRecord) - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
addClassIndicatorFieldToRow(AbstractMarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
addClassIndicatorFieldToRow(AbstractMarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
addClassIndicatorFieldToRow(AbstractRecord) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Add abstract class indicator information to the database row.
addClassIndicatorFieldToRow(AbstractRecord) - Method in class org.eclipse.persistence.internal.oxm.QNameInheritancePolicy
INTERNAL: Add abstract class indicator information to the database row.
addClassIndicatorTypeToParent(Object) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Post initialize the child descriptors
addClassNameIndicator(String, Object) - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL: Add the class name reference by class name, used by the MW.
addClassNameIndicator(String, Object) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Add the class name reference by class name, used by the MW.
addClassNameIndicator(String, Object) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Add indicators by classname.
addCMPPolicyLines(NonreflectiveMethodDefinition, CMPPolicy) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addCollectionToMain(int, int, Collection<? extends DatabaseField>) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
 
addColumnResult(ColumnResult) - Method in class org.eclipse.persistence.queries.ConstructorResult
Add a column result to this constructor result.
addConnectionPool(String) - Method in class org.eclipse.persistence.descriptors.partitioning.HashPartitioningPolicy
PUBLIC: Add the connection pool name to the list of pools to rotate queries through.
addConnectionPool(String) - Method in class org.eclipse.persistence.descriptors.partitioning.ReplicationPartitioningPolicy
PUBLIC: Add the connection pool name to the list of pools to rotate queries through.
addConnectionPool(String, Login, int, int) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Add the connection pool.
addConnectionPool(String, Login, int, int) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Add the connection pool.
addConnectionPool(ConnectionPool) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Connection are pooled to share and restrict the number of database connections.
addConnectionPool(ConnectionPool) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Connection are pooled to share and restrict the number of database connections.
addConnectionPoolConfig(ConnectionPoolConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.PoolsConfig
 
addConnectionToExternalService(RemoteConnection) - Method in class org.eclipse.persistence.sessions.coordination.broadcast.BroadcastTransportManager
INTERNAL: Add a remote Connection to a remote service.
addConnectionToExternalService(RemoteConnection) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Add a remote Connection to a remote service.
addConstraintDependencies(Class<?>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: EclipseLink automatically orders database access through the foreign key information provided in 1:1 and 1:m mappings.
addConstraintDependency(Class<?>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: EclipseLink automatically orders database access through the foreign key information provided in 1:1 and 1:m mappings.
addConstructorReportItem(ConstructorReportItem) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add a ConstructorReportItem to this query's set of return values.
addContext(DatabaseField, Object) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Add a field - value pair for LOB field into the context.
addConversion(QName, Class<?>) - Method in class org.eclipse.persistence.oxm.XMLField
Add an entry for both an XML Conversion and a Java Conversion entry
addConversionValue(Object, Object) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
PUBLIC: A type conversion value is a two-way mapping from the database to the object.
addConversionValueStrings(String, String) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Set from JPA processing where we deal with strings only to avoid class loader conflicts.
addConverter(Converter, String) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Add a converter to be applied to a mapping of the aggregate descriptor.
addConverter(Converter, String) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
Add a converter to be applied to a mapping of the aggregate descriptor.
addConverter(Converter, String) - Method in interface org.eclipse.persistence.mappings.EmbeddableMapping
 
addConverter(XMLField, Converter) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
addConverter(XMLField, Converter) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
addConverter(XML_FIELD, CONVERTER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
addConverter(XML_FIELD, CONVERTER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
addConverterLines(NonreflectiveMethodDefinition, String, Converter) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addCount() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Include the number of rows returned by the query in the result.
addCount(String) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Include the number of rows returned by the query in the result, where attributeExpression is not null.
addCount(String, Class<?>) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Include the number of rows returned by the query in the result, where attributeExpression is not null.
addCount(String, Expression) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Include the number of rows returned by the query in the result, where attributeExpression is not null.
addCount(String, Expression, Class<?>) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Include the number of rows returned by the query in the result, where attributeExpression is not null.
addDataModificationEvent(DatabaseMapping, Object[]) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Add the data query to be performed at the end of the commit.
addDataResults(AbstractRecord) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Add the row to the set of data results.
addDate() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
addDate() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Adds to a date the specified addition number as the specified interval unit and returns the resulting date.
Builds Symfoware equivalent to addDate(unit, number).
Symfoware: ADD_DATE(date, number, unit)
addDate(String, int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, return an expression that adds to a date based on the specified datePart.
addDate(String, Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, return an expression that adds to a date based on the specified datePart.
AddDate - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
addDefaultEventListener(DescriptorEventListener) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: EJB 3.0 support for default listeners.
addDefaultReadOnlyClass(Class<?>) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Add the read-only class which apply to each UnitOfWork created by default.
addDeferredCall(DatabaseTable, DatasourceCall, DatabaseQueryMechanism) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Add the data query to be performed at the end of the commit.
addDeferredLock(Object) - Method in class org.eclipse.persistence.internal.helper.DeferredLockManager
add a concurrency manager as deferred locks to the DLM
addDeletedObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Add the Deleted object to the changeSet.
addDeletedObjects(Map, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Add the Deleted objects to the changeSet.
addDeletedPrivateOwnedObjects(DatabaseMapping, Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Records a private owned object that has been de-referenced and will need to processed for related private owned objects.
addDeletionDependency(Object, Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Record deleted objects that have reference to other deleted objects.
addDerivedExpression(Expression) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL: Add the expression as a derived child of this expression.
addDerivedField(Expression) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
addDerivedTable(Expression) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
addDescendingOrdering() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Provide descending order support for this direct collection mapping.
addDescendingOrdering(String) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Provide order support for queryKeyName in descending order.
addDescendingOrdering(String) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Order the query results by the object's attribute or query key name.
addDescriptor(DESCRIPTOR) - Method in class org.eclipse.persistence.core.sessions.CoreProject
 
addDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Add the descriptor to the session.
addDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: You cannot add a descriptor to a session broker, you must add it to its session.
addDescriptor(ClassDescriptor) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Add the descriptor to the session.
addDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Add the descriptor to the project.
addDescriptor(ClassDescriptor, DatabaseSessionImpl) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Used by the BuilderInterface when reading a Project from INI files.
addDescriptorByQName(QName, DESCRIPTOR) - Method in class org.eclipse.persistence.internal.oxm.Context.ContextState
 
addDescriptorByQName(QName, XMLDescriptor) - Method in class org.eclipse.persistence.oxm.XMLContext
 
addDescriptorNamespacesToXMLRecord(DESCRIPTOR, AbstractMarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
addDescriptorPropertyLines(NonreflectiveMethodDefinition, ClassDescriptor) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addDescriptors(Collection) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Add the descriptors to the session.
addDescriptors(Collection) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Add the descriptors to the session.
addDescriptors(Collection, DatabaseSessionImpl) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Add the descriptors to the session.
addDescriptors(Vector) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: You cannot add descriptors to a session broker, you must add them to its session.
addDescriptors(Project) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Add the descriptors to the session from the Project.
addDescriptors(Project) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: You cannot add a project to a session broker, you must add it to its session.
addDescriptors(Project) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Add the descriptors to the session from the Project.
addDescriptors(Project, DatabaseSessionImpl) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Merge the descriptors from another project into this one.
addDescriptorsToSequencing(Collection<ClassDescriptor>) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: If sequencing is connected then initializes sequences referenced by the passed descriptors, otherwise connects sequencing.
addDirectCollectionMapping(String, String, String, Class<?>, String...) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Add a DirectCollectionMapping to the DynamicTypeBuilder.entityType being built or extended.
addDirectCollectionMappingLines(NonreflectiveMethodDefinition, String, DirectCollectionMapping) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addDirectMapMappingLines(NonreflectiveMethodDefinition, String, DirectMapMapping) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addDirectMapping(String, Class<?>, String) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Allows DirectToFieldMapping (@Basic) mapping to be added to a dynamic type through API.
addDirectMapping(String, String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Add a direct to field mapping to the receiver.
addDirectMapping(String, String) - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Add a direct mapping to the receiver.
addDirectMapping(String, String) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: Add a direct mapping to the receiver.
addDirectMapping(String, String, String, String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Add a direct to field mapping to the receiver.
addDirectMapping(String, String, String, String) - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Add a direct to node mapping to the receiver.
addDirectMapping(String, String, String, String) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: Add a direct to node mapping to the receiver.
addDirectMappingForEnum(String, String, String) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
 
addDirectQueryKey(String, String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Add a query key to the descriptor.
addDynamicClasses(DynamicClassLoader, String, DynamicType) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Register a DynamicClassWriter with the provided DynamicClassLoader so that a dynamic class can be generated when needed.
addElement(E) - Method in class org.eclipse.persistence.indirection.IndirectList
 
addElement(E) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
addElement(E) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Add and notify any waiters that there are new elements.
addElement(Element) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
addElement(Element) - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
addElement(Element) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
addElement(Element) - Method in class org.eclipse.persistence.internal.oxm.schema.model.TypeDefParticle
 
addEndFieldName(String) - Method in class org.eclipse.persistence.history.HistoryPolicy
PUBLIC:
addEntityListenerEventListener(DescriptorEventListener) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: EJB 3.0 support for lifecycle callback events defined on an entity listener class.
addEntityListenerHolder(SerializableDescriptorEventHolder) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL:
addEnum(String, Object...) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
 
addEnum(String, String, String, DynamicClassLoader) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
 
addEnumLiteral(String) - Method in class org.eclipse.persistence.dynamic.DynamicEnumBuilder
 
addEventManagerPropertyLines(NonreflectiveMethodDefinition, ClassDescriptor) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addException(String) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
addExpressionAndBaseToGroupedList(Expression, List, Expression) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
adds expression and its base expressions recursively to the expressionList in groups, so that an expression is never listed before its base expression
addExtraNamespacesToNamespaceResolver(Descriptor, CoreAbstractSession, boolean, boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
addExtraNamespacesToNamespaceResolver(Descriptor, CoreAbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
addExtraNamespacesToNamespaceResolver(Descriptor, CoreAbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
addExtraNamespacesToNamespaceResolver(Descriptor, CoreAbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL
addExtraNamespacesToNamespaceResolver(Descriptor, AbstractMarshalRecord, CoreAbstractSession, boolean, boolean) - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
addExtraNamespacesToNamespaceResolver(Descriptor, AbstractMarshalRecord, CoreAbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
addExtraNamespacesToNamespaceResolver(Descriptor, AbstractMarshalRecord, CoreAbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
addExtraNamespacesToNamespaceResolver(Descriptor, AbstractMarshalRecord, CoreAbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
addFailoverConnectionPool(String) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Add the connection pool to used if this pool database goes down.
addFetchGroup(FetchGroup) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
Add a named fetch group to the descriptor
addFetchGroupLines(NonreflectiveMethodDefinition, FetchGroup, String) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addFetchGroupManagerLine(NonreflectiveMethodDefinition, ClassDescriptor) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addField(String) - Method in class org.eclipse.persistence.tools.schemaframework.IndexDefinition
PUBLIC: Add the field to the index.
addField(String, Class<?>) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add the field to the table, default sizes are used.
addField(String, Class<?>) - Method in class org.eclipse.persistence.tools.schemaframework.TypeDefinition
PUBLIC: Add the field to the type, default sizes are used.
addField(String, Class<?>, int) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add the field to the table.
addField(String, Class<?>, int) - Method in class org.eclipse.persistence.tools.schemaframework.TypeDefinition
PUBLIC: Add the field to the type.
addField(String, Class<?>, int, int) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add the field to the table.
addField(String, Class<?>, int, int) - Method in class org.eclipse.persistence.tools.schemaframework.TypeDefinition
PUBLIC: Add the field to the type.
addField(String, String) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add the field to the type to a nested type.
addField(String, String) - Method in class org.eclipse.persistence.tools.schemaframework.TypeDefinition
PUBLIC: Add the field to the type to a nested type.
addField(String, DatabaseType) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
addField(String, DatabaseType, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
addField(String, DatabaseType, int, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
addField(Expression) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: adds an expression to the fields.
addField(DatabaseField) - Method in class org.eclipse.persistence.descriptors.CacheIndex
 
addField(DatabaseField) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
addField(DatabaseField, boolean, boolean, boolean) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
addField(PLSQLargument) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
addField(FieldDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add the field to the table.
addField(FieldDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.TypeDefinition
PUBLIC: Add the field to the type.
addFieldForInsert(String) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
PUBLIC: Define that the field will be returned from an insert operation.
addFieldForInsert(String, Class<?>) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
PUBLIC: Define that the field will be returned from an insert operation.
addFieldForInsert(DatabaseField) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
PUBLIC: Define that the field will be returned from an insert operation.
addFieldForInsertReturnOnly(String) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
PUBLIC: Define that the field will be returned from an insert operation.
addFieldForInsertReturnOnly(String, Class<?>) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
PUBLIC: Define that the field will be returned from an insert operation.
addFieldForInsertReturnOnly(DatabaseField) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
PUBLIC: Define that the field will be returned from an insert operation.
addFieldForUpdate(String) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
PUBLIC: Define that the field will be returned from an update operation.
addFieldForUpdate(String, Class<?>) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
PUBLIC: Define that the field will be returned from an update operation.
addFieldForUpdate(DatabaseField) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
PUBLIC: Define that the field will be returned from an update operation.
addFieldLines(FieldDefinition, NonreflectiveMethodDefinition) - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
 
addFieldName(String) - Method in class org.eclipse.persistence.descriptors.CacheIndex
PUBLIC: Add the database column name to the cache index.
addFieldNameTranslation(String, String) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Maps a field name in the aggregate descriptor to a field name in the source table.
addFieldNameTranslation(String, String) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
PUBLIC: Add a field name translation that maps from a field name in the source table to a field name in the aggregate descriptor.
addFieldOnDatabase(AbstractSession, FieldDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Execute the SQL alter table to add the field to the table.
addFieldOrdering(String) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
PUBLIC: Order the fields in a specific Add the field ordering, this will order the fields in the order this method is called.
addFieldResult(FieldResult) - Method in class org.eclipse.persistence.queries.EntityResult
 
addFields(ClassWriter, String) - Method in class org.eclipse.persistence.dynamic.DynamicClassWriter
Allow subclasses to add additional state to the dynamic entity.
addFieldsForMapKey(AbstractRecord) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Called when the insert query is being initialized to ensure the fields for the key are in the insert query
addFieldsForMapKey(AbstractRecord) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Called when the insert query is being initialized to ensure the fields for the key are in the insert query
addFieldsForMapKey(AbstractRecord) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Used when initializing queries for mappings that use a Map Called when the insert query is being initialized to ensure the fields for the map key are in the insert query
addFieldsForMapKey(AbstractRecord) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Used when initializing queries for mappings that use a Map Called when the insert query is being initialized to ensure the fields for the map key are in the insert query.
addFieldsForMapKey(AbstractRecord) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Used when initializing queries for mappings that use a Map Called when the insert query is being initialized to ensure the fields for the map key are in the insert query
addFieldsForMapKey(AbstractRecord) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Used when initializing queries for mappings that use a Map Called when the insert query is being initialized to ensure the fields for the map key are in the insert query
addFieldsForMappedKeyMapContainerPolicy(ContainerPolicy, TableDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
The ContainerPolicy may contain some additional fields that should be added to the table
addFieldsToParent(Vector) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Recursively adds fields to all the parents
addFieldsToRow(AbstractRecord, AbstractSession) - Method in interface org.eclipse.persistence.descriptors.MultitenantPolicy
 
addFieldsToRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL: Add the tenant discriminator fields to the row.
addFieldsToRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL:
addFieldToMain(int, int, DatabaseField) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
 
addFieldTransformation(String, String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.TransformationMapping
Add the name of field and the name of the method that returns the value to be placed in said field when the object is written to the database.
addFieldTransformation(String, String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Add the name of field and the name of the method that returns the value to be placed in said field when the object is written to the database.
addFieldTransformation(String, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLTransformationMapping
 
addFieldTransformation(DatabaseField, String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Add the field and the name of the method that returns the value to be placed in said field when the object is written to the database.
addFieldTransformer(String, FieldTransformer) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Add the name of field and the transformer that returns the value to be placed in the field when the object is written to the database.
addFieldTransformer(String, FieldTransformer) - Method in class org.eclipse.persistence.oxm.mappings.XMLTransformationMapping
 
addFieldTransformer(DatabaseField, FieldTransformer) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Add the field and the transformer that returns the value to be placed in the field when the object is written to the database.
addFieldTransformerClassName(String, String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.TransformationMapping
INTERNAL: Add the name of a field and the name of a class which implements the FieldTransformer interface.
addFieldTransformerClassName(String, String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Add the name of a field and the name of a class which implements the FieldTransformer interface.
addFieldTransformerClassName(String, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLTransformationMapping
 
addFieldTransformerClassName(DatabaseField, String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Add the name of a field and the name of a class which implements the FieldTransformer interface.
addFieldTranslation(DatabaseField, String) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Maps a field name in the aggregate descriptor to a field in the source table.
addFieldTranslation(DatabaseField, String) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
PUBLIC: Add a field translation that maps from a field in the source table to a field name in the aggregate descriptor.
addFieldTranslation(DatabaseField, String) - Method in interface org.eclipse.persistence.mappings.EmbeddableMapping
 
addFieldTranslations(Map<String, DatabaseField>) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Maps a field name in the aggregate descriptor to a field name in the source table.
addFirst(Object) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
Inserts the given contents at the beginning of this list.
addForeignKeyConstraint(String, String, String, String) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add a foreign key constraint to the table.
addForeignKeyConstraint(ForeignKeyConstraint) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
addForeignKeyConstraint(ForeignKeyConstraint) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add a foreign key constraint to the table.
addForeignKeyConstraint(TableDefinition, TableDefinition, List<String>, List<String>, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Add a foreign key constraint to the source table.
addForeignKeyField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
PUBLIC: Define the source foreign key relationship in the one-to-many mapping.
addForeignKeyField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
PUBLIC: Define the source foreign key relationship in the one-to-one mapping.
addForeignKeyField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Allow subclass to define a foreign key in the source's table.
addForeignKeyField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Define the foreign key relationship in the 1-1 mapping.
addForeignKeyFieldForMultipleTable(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This protocol can be used to associate multiple tables with foreign key information.
addForeignKeyFieldName(String, String) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
PUBLIC: Define the source foreign key relationship in the one-to-many mapping.
addForeignKeyFieldName(String, String) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
PUBLIC: Define the source foreign key relationship in the one-to-one mapping.
addForeignKeyFieldName(String, String) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Define the foreign key relationship in the 1-1 mapping.
addForeignKeyFieldNameForMultipleTable(String, String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This protocol can be used to associate multiple tables with foreign key information.
addForeignKeyFieldToSourceTargetTable(OneToManyMapping) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
 
addForeignKeyFieldToSourceTargetTable(OneToOneMapping) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
 
addForeignKeyLines(ForeignKeyConstraint, NonreflectiveMethodDefinition) - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
 
addForeignMappingFkConstraint(Map<DatabaseField, DatabaseField>, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
 
addForeignQueryKeyName(String, String) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
PUBLIC: A foreign key from the source table and abstract query key from the interface descriptor are added to the mapping.
addForeignQueryKeyName(DatabaseField, String) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
PUBLIC: A foreign key from the source table and abstract query key from the interface descriptor are added to the mapping.
addForeignReferenceMappingLines(NonreflectiveMethodDefinition, String, ForeignReferenceMapping) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addFunctionItem(String, Expression, String) - Method in class org.eclipse.persistence.queries.ReportQuery
ADVANCED: Add the function against the attribute expression to be included in the result.
addGrouping(String) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the attribute to the group by expressions.
addGrouping(Expression) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the attribute expression to the group by expressions.
addGroupingElement(XPathNode) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
addGroupingElement(XPathNode) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
INTERNAL: If an XPathNode does not have an associated NodeValue then add it to the MarshalRecord as a grouping element.
addGroupingElement(XPathNode) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
addGroups(Collection<ATTRIBUTE_GROUP>) - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
INTERNAL: Adds the list of groups as to the item
addHistoryPolicyLines(NonreflectiveMethodDefinition, ClassDescriptor) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addHistoryPolicyLines(NonreflectiveMethodDefinition, HistoryPolicy, String) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addHistoryPolicyLines(NonreflectiveMethodDefinition, DirectCollectionMapping, String) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addHistoryPolicyLines(NonreflectiveMethodDefinition, ManyToManyMapping, String) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addHistoryTableName(String) - Method in class org.eclipse.persistence.history.HistoryPolicy
PUBLIC: Use to specify the names of the mirroring historical tables.
addHistoryTableName(String, String) - Method in class org.eclipse.persistence.history.HistoryPolicy
PUBLIC: Use to specify the names of the mirroring historical tables.
addIdentityField(String, Class<?>) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add the field to the table, default sizes are used.
addIdentityField(String, Class<?>, int) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add the field to the table, default sizes are used.
addImport(String) - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
The importStatement should be of the form "{packageName}.{shortName or '*'}"
addIndex(IndexDefinition) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Add an index definition to this table.
addIndex(IndexDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add an index to the table.
addInheritanceLines(NonreflectiveMethodDefinition, InheritancePolicy) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addInnerClass(ClassDefinition) - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
addInOutputArgument(String, Class<?>) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The output arguments are used to get values back from the proc.
addInOutputArgument(FieldDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The output arguments are used to get values back from the proc, such as cursors.
addInterface(String) - Method in class org.eclipse.persistence.dynamic.DynamicClassWriter
Allow subclasses to add additional interfaces to the dynamic entity.
addInterface(String) - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
addInterfaceLines(NonreflectiveMethodDefinition, InterfacePolicy) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addInternalException(Object) - Method in exception org.eclipse.persistence.exceptions.JPQLException
INTERNAL Add an internal Exception to the collection of internal Exceptions
addInternalListener(DescriptorEventListener) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL:
addInto(Object, Object, ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Add element to container.
addInto(Object, Object, Object, ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Add element to container.
addInto(Object, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
INTERNAL: Add element into a container which implements the Collection interface.
addInto(Object, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Add element to container.
addInto(Object, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Add element into container which implements the Map interface.
addInto(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Add element to container.
addInto(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Add element to container.
addInto(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Add element into container which implements the Map interface.
addInto(Object, Object, AbstractSession, AbstractRecord, DataReadQuery, CacheKey, boolean) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: This is used for adding to a direct map or direct collection from the database.
addInto(Object, Object, AbstractSession, AbstractRecord, DataReadQuery, CacheKey, boolean) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: This is used for ordered List containers to add all of the elements to the collection in the order of the index field in the row.
addInto(Object, Object, AbstractSession, AbstractRecord, ObjectBuildingQuery, CacheKey, boolean) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Add element to container.
addInto(Object, Object, AbstractSession, AbstractRecord, ObjectBuildingQuery, CacheKey, boolean) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Add element to that implements the Map interface use the row to compute the key
addIntoAtIndex(Integer, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Add element into a container which implements the List interface.
addItem(String, Expression) - Method in class org.eclipse.persistence.queries.ReportQuery
ADVANCED: Add the expression value to be included in the result.
addItem(String, Expression, Class<?>) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Add the expression value to be included in the result.
addItem(String, Expression, List) - Method in class org.eclipse.persistence.queries.ReportQuery
ADVANCED: Add the expression value to be included in the result.
addItem(ReportItem) - Method in class org.eclipse.persistence.queries.ConstructorReportItem
 
additional - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
additional - Variable in class org.eclipse.persistence.tools.schemaframework.TypeTableDefinition
 
ADDITIONAL_CRITERIA_NOT_SUPPORTED_WITH_INHERITANCE_VIEWS - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ADDITIONAL_SIZE_QUERY_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
additionalAggregateCollectionKeyFields - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
used by aggregate descriptors to hold additional fields needed when they are stored in an AggregatateCollection These fields are generally foreign key fields that are required in addition to the fields in the descriptor's mappings to uniquely identify the Aggregate
additionalCriteria - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
AdditionalCriteria - Annotation Type in org.eclipse.persistence.annotations
An additional criteria can be specified at the Entity or MappedSuperclass level.
additionalCriteriaNotSupportedWithInheritanceViews(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
additionalExpression - Variable in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
A new root expression can be made from joins being added to the original expression.
additionalExpressionCriteria() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL: Return the expression to join the main table of this node to any auxiliary tables.
additionalExpressionCriteria() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Return the expression to join the main table of this node to any auxiliary tables.
additionalExpressionCriteriaMap() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL: Used in case outer joins should be printed in FROM clause.
additionalExpressionCriteriaMap() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Used in case outer joins should be printed in FROM clause.
additionalFieldExpressions - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
 
additionalFields - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Allow for additional fields to be selected, used for m-m batch reading.
additionalHistoryExpression(Expression, Expression) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL: Add any temporal querying conditions to this object expression.
additionalHistoryExpression(Expression, Expression, Integer) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL: Add any temporal querying conditions to this object expression.
additionalJoinExpression - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
additionalLocalExpression - Variable in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
Local expression from joins being added to the original expression.
additionalSizeQueryNotSpecified(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
additionalTablePrimaryKeyFields - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
additionalTreatExpressionCriteria() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
INTERNAL: Return the expression to join the main table of this node to any auxiliary tables.
additionalTreatExpressionCriteriaMap() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
INTERNAL: Used in case outer joins should be printed in FROM clause.
additionalWritableMapKeyFields - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
stores fields that are written by Map key mappings so they can be checked for multiple writable mappings
addJavaConversion(Class<?>, QName) - Method in class org.eclipse.persistence.oxm.XMLField
Add a Java to XML Conversion pair entry
addJoinColumnsFkConstraint(List<DatabaseField>, List<DatabaseField>, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
 
addJoinedAttribute(String) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Specify the relationship attribute to be join fetched in this query.
addJoinedAttribute(Expression) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
 
addJoinedAttribute(Expression) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Specify the attribute to be join fetched in this query.
addJoinedAttributeExpression(Expression) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
 
addJoinedMapping(String) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Add an attribute represented by the given attribute name to the list of joins for this query.
addJoinedMappingExpression(Expression) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Add an attribute represented by the given attribute name to the list of joins for this query.
addJoinSelectionFields(Vector, boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: The method adds to the passed input vector the fields or expressions corresponding to the joins.
addJPAQuery(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return all pre-defined not yet parsed EJBQL queries.
addJPAQuery(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return all pre-defined not yet parsed EJBQL queries.
addJPAQuery(DatabaseQuery) - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Add a pre-defined not yet parsed JPQL String/query to the session to be parsed after descriptors are initialized.
addJPATablePerTenantQuery(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return all pre-defined not yet parsed EJBQL multitenant queries.
addJPATablePerTenantQuery(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return all pre-defined not yet parsed EJBQL queries to table per tenant entities.
addKeyGroup(ATTRIBUTE_GROUP) - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
addKeyGroups(Collection<ATTRIBUTE_GROUP>) - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
addKeyToDeletedObjectsList(Object, Map) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: For mappings used as MapKeys in MappedKeyContainerPolicy.
addKeyToDeletedObjectsList(Object, Map) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: For mappings used as MapKeys in MappedKeyContainerPolicy.
addKeyToDeletedObjectsList(Object, Map) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: For mappings used as MapKeys in MappedKeyContainerPolicy.
addKeyToDeletedObjectsList(Object, Map) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: For mappings used as MapKeys in MappedKeyContainerPolicy.
addLast(Object) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
Appends the given contents to the end of this list.
addLine(String) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
addListener(DescriptorEventListener) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: Listener objects can be registered with the event manager to be notified when an event occurs on any instance of the descriptor's class.
addListener(SessionEventListener) - Method in class org.eclipse.persistence.sessions.SessionEventManager
PUBLIC: Add the event listener to the session.
addListener(SESSION_EVENT_LISTENER) - Method in class org.eclipse.persistence.core.sessions.CoreSessionEventManager
PUBLIC: Add the event listener to the session.
addListenerToEventManager(ClassDescriptor, AbstractSession, ClassLoader) - Method in interface org.eclipse.persistence.descriptors.SerializableDescriptorEventHolder
 
addLiteralLabel(String) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader.EnumInfo
 
addLocalResource(String, String) - Method in class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
INTERNAL:
addLockedExpression(FieldExpression) - Method in class org.eclipse.persistence.internal.expressions.ForUpdateOfClause
 
addLockedExpression(ObjectExpression) - Method in class org.eclipse.persistence.internal.expressions.ForUpdateOfClause
 
addLockFieldName(String) - Method in class org.eclipse.persistence.descriptors.SelectedFieldsLockingPolicy
PUBLIC: Add a field name to lock on.
addLockFieldsToUpdateRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Add update fields for template row.
addLockFieldsToUpdateRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Add update fields for template row.
addLockFieldsToUpdateRow(AbstractRecord, AbstractSession) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: Add update fields for template row.
addLockValuesToTranslationRow(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.descriptors.AllFieldsLockingPolicy
INTERNAL: Values to be included in the locking mechanism are added to the translation row.
addLockValuesToTranslationRow(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.descriptors.ChangedFieldsLockingPolicy
INTERNAL: Values to be included in the locking mechanism are added to the translation row.
addLockValuesToTranslationRow(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Values to be included in the locking mechanism are added to the translation row.
addLockValuesToTranslationRow(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.descriptors.SelectedFieldsLockingPolicy
INTERNAL: Values to be included in the locking mechanism are added to the translation row.
addLockValuesToTranslationRow(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: This method adds the lock value to the translation row of the passed in query.
addLockValuesToTranslationRow(ObjectLevelModifyQuery) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: The method should update the translation row with the correct write lock values.
addLogger(String, String) - Method in class org.eclipse.persistence.logging.JavaLog
INTERNAL: Add Logger to the categoryloggers.
addManyToManyMapping(String, DynamicType, String) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Add a ManyToManyMapping to the DynamicTypeBuilder.entityType being built or extended.
addManyToManyMappingLines(NonreflectiveMethodDefinition, String, ManyToManyMapping) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addMappedFieldToMain(DatabaseField, ReturningPolicy.Info) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
 
addMappedSuperclass(String, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: 266912: Add a descriptor to the Map of mappedSuperclass descriptors
addMapping(CORE_MAPPING) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Add a database mapping to the receiver.
addMapping(DatabaseMapping) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Add a database mapping to the receiver.
addMapping(DatabaseMapping) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Add the mapping to the DynamicTypeBuilder.entityType's descriptor being built or extended.
addMappingLines(NonreflectiveMethodDefinition, DatabaseMapping) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addMappingsPostCalculateChanges(DatabaseMapping) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Add a mapping to the list of mappings that require postCalculateChanges method to be called.
addMappingsPostCalculateChangesOnDeleted(DatabaseMapping) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Add a mapping to the list of mappings that require mappingsPostCalculateChangesOnDeleted method to be called.
addMapsIdMapping(DatabaseMapping) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: In JPA users may specify a maps id mapping on a shared embeddable descriptor.
addMaximum(String) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the maximum value of the attribute to be included in the result.
addMaximum(String, Class<?>) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the maximum value of the attribute to be included in the result.
addMaximum(String, Expression) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the maximum value of the attribute to be included in the result.
addMaximum(String, Expression, Class<?>) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the maximum value of the attribute to be included in the result.
addMetamodelIdClassMapEntry(String, String) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Add an IdClass entry to the map of ids for a particular owner This function is used exclusively by the Metamodel API.
addMethod(MethodDefinition) - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
addMethods(ClassWriter, String) - Method in class org.eclipse.persistence.dynamic.DynamicClassWriter
Allow subclasses to add additional methods to the dynamic entity.
addMinimalFetchGroup(FetchGroup) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Add primary key and version attributes to the passed fetch group.
addMinimum(String) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the minimum value of the attribute to be included in the result.
addMinimum(String, Class<?>) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the minimum value of the attribute to be included in the result.
addMinimum(String, Expression) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the minimum value of the attribute to be included in the result.
addMinimum(String, Expression, Class<?>) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the minimum value of the attribute to be included in the result.
addMonths() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
addMonths(int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, to add months to a date.
addMonths(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, to add months to a date.
AddMonths - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
addMonthsOperator() - Static method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Function, to add months to a date.
addMovedChangeSet(Object, int, int) - Method in class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
Add an moved change set.
addMtomAttachment(byte[], int, int, String, String, String) - Method in interface org.eclipse.persistence.oxm.attachment.XMLAttachmentMarshaller
 
addMtomAttachment(DataHandler, String, String) - Method in interface org.eclipse.persistence.oxm.attachment.XMLAttachmentMarshaller
 
addMultitenantContextProperty(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return a set of multitenant context properties this session
addNamedArgument(String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedArgument(String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the argument to the stored procedure and the field/argument name to be substitute for it.
addNamedArgument(String, String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedArgument(String, String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the argument to the stored procedure and the field/argument name to be substitute for it.
addNamedArgument(String, String, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedArgument(String, String, int) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the input argument to the stored procedure and the field/argument name to be substitute for it.
addNamedArgument(String, String, int, String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedArgument(String, String, int, String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the output argument to the stored procedure and the field/argument name to be substitute for it.
addNamedArgument(String, String, int, String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the output argument to the stored procedure and the field/argument name to be substitute for it.
addNamedArgument(String, String, int, String, Class<?>, DatabaseField) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inout argument to the stored procedure and the field/argument name to be substituted for it.
addNamedArgument(String, String, int, String, String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the output argument to the stored procedure and the field/argument name to be substitute for it.
addNamedArgument(String, String, int, String, DatabaseField) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the output argument to the stored procedure and the field/argument name to be substitute for it.
addNamedArgument(String, String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the input argument to the stored procedure and the field/argument name to be substitute for it.
addNamedArgument(String, DatabaseType) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
PUBLIC: Add a named IN argument to the stored procedure.
addNamedArgument(String, DatabaseType, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
PUBLIC: Add a named IN argument to the stored procedure.
addNamedArgument(String, DatabaseType, int, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
PUBLIC: Add a named IN argument to the stored procedure.
addNamedArgumentValue(String, Object) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedArgumentValue(String, Object) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the argument to the stored procedure and the value to be substitute for it.
addNamedCursorOutputArgument(String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
ADVANCED: Add the cursor output parameter to the procedure.
addNamedInOutputArgument(String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedInOutputArgument(String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure and the field/argument name to be substitute for it on the way in and out.
addNamedInOutputArgument(String, String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedInOutputArgument(String, String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure and the field/argument name to be substitute for it on the way in and out.
addNamedInOutputArgument(String, String, Class<?>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedInOutputArgument(String, String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure and the field/argument name to be substitute for it on the way in and out.
addNamedInOutputArgument(String, String, String, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedInOutputArgument(String, String, String, int) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure and the field/argument name to be substitute for it on the way in and out.
addNamedInOutputArgument(String, String, String, int, String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedInOutputArgument(String, String, String, int, String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure and the field/argument name to be substitute for it on the way in and out.
addNamedInOutputArgument(String, String, String, int, String, Class<?>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedInOutputArgument(String, String, String, int, String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure and the field/argument name to be substitute for it on the way in and out.
addNamedInOutputArgument(String, String, String, int, String, Class<?>, DatabaseField) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedInOutputArgument(String, String, String, int, String, Class<?>, DatabaseField) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure and the field/argument name to be substitute for it on the way in and out.
addNamedInOutputArgument(String, String, String, Class<?>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedInOutputArgument(String, String, String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure and the field/argument name to be substitute for it on the way in and out.
addNamedInOutputArgument(String, DatabaseType) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
PUBLIC: Add a named IN OUT argument to the stored procedure.
addNamedInOutputArgument(String, DatabaseType, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
PUBLIC: Add a named IN OUT argument to the stored procedure.
addNamedInOutputArgument(String, DatabaseType, int, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
PUBLIC: Add a named IN OUT argument to the stored procedure.
addNamedInOutputArgumentValue(String, Object, String, Class<?>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedInOutputArgumentValue(String, Object, String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure and the field/argument name to be substitute for it on the way in and out.
addNamedOutputArgument(String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedOutputArgument(String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the output argument to the stored procedure and the field/argument name to be substitute for it.
addNamedOutputArgument(String, String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedOutputArgument(String, String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the output argument to the stored procedure and the field/argument name to be substitute for it.
addNamedOutputArgument(String, String, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedOutputArgument(String, String, int) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the output argument to the stored procedure and the field/argument name to be substitute for it.
addNamedOutputArgument(String, String, int, String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedOutputArgument(String, String, int, String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the output argument to the stored procedure and the field/argument name to be substitute for it.
addNamedOutputArgument(String, String, int, String, Class<?>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedOutputArgument(String, String, int, String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the output argument to the stored procedure and the field/argument name to be substitute for it.
addNamedOutputArgument(String, String, int, String, Class<?>, DatabaseField) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedOutputArgument(String, String, int, String, Class<?>, DatabaseField) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the output argument to the stored procedure and the field/argument name to be substitute for it.
addNamedOutputArgument(String, String, Class<?>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addNamedOutputArgument(String, String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the output argument to the stored procedure and the field/argument name to be substitute for it.
addNamedOutputArgument(String, DatabaseType) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
PUBLIC: Add a named OUT argument to the stored procedure.
addNamedOutputArgument(String, DatabaseType, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
PUBLIC: Add a named OUT argument to the stored procedure.
addNamedOutputArgument(String, DatabaseType, int, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
PUBLIC: Add a named OUT argument to the stored procedure.
addNamedQueryLines(NonreflectiveMethodDefinition, DatabaseQuery, DescriptorQueryManager, int) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addNamespaceDeclaration(Element, String, String) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
addNamespaceDeclarations(Document) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
addNamespacesToWorkingSchema(NamespaceResolver, Schema) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Adds each namespace in the given resolver to the schema.
addNestedFieldNameTranslation(String, String, String) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Map the name of an attribute of the reference descriptor mapped with AggregateCollectionMapping to aggregateToSourceFieldNames that should be applied to this mapping.
addNestedFieldNameTranslations(String, Map<String, DatabaseField>) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Map the name of an attribute of the reference descriptor mapped with AggregateCollectionMapping to aggregateToSourceFields that should be applied to this mapping.
addNestedFieldTranslation(String, DatabaseField, String) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Map the name of an attribute of the reference descriptor mapped with AggregateCollectionMapping to aggregateToSourceFieldNames that should be applied to this mapping.
addNestedFieldTranslation(String, DatabaseField, String) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Add a nested field translation that maps from a field in the source table to a field name in a nested aggregate descriptor.
addNestedFieldTranslation(String, DatabaseField, String) - Method in interface org.eclipse.persistence.mappings.EmbeddableMapping
 
addNestedFunctionsForArgument(List<String>, PLSQLargument, DatabaseType, Set<DatabaseType>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
INTERNAL Add the nested function string required for the type and its subtypes.
addNestedJoinsQueriesForMapKey(JoinedAttributeManager, ObjectLevelReadQuery, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Used for joining.
addNestedJoinsQueriesForMapKey(JoinedAttributeManager, ObjectLevelReadQuery, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Used for joining.
addNewAggregate(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Register a new aggregate object with the unit of work.
addNewConnectionPool(String, int, int, String, String, String, String, String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method provides client with access to add a new connection pool to a TopLink ServerSession.
addNewConnectionPool(String, int, int, String, String, String, String, String) - Method in class org.eclipse.persistence.services.RuntimeServices
This method provides client with access to add a new connection pool to a EclipseLink ServerSession.
addNewObjectChangeSet(ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Add to the changes for 'object' object to this changeSet.
addNextValueFromIteratorInto(Object, Object, CacheKey, Object, CollectionMapping, Integer, AbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: This method is used to add the next value from an iterator built using ContainerPolicy's iteratorFor() method into the toCollection.
addNextValueFromIteratorInto(Object, Object, CacheKey, Object, CollectionMapping, Integer, AbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: This method is used to add the next value from an iterator built using ContainerPolicy's iteratorFor() method into the toCollection.
addNode(ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
 
addNodes(Vector) - Method in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
 
addNonBindingOperator(ExpressionOperator) - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Symfoware does not support the use of parameters in certain functions.
This adds the operator and disables binding support at the same time.
addNonFetchJoin(Expression) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Specify the object expression to be joined in this query.
addNonFetchJoinedAttribute(String) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Specify the relationship attribute to be join in this query.
addNonFetchJoinedAttribute(Expression) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Specify the relationship attribute to be join in this query.
addObjectChangeSet(ObjectChangeSet, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Add to the changes for 'object' object to this changeSet.
addObjectChangeSetForIdentity(ObjectChangeSet, Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Add change records to the lists used to maintain identity.
addObjectDeletedDuringCommit(Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Add object deleted during root commit of unit of work.
addObjectList - Variable in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Contains the added values to the collection and their corresponding ChangeSets.
addObjectMap - Variable in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
addObjectsList - Variable in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
 
addObjectToCache(Object, Node) - Method in class org.eclipse.persistence.oxm.documentpreservation.DocumentPreservationPolicy
 
addObjectToCache(Object, Node, Mapping) - Method in class org.eclipse.persistence.oxm.documentpreservation.DocumentPreservationPolicy
 
addObjectToDelete(Object) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Deletion are cached until the end.
addObjectTypeConverterLines(NonreflectiveMethodDefinition, String, ObjectTypeConverter) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addOneToManyMapping(String, DynamicType, String...) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Add a OneToManyMapping to the DynamicTypeBuilder.entityType being built or extended.
addOneToManyMappingLines(NonreflectiveMethodDefinition, String, OneToManyMapping) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addOneToOneMapping(String, DynamicType, String...) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Allows OneToOneMapping (@OneToOne and @ManyToOne) mappings to be added to a dynamic type through API.
addOneToOneMappingLines(NonreflectiveMethodDefinition, String, OneToOneMapping) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
addOperator(ExpressionOperator) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Add an operator to the user defined list of operators.
addOperator(ExpressionOperator) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
addOptimisticLockingLines(NonreflectiveMethodDefinition, OptimisticLockingPolicy) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addOptimizedClonedExpressions(Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: It is used by subqueries to avoid duplicate joins.
addOptionalArgument(String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Add the optional argument.
addOrderBy(String, boolean) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Provide order support for queryKeyName in descending or ascending order.
addOrderByExpressionToSelectForDistinct() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
When distinct is used with order by the ordered fields must be in the select clause.
addOrderedAdditionChange(List<Object>, Map<Object, Integer>, UnitOfWorkChangeSet, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This method takes a list of objects and converts them into ObjectChangeSets.
addOrderedRemoveChange(List<Integer>, Map, UnitOfWorkChangeSet, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This method takes a map of objects and converts them into ObjectChangeSets.
addOrdering(Expression) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
ADVANCED: Used this method to add custom ordering expressions when fetching the collection.
addOrdering(Expression) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Add the ordering expression.
addOuterJoinExpressionsHolders(Map<DatabaseTable, Expression>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: used by TREAT to add in a join from the parent table to the child tables when the parent expression did not add an outer join of its own
addOuterJoinExpressionsHolders(ObjectExpression, Expression, Map<DatabaseTable, Expression>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Used by ExpressionBuilder and QueryKeyExpression normalization to create a standard outerjoin.
addOutputArgument(String) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: Define the output argument to the interaction and the field/argument name to be substitute for it.
addOutputArgument(String) - Method in class org.eclipse.persistence.eis.interactions.IndexedInteraction
PUBLIC: Define the field/argument name to be substitute for the index output argument.
addOutputArgument(String, Class<?>) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The output arguments are used to get values back from the proc.
addOutputArgument(String, Class<?>, int) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The output arguments are used to get values back from the proc.
addOutputArgument(String, String) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: Define the output argument to the interaction and the field/argument name to be substitute for it.
addOutputArgument(String, String) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The output arguments are used to get values back from the proc, such as cursors.
addOutputArgument(FieldDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The output arguments are used to get values back from the proc, such as cursors.
addOverFlow - Variable in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Contains a list of extra adds.
addOverrideManyToManyMapping(ManyToManyMapping) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: In JPA users may specify overrides to apply to a many to many mapping on a shared embeddable descriptor.
addOverrideManyToManyMapping(ManyToManyMapping) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: In JPA users may specify overrides to apply to a many to many mapping on a shared embeddable descriptor.
addOverrideManyToManyMapping(ManyToManyMapping) - Method in interface org.eclipse.persistence.mappings.EmbeddableMapping
 
addOverrideUnidirectionalOneToManyMapping(UnidirectionalOneToManyMapping) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: In JPA users may specify overrides to apply to a unidirectional one to many mapping on a shared embeddable descriptor.
addOverrideUnidirectionalOneToManyMapping(UnidirectionalOneToManyMapping) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: In JPA users may specify overrides to apply to a unidirectional one to many mapping on a shared embeddable descriptor.
addOverrideUnidirectionalOneToManyMapping(UnidirectionalOneToManyMapping) - Method in interface org.eclipse.persistence.mappings.EmbeddableMapping
 
addParentDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Add parent descriptor.
addParentInterface(Class<?>) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
PUBLIC: Add the parent Interface class.
addParentInterfaceName(String) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
 
addPartialAttribute(String) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Deprecated.
since EclipseLink 2.1, partial attributes replaced by fetch groups.
addPartialAttribute(Expression) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Deprecated.
since EclipseLink 2.1, partial attributes replaced by fetch groups.
addPartition(Object, String) - Method in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
PUBLIC: Add the value partition.
addPartition(String, Comparable, Comparable) - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartitioningPolicy
PUBLIC: Add the range partition.
addPartition(RangePartition) - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartitioningPolicy
PUBLIC: Add the range partition.
addPartitioningPolicy(PartitioningPolicy) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set the map of partitioning policies, keyed by name.
addPartitionName(String, String) - Method in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
INTERNAL: Add partition values by name (will be initialized at runtime with the real class loader).
addPattern(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
addPattern(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
addPessimisticLockedClone(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL:
addPositionalNodes(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
addPositionalNodes(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
addPreDeleteMapping(DatabaseMapping) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Add the mapping to be notified before deletion.
addPrimaryKeyField(FIELD) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
ADVANCED: Specify the primary key field of the descriptors table.
addPrimaryKeyField(String, Class<?>) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add the field to the table, default sizes are used.
addPrimaryKeyField(String, Class<?>, int) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add the field to the table, default sizes are used.
addPrimaryKeyField(DatabaseField) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Specify the primary key field of the descriptors table.
addPrimaryKeyField(DatabaseField) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
addPrimaryKeyFieldName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Specify the primary key field of the descriptors table.
addPrimaryKeyFieldName(String) - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Specify the primary key field.
addPrimaryKeyFieldName(String) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
addPrimaryKeyForNonDefaultTable(AbstractRecord) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Add the primary key and its value to the Record for all the non default tables.
addPrimaryKeyForNonDefaultTable(AbstractRecord, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Add the primary key and its value to the Record for all the non default tables.
addPrimaryKeyJoinField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Add a primary key join column (secondary field).
addPrivateOwnedObject(DatabaseMapping, Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Add a privately owned object to the privateOwnedObjectsMap.
addProcedures(StoredProcedureDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.PackageDefinition
Packages can contain sets of procedures.
addProfile(Profile) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
addProperty(String, String, Object) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGeneratorProperties
Adds the key/value pair to the Properties object associated with the given namespace URI.
addQuery(String, DatabaseQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Add the query to the descriptor queries with the given name
addQuery(String, DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Add the query to the session queries with the given name.
addQuery(String, DatabaseQuery) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Add the query to the session queries with the given name.
addQuery(String, DatabaseQuery, boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Add the query to the session queries with the given name.
addQuery(DatabaseQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Add the query to the session queries
addQuery(DatabaseQuery, boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Add the query to the session queries.
addQueryKey(QueryKey) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Add a query key to the descriptor.
addQueryKeyLines(NonreflectiveMethodDefinition, QueryKey) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addQueryManagerPropertyLines(NonreflectiveMethodDefinition, ClassDescriptor) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addReadLock(ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ReadLockManager
add a concurrency manager as deferred locks to the DLM
addReadLockToReadLockManager() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
The current thread has incremented the number of readers on the current cache key.
addReadOnlyClass(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Adds the given Java class to the receiver's set of read-only classes.
addReadOnlyClass(Class<?>) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Adds the given Java class to the receiver's set of read-only classes.
addReadOnlyClasses(Collection) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Adds the classes in the given Vector to the existing set of read-only classes.
addReadOnlyClasses(Collection) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Adds the classes in the given Vector to the existing set of read-only classes.
addReference(Reference) - Method in class org.eclipse.persistence.internal.oxm.ReferenceResolver
Add a Reference object to the list - these References will be resolved after unmarshalling is complete.
addReferenceKeyField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Add the reference key field.
addReferenceKeyFieldName(String, String) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Add the name of the reference key field.
addRelationTableSourceRow(Object, AbstractSession, AbstractRecord, ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Add to a row source relation fields with values extracted from the source object.
addRelationTableSourceRow(AbstractRecord, AbstractRecord) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Add to a row source relation fields with values extracted from the source row.
addRelationTableTargetRow(Object, AbstractSession, AbstractRecord, ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Add to a row target relation fields with values extracted from the target object.
addRemoveChange(Object, Integer) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
This method takes a single remove change and integrates it with this changeset.
addRemoveChange(Object, Object) - Method in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
Adds the items that were removed from the collection.
addRemoveChange(HashMap) - Method in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
Adds the items that were removed from the collection.
addRemoveChange(HashMap, HashMap) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
This method takes a hashtable of primitive objects and adds them to the remove list.
addRemoveChange(Map, ContainerPolicy, UnitOfWorkChangeSet, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This method takes a Map of objects, converts these into ObjectChangeSets.
addRemovedChangeSet(Object) - Method in class org.eclipse.persistence.eis.EISCollectionChangeRecord
Add an removed change set.
addRemovedChangeSet(Object, int) - Method in class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
Add an removed change set.
addRemovedObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Register that an object was removed in a nested unit of work.
addRemoveReadLockProblemsDetected(String) - Method in class org.eclipse.persistence.internal.helper.ReadLockManager
Allow the concurrency manager to directly pump a message stating that there was a problem while decrementing the number of readers.
addResult(SQLResult) - Method in class org.eclipse.persistence.queries.SQLResultSetMapping
 
addReturningPolicyLines(NonreflectiveMethodDefinition, ReturningPolicy) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addReturningPolicyLines(NonreflectiveMethodDefinition, ReturningPolicy, String) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addRightMostChild(Expression) - Method in class org.eclipse.persistence.internal.expressions.ArgumentListFunctionExpression
INTERNAL: Add a child and ensure it is the rightmost in the tree as long as it is in the tree If there is already a node that is set as therightmost node, replace it
addRootElement(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Add a root element name for the Descriptor This value is stored in place of a table name
addRootElement(String) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: Add a root element name for the Descriptor This value is stored in place of a table name
addSchemaType(QName) - Method in interface org.eclipse.persistence.internal.oxm.mappings.UnionField
Adds the new type value to the list of types
addSchemaType(QName) - Method in class org.eclipse.persistence.oxm.XMLUnionField
Adds the new type value to the list of types
addSelectionFieldsForJoinedExpression(List, boolean, Expression) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: The method adds to the passed input vector the fields or expressions corresponding to the passed join expression.
addSequence(Sequence) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
addSequence(Sequence) - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
addSequence(Sequence) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
addSequence(Sequence) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Add sequence corresponding to the name
addSequence(Sequence) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Add sequence.
addSequence(Sequence) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Add the sequence to the session.
addSequence(Sequence) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: You cannot add a sequence to a session broker, you must add it to its session.
addSequence(Sequence) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Add the sequence to the session.
addSequence(Sequence) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
Add sequence corresponding to the name Don't use if the session is connected.
addSequence(Sequence, boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Add sequence corresponding to the name.
addSequence(Sequence, boolean) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Add sequence.
addSession(String, Session) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
ADVANCED: add an named session to the hashtable.
addSession(DatabaseSession) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Add and initialize a new session to the list of sessions associated with this XMLContext.
addSession(Session) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
INTERNAL: Add an named session to the hashtable.
addSessionConfig(SessionConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.SessionConfigs
 
addSessionEventListener(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.event.SessionEventManagerConfig
 
addSessionName(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionBrokerConfig
 
addSessionName(String) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionBrokerPlaceHolder
 
addSkip() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
addSourceField(String) - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
addSourceField(String) - Method in class org.eclipse.persistence.tools.schemaframework.UniqueKeyConstraint
PUBLIC:
addSourceRelationKeyField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Add the fields in the intermediate table that corresponds to the primary key in the source table.
addSourceRelationKeyField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Add the fields in the intermediate table that corresponds to the primary key in the source table.
addSourceRelationKeyFieldName(String, String) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Add the fields in the intermediate table that corresponds to the primary key in the source table.
addSourceRelationKeyFieldName(String, String) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Add the fields in the intermediate table that corresponds to the primary key in the source table.
addSourceToTargetKeyFieldAssociation(String, String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ObjectReferenceMapping
Add a source-target xpath pair to the map.
addSourceToTargetKeyFieldAssociation(String, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
PUBLIC: Add a source-target xpath pair to the map.
addSourceToTargetKeyFieldAssociation(XMLField, XMLField) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
 
addSpecialOperation(Class<?>, String) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: Allows operations other than Expression.equal to be used for comparisons.
addSQLResultSetMapping(SQLResultSetMapping) - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: This will be the SQLResultSetMapping that is used by this query to process the database results
addSQLResultSetMapping(SQLResultSetMapping) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Add a named SQLResultSetMapping to this project.
addSQLResultSetMappingName(String) - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: Add a SQLResultSetMapping that is used by this query to process the database results.
addStandardDeviation(String) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the standard deviation value of the attribute to be included in the result.
addStandardDeviation(String, Expression) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the standard deviation value of the attribute to be included in the result.
addStartFieldName(String) - Method in class org.eclipse.persistence.history.HistoryPolicy
PUBLIC: Sets the name of the start field.
addStatement(String) - Method in class org.eclipse.persistence.tools.schemaframework.PackageDefinition
The statements are the SQL lines of code.
addStatement(String) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The statements are the SQL lines of code in procedure.
addStatement(SQLStatement) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Used to define a statement level query.
addStaticMetamodelClass(String, String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Add a metamodel class to model class reference.
addStructConverter(StructConverter) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
PUBLIC: Add a StructConverter to this DatabasePlatform This StructConverter will be invoked for all writes to the database for the class returned by its getJavaType() method and for all reads from the database for the Structs described by its getStructName() method
addStructConverter(StructConverter) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
ADVANCED: Add a StructConverter
addStructConverterClass(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.StructConverterConfig
 
addSubGroup(ATTRIBUTE_GROUP) - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
addSubSelectExpression(SubSelectExpression) - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
INTERNAL: Remember this subselect so that it can be normalized after the enclosing select statement is.
addSum(String) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the sum value of the attribute to be included in the result.
addSum(String, Class<?>) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the sum value of the attribute to be included in the result and return it as the specified resultType.
addSum(String, Expression) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the sum value of the attribute to be included in the result.
addSum(String, Expression, Class<?>) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the sum value of the attribute to be included in the result and return it as the specified resultType.
addSwaRefAttachment(byte[], int, int) - Method in interface org.eclipse.persistence.oxm.attachment.XMLAttachmentMarshaller
 
addSwaRefAttachment(DataHandler) - Method in interface org.eclipse.persistence.oxm.attachment.XMLAttachmentMarshaller
 
addTable(DatabaseTable) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Specify the table for the class of objects the receiver describes.
addTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Add a table to the statement.
addTableDefinition(TableDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Add the table.
addTableDefinitions(Collection<TableDefinition>) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Add a set of tables.
addTableName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Specify the table name for the class of objects the receiver describes.
addTableName(String) - Method in class org.eclipse.persistence.descriptors.RelationalDescriptor
PUBLIC: Specify the table name for the class of objects the receiver describes.
addTablePerTenantDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Add a descriptor that is uses a table per tenant multitenant policy.
addTablePerTenantQuery(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Add a query that queries a table per tenant entity
addTargetField(String) - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
addTargetForeignKeyField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Define the target foreign key relationship in the 1-M aggregate collection mapping.
addTargetForeignKeyField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Allow subclass to define a foreign key in the target's table.
addTargetForeignKeyField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Add the associated fields to the appropriate collections.
addTargetForeignKeyField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Define the target foreign key relationship in the 1-1 mapping.
addTargetForeignKeyFieldName(String, String) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Define the target foreign key relationship in the 1-M aggregate collection mapping.
addTargetForeignKeyFieldName(String, String) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
PUBLIC: Define the target foreign key relationship in the one-to-many mapping.
addTargetForeignKeyFieldName(String, String) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Define the target foreign key relationship in the 1-1 mapping.
addTargetForeignQueryKeyName(String, String) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
PUBLIC: Define the target foreign key relationship in the Variable 1-1 mapping.
addTargetQuery - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
Query used to update a single target row setting its foreign key to point to the source.
addTargetRelationKeyField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Add the fields in the intermediate table that corresponds to the primary key in the target table.
addTargetRelationKeyField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Add the fields in the intermediate table that corresponds to the primary key in the target table.
addTargetRelationKeyFieldName(String, String) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Add the fields in the intermediate table that corresponds to the primary key in the target table.
addTargetRelationKeyFieldName(String, String) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Add the fields in the intermediate table that corresponds to the primary key in the target table.
addTenantDiscriminatorField(String, DatabaseField) - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL: Add a tenant discriminator field to the policy.
addTenantDiscriminatorField(String, DatabaseField) - Method in class org.eclipse.persistence.descriptors.VPDMultitenantPolicy
INTERNAL: Return all the tenant id fields.
addThreadsKnownToBeStuckTryingToAcquireLock(Thread) - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
addThreadsKnownToBeStuckTryingToAcquireLockForReading(Thread) - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
addThreadsThatAcquiredActiveLock(Thread) - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
addThreadsThatAcquiredDeferredLock(Thread) - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
addThreadsThatAcquiredReadLock(Thread) - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
addTiming(String, long) - Method in class org.eclipse.persistence.tools.profiler.Profile
 
addToAttributeOnlyConversionValue(Object, Object) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
PUBLIC: An attribute only conversion value is a one-way mapping from the database to the object.
addToAttributeOnlyConversionValueStrings - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
addToAttributeOnlyConversionValueStrings(String, String) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Set from JPA processing where we deal with strings only to avoid class loader conflicts.
addToBuffer(String) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
This method can be used to store a string that will be prepended to the very next line of code entered
addToChangeTrackedHardList(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
addToCollectionChangeRecord(Object, Object, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Add a new value and its change set to the collection change record.
addToConstructorItem - Variable in class org.eclipse.persistence.queries.ReportQuery
flag to allow items to be added to the last ConstructorReportItem
addToMap(Map<DatabaseTable, DatabaseTable>) - Method in class org.eclipse.persistence.internal.expressions.TableAliasLookup
 
addTopLevelComplexTypes(ComplexType) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
addTopLevelElement(Element) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
addTopLevelSimpleTypes(SimpleType) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
addToTableDefinition(TableDefinition) - Method in interface org.eclipse.persistence.descriptors.MultitenantPolicy
 
addToTableDefinition(TableDefinition) - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL:
addToTableDefinition(TableDefinition) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL:
addToTableDefinition(TableDefinition) - Method in class org.eclipse.persistence.descriptors.VPDMultitenantPolicy
INTERNAL:
addTransformationMapping(TransformationMapping) - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
addTransformationMappingLines(NonreflectiveMethodDefinition, String, TransformationMapping) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addTypeAttribute(Descriptor, MarshalRecord, String) - Method in class org.eclipse.persistence.internal.oxm.XMLRelationshipMappingNodeValue
 
addTypeAttribute(MarshalRecord, String) - Method in class org.eclipse.persistence.internal.oxm.MappingNodeValue
 
addTypeConversionConverterLines(NonreflectiveMethodDefinition, String, TypeConversionConverter) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addTypes(boolean, boolean, DynamicType...) - Method in class org.eclipse.persistence.dynamic.DynamicHelper
Add one or more EntityType instances to a session and optionally generate needed tables with or without FK constraints.
addUnamedArgument(String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedArgument(String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the field/argument name to be substitute for the index argument.
addUnamedArgument(String, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedArgument(String, int) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the argument to the stored procedure for the index argument.
addUnamedArgument(String, int, String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedArgument(String, int, String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the argument to the stored procedure for the index argument.
addUnamedArgument(String, int, String, DatabaseField) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedArgument(String, int, String, DatabaseField) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the argument to the stored procedure for the index argument.
addUnamedArgument(String, Class<?>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedArgument(String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the argument to the stored procedure for the index argument.
addUnamedArgumentValue(Object) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedArgumentValue(Object) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the argument to the stored procedure for the index argument.
addUnamedInOutputArgument(String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedInOutputArgument(String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure for the index argument and the field/argument name to be substitute for it on the way in and out.
addUnamedInOutputArgument(String, Class<?>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedInOutputArgument(String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure for the index argument and the field/argument name to be substitute for it on the way in and out.
addUnamedInOutputArgument(String, String, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedInOutputArgument(String, String, int) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the argument to the stored procedure for the index argument.
addUnamedInOutputArgument(String, String, int, String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedInOutputArgument(String, String, int, String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure for the index argument and the field/argument name to be substitute for it on the way in and out.
addUnamedInOutputArgument(String, String, int, String, Class<?>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedInOutputArgument(String, String, int, String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure for the index argument and the field/argument name to be substitute for it on the way in and out.
addUnamedInOutputArgument(String, String, int, String, Class<?>, DatabaseField) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedInOutputArgument(String, String, int, String, Class<?>, DatabaseField) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure for the index argument and the field/argument name to be substitute for it on the way in and out.
addUnamedInOutputArgument(String, String, Class<?>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedInOutputArgument(String, String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the argument to the stored procedure for the index argument.
addUnamedInOutputArgumentValue(Object, String, Class<?>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedInOutputArgumentValue(Object, String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the inoutput argument to the stored procedure for the index argument and the field/argument name to be substitute for it on the way in and out.
addUnamedOutputArgument(String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedOutputArgument(String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the field/argument name to be substitute for the index output argument.
addUnamedOutputArgument(String, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedOutputArgument(String, int) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the field/argument name to be substitute for the index output argument.
addUnamedOutputArgument(String, int, String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedOutputArgument(String, int, String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the field/argument name to be substitute for the index output argument.
addUnamedOutputArgument(String, int, String, Class<?>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedOutputArgument(String, int, String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the field/argument name to be substitute for the index output argument.
addUnamedOutputArgument(String, int, String, Class<?>, DatabaseField) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedOutputArgument(String, int, String, Class<?>, DatabaseField) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the field/argument name to be substitute for the index output argument.
addUnamedOutputArgument(String, Class<?>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
addUnamedOutputArgument(String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Define the field/argument name to be substitute for the index output argument.
addUnconvertedProperty(String, String, String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Add an unconverted property (to be initialiazed at runtime)
addUnconvertedProperty(String, String, String) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: Add an unconverted property (to be initialiazed at runtime)
addUnionExpression(Expression) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Add the union expression to the query.
addUniqueConstraints(String, List<String>) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Add the unique constraint for the columns names.
addUniqueKeyConstraint(String, String) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add a unique key constraint to the table.
addUniqueKeyConstraint(String, String[]) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add a unique key constraint to the table.
addUniqueKeyConstraint(UniqueKeyConstraint) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Add a unique key constraint to the table.
addUniqueKeyConstraints(TableDefinition, Map<String, List<List<String>>>) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
 
addUnitOfWork(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Add a UnitOfWork object to the Hashtable keyed on the external transaction object.
addUnmappedFieldToMain(DatabaseField, ReturningPolicy.Info) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
 
addUnnamedCursorOutputArgument(String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
ADVANCED: Add the cursor output parameter to the procedure.
addUpdate(String, Object) - Method in class org.eclipse.persistence.queries.UpdateAllQuery
PUBLIC: Adds the update (SET) clause to the query.
addUpdate(String, Expression) - Method in class org.eclipse.persistence.queries.UpdateAllQuery
PUBLIC: Adds the update (SET) clause to the query.
addUpdate(Expression, Object) - Method in class org.eclipse.persistence.queries.UpdateAllQuery
PUBLIC: Adds the update (SET) clause to the query.
addUpdate(Expression, Expression) - Method in class org.eclipse.persistence.queries.UpdateAllQuery
PUBLIC: Adds the update (SET) clause to the query.
addUpdateInternal(Object, Object) - Method in class org.eclipse.persistence.queries.UpdateAllQuery
INTERNAL:
addValue(Object, boolean, Object) - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
addValueToArray(JsonBuilderRecord.Level, Object, QName) - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord
 
addValueToArray(JsonRecord.Level, Object, QName) - Method in class org.eclipse.persistence.oxm.record.JsonGeneratorRecord
 
addValueToArray(T, Object, QName) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
addValueToObject(JsonBuilderRecord.Level, String, Object, QName) - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord
 
addValueToObject(JsonRecord.Level, String, Object, QName) - Method in class org.eclipse.persistence.oxm.record.JsonGeneratorRecord
 
addValueToObject(T, String, Object, QName) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
addVariable(String, String) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The variables are the names of the declared variables used in the procedure.
addVariable(FieldDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The variables are the names of the declared variables used in the procedure.
addVariableOneToOneMappingLines(NonreflectiveMethodDefinition, String, VariableOneToOneMapping) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addVariance(String) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the variance value of the attribute to be included in the result.
addVariance(String, Expression) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the variance value of the attribute to be included in the result.
addWriteConnection(String, Accessor) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Add the connection to the client session.
addWriteLockFieldForInsert() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Add the initial write lock value to the row for insert.
addXDBDescriptors(String, DatabaseSessionImpl, NamespaceResolver) - Method in class org.eclipse.persistence.internal.sessions.factories.DirectToXMLTypeMappingHelper
Invoked from a descriptor add the descriptor for DirectToXMLTypeMapping
addXDBDescriptors(String, DatabaseSessionImpl, NamespaceResolver) - Method in class org.eclipse.persistence.sessions.factories.OracleDirectToXMLTypeMappingHelper
Invoked from a descriptor is not found.
addXMLConversion(QName, Class<?>) - Method in class org.eclipse.persistence.oxm.XMLField
Add an XML to Java Conversion pair entry
addXMLInteractionLines(NonreflectiveMethodDefinition, XMLInteraction, String) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
addXsiTypeAndClassIndicatorIfRequired(Descriptor, Descriptor, Field, boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
addXsiTypeAndClassIndicatorIfRequired(Descriptor, Descriptor, Field, boolean) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
addXsiTypeAndClassIndicatorIfRequired(Descriptor, Descriptor, Field, boolean) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
addXsiTypeAndClassIndicatorIfRequired(Descriptor, Descriptor, Field, boolean) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL
addXsiTypeAndClassIndicatorIfRequired(Descriptor, Descriptor, Field, Object, Object, boolean, boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
addXsiTypeAndClassIndicatorIfRequired(Descriptor, Descriptor, Field, Object, Object, boolean, boolean) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
INTERNAL
addXsiTypeAndClassIndicatorIfRequired(Descriptor, Descriptor, Field, Object, Object, boolean, boolean) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
addXsiTypeAndClassIndicatorIfRequired(Descriptor, Descriptor, Field, Object, Object, boolean, boolean) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL
adjustMultipleTableInsertOrder() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Adjust the order of the tables in the multipleTableInsertOrder Vector according to the FK relationship if one (or more) were previously specified.
adjustTypeName(String, Map<String, Set<String>>) - Static method in class org.eclipse.persistence.internal.codegen.CodeDefinition
Compares the typeName to those stored in the typeNameMap.
adjustTypeNames(Map<String, Set<String>>) - Method in class org.eclipse.persistence.internal.codegen.AttributeDefinition
 
adjustTypeNames(Map<String, Set<String>>) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
adjustTypeNames(Map<String, Set<String>>) - Method in class org.eclipse.persistence.internal.codegen.NonreflectiveAttributeDefinition
 
adjustTypeNames(Map<String, Set<String>>) - Method in class org.eclipse.persistence.internal.codegen.NonreflectiveMethodDefinition
 
adm - Variable in class org.eclipse.persistence.dynamic.DynamicEnumBuilder
 
AdvancedProcessor - Class in org.eclipse.persistence.internal.cache
Processor for computable tasks.
AdvancedProcessor() - Constructor for class org.eclipse.persistence.internal.cache.AdvancedProcessor
 
AFTER_EJBCREATE - Static variable in class org.eclipse.persistence.descriptors.CMPPolicy
issue SQL after ejbCreate but before ejbPostCreate
AFTER_EJBPOSTCREATE - Static variable in class org.eclipse.persistence.descriptors.CMPPolicy
issue SQL after ejbPostCreate
AFTER_INSERT - Static variable in interface org.eclipse.persistence.internal.sequencing.Sequencing
 
afterCommit(Accessor) - Method in interface org.eclipse.persistence.internal.sequencing.SequencingCallback
INTERNAL: Called after transaction has committed by the object that owns it: Accessor in non-jta case, SynchronizationListener in jta case.
afterCompletion(int) - Method in class org.eclipse.persistence.transaction.JTASynchronizationListener
INTERNAL: Called by the JTA transaction manager after the transaction is committed or rolled back.
afterCompletion(Object) - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
INTERNAL: The method performs the logic that should be executed after the transaction has been completed.
afterContainmentMarshal(Object, Object) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
afterContainmentMarshal(Object, Object) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
afterContainmentMarshal(Object, Object) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
afterExternalTransactionRollback() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Called after external transaction rolled back.
AfterExternalTransactionRolledBack - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
afterLast() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
Moves the cursor to the end of the result set, just after the last row.
afterLast() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Moves the cursor to the end of the result set, just after the last row.
afterMarshal(Object) - Method in interface org.eclipse.persistence.internal.oxm.Marshaller.Listener
This event will be called after an object is marshalled.
afterTranslateCustomQuery(List, List<DatasourceCall.ParameterType>) - Method in class org.eclipse.persistence.queries.SQLCall
INTERNAL: Set the data passed through setCustomSQLArgumentType and useCustomSQLCursorOutputAsResultSet methods.
afterTranslateCustomQueryUpdateParameter(DatabaseField, int, DatasourceCall.ParameterType, List, List<DatasourceCall.ParameterType>) - Method in class org.eclipse.persistence.queries.SQLCall
INTERNAL: Set the data passed through setCustomSQLArgumentType and useCustomSQLCursorOutputAsResultSet methods.
afterUnmarshal(Object, Object) - Method in interface org.eclipse.persistence.internal.oxm.Unmarshaller.Listener
Event that will be called after objects are unmarshalled.
AGGREGATE - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
AGGREGATE_COLLECTION - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
AGGREGATE_OBJECT_CANNOT_BE_DELETED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
AggregateAttributeChangeListener - Class in org.eclipse.persistence.internal.descriptors.changetracking
Purpose: Define a listener for attribute change tracking.
AggregateAttributeChangeListener(ClassDescriptor, UnitOfWorkImpl, AttributeChangeListener, String, Object) - Constructor for class org.eclipse.persistence.internal.descriptors.changetracking.AggregateAttributeChangeListener
Create a AttributeChangeListener with a descriptor and unit of work
AggregateChangeRecord - Class in org.eclipse.persistence.internal.sessions
This change Record is used to record the changes for AggregateObjectMapping.
AggregateChangeRecord - Interface in org.eclipse.persistence.sessions.changesets
Purpose: Define the Public interface for the Aggregate Change Record.
AggregateChangeRecord() - Constructor for class org.eclipse.persistence.internal.sessions.AggregateChangeRecord
This default constructor.
AggregateChangeRecord(ObjectChangeSet) - Constructor for class org.eclipse.persistence.internal.sessions.AggregateChangeRecord
This constructor returns an ChangeRecord representing an AggregateMapping.
aggregateChangeSets - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
 
AggregateCollectionChangeRecord - Class in org.eclipse.persistence.internal.sessions
This change record records the changes for AggregateCollectionMapping.
AggregateCollectionChangeRecord - Interface in org.eclipse.persistence.sessions.changesets
Purpose: Define the Public interface for the Aggregate Collection Change Record.
AggregateCollectionChangeRecord() - Constructor for class org.eclipse.persistence.internal.sessions.AggregateCollectionChangeRecord
This default constructor.
AggregateCollectionChangeRecord(ObjectChangeSet) - Constructor for class org.eclipse.persistence.internal.sessions.AggregateCollectionChangeRecord
This constructor returns an ChangeRecord representing an AggregateMapping.
AggregateCollectionMapping - Class in org.eclipse.persistence.mappings
Purpose: The aggregate collection mapping is used to represent the aggregate relationship between a single source object and a collection of target objects.
AggregateCollectionMapping() - Constructor for class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Default constructor.
aggregateKeyTable - Variable in class org.eclipse.persistence.mappings.AggregateObjectMapping
 
AggregateMapping - Class in org.eclipse.persistence.mappings
Purpose: Two objects can be considered to be related by aggregation if there is a strict 1:1 relationship between the objects.
AggregateMapping() - Constructor for class org.eclipse.persistence.mappings.AggregateMapping
Default constructor.
aggregateObjectCannotBeDeletedOrWritten(ClassDescriptor, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
AggregateObjectChangeListener - Class in org.eclipse.persistence.internal.descriptors.changetracking
Purpose: Define a listener for object change tracking.
AggregateObjectChangeListener(ObjectChangeListener, String) - Constructor for class org.eclipse.persistence.internal.descriptors.changetracking.AggregateObjectChangeListener
INTERNAL: Create a ObjectChangeListener
AggregateObjectChangeSet - Class in org.eclipse.persistence.internal.sessions
 
AggregateObjectChangeSet() - Constructor for class org.eclipse.persistence.internal.sessions.AggregateObjectChangeSet
The default constructor.
AggregateObjectChangeSet(Object, ClassDescriptor, Object, UnitOfWorkChangeSet, boolean) - Constructor for class org.eclipse.persistence.internal.sessions.AggregateObjectChangeSet
This constructor is used to create an ObjectChangeSet that represents a regular object.
AggregateObjectMapping - Class in org.eclipse.persistence.mappings
Purpose:Two objects can be considered to be related by aggregation if there is a strict 1:1 relationship between the objects.
AggregateObjectMapping() - Constructor for class org.eclipse.persistence.mappings.AggregateObjectMapping
Default constructor.
AggregateOperator - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
aggregateQueries - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Allow aggregate queries to be prepared and cached.
aggregateToSourceFields - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Map the name of a field in the aggregate collection descriptor to a field in the actual table specified in the mapping.
aggregateToSourceFields - Variable in class org.eclipse.persistence.mappings.AggregateObjectMapping
322233 - changed to store the source DatabaseField to hold Case and other colunm info
alias - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
alias(String) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression for the alias.
aliasDescriptors - Variable in class org.eclipse.persistence.sessions.Project
Cache the EJBQL descriptor aliases.
aliasedField - Variable in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
Cache the aliased field.
aliasedField - Variable in class org.eclipse.persistence.internal.expressions.FieldExpression
 
aliasedField - Variable in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
Cache the aliased field.
aliasedFields - Variable in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
aliasedViewTable - Variable in class org.eclipse.persistence.expressions.ExpressionBuilder
 
aliasFields(ObjectExpression, Vector) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Alias the supplied fields with respect to the expression node.
aliasForTable(DatabaseTable) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Find the alias for a given table
aliasForTable(DatabaseTable) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Find the alias for a given table.
aliasForTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: Find the alias for a given table from the first or second child in the additionalOuterJoinCriteria
aliasForTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL: Find the alias for a given table
aliasForTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
INTERNAL: Any table should use the sub-selects alias.
aliasForTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Find the alias for a given table
aliasForTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
INTERNAL: Find the alias for a given table.
aliasForTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Find the alias for a given table
aliasForTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
aliasPresetFields(SQLSelectStatement) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
If the fields in the statement have breen pre-set, e.g.
aliasResolutionException - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
aliasResolutionException(String, int, int, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
all() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the ALL operator.
all(boolean[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
all(byte[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that is used with a comparison expression.
all(char[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
all(double[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
all(float[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
all(int[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
all(long[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
all(short[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
all(Object[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
all(List) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
all(Expression) - Method in class org.eclipse.persistence.expressions.Expression
 
all(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
 
All - Class in org.eclipse.persistence.internal.oxm.schema.model
 
All - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
All() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.All
 
ALL - org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy.LockOnChange
 
ALL - org.eclipse.persistence.logging.LogCategory
 
ALL - org.eclipse.persistence.logging.LogLevel
Log everything.
ALL - Static variable in class org.eclipse.persistence.descriptors.ReturningPolicy
 
ALL - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
ALL - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
ALL_COLUMNS - org.eclipse.persistence.annotations.OptimisticLockingType
Using this type of locking policy compares every field in the table in the WHERE clause when doing an update or a delete.
ALL_LABEL - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
ALL_MODIFICATIONS - Static variable in class org.eclipse.persistence.descriptors.CMPPolicy
defer all modifications, inserts and deletes included (default)
allAggregateFieldsAreNull(AbstractRecord) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return whether all the aggregate fields in the specified row are NULL.
allChangeSets - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
 
allChildClassIndicators - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
allChildrenAreFields() - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
Test that both of our children are field nodes
allClones - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
This member variable contains a copy of all of the clones for this particular UOW
allFields - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
allFields - Variable in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
AllFieldsLockingPolicy - Class in org.eclipse.persistence.descriptors
Purpose: An implementation of the OptimisticLockingPolicy interface.
AllFieldsLockingPolicy() - Constructor for class org.eclipse.persistence.descriptors.AllFieldsLockingPolicy
PUBLIC: Create a new all fields locking policy.
allInternalOperators - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
Contains internal defined operators meant as placeholders for platform operators
allNonPrimaryKeyFields - Variable in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
 
allocateCalendar() - Static method in class org.eclipse.persistence.internal.helper.Helper
PERF: This is used to optimize Calendar conversion/printing.
allocateDynamicStatement(Connection) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Allocate a statement for dynamic SQL execution.
allocateReadConnection() - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Return a read connection from the read pool.
allOf(String, Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Returns an expression equivalent to all of attributeName holding true for criteria.
allOperators - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
Contains user defined operators
allOrderedFields - Variable in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
 
ALLOW_NATIVE_SQL_QUERIES - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jdbc.allow-native-sql-queries" property specifies whether any user defined SQL is allowed within a persistence unit.
ALLOW_NATIVE_SQL_QUERY - Static variable in class org.eclipse.persistence.config.QueryHints
The "eclipselink.jdbc.allow-native-sql-query" property specifies whether a single native SQL query should override a persistence unit level setting (eclipselink.jdbc.allow-native-sql-queries).
ALLOW_ZERO_ID - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
replaced by PersistenceUnitProperties.ID_VALIDATION property with value "NULL".
allowBindingForSelectClause() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
allowBindingForSelectClause() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 does not allow stand alone, untyped parameter markers in select clause.
allowBindingForSelectClause() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
 
allowBindingForSelectClause() - Method in class org.eclipse.persistence.platform.database.H2Platform
 
allowBindingForSelectClause() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
 
allowBindingForSelectClause() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
 
allowExtendedCacheLogging - Variable in class org.eclipse.persistence.sessions.Project
Flag that allows extended logging of JPA L2 cache or not.
allowExtendedCacheLogging() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return true if extended logging of JPA L2 cache usage is allowed on this project.
allowExtendedThreadLogging - Variable in class org.eclipse.persistence.sessions.Project
Flag that allows extended thread logging or not.
allowExtendedThreadLogging() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return true if extended thread logging is allowed on this project.
allowExtendedThreadLoggingThreadDump - Variable in class org.eclipse.persistence.sessions.Project
Flag that allows add to extended thread logging output thread stack trace or not.
allowExtendedThreadLoggingThreadDump() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return true if thread dumps will be added to extended thread logging.
allowExternalAccess(DocumentBuilderFactory, String, boolean) - Static method in class org.eclipse.persistence.internal.helper.XMLHelper
 
allowExternalAccess(TransformerFactory, String, boolean) - Static method in class org.eclipse.persistence.internal.helper.XMLHelper
 
allowExternalAccess(SchemaFactory, String, boolean) - Static method in class org.eclipse.persistence.internal.helper.XMLHelper
 
allowExternalAccess(XMLReader, String, boolean) - Static method in class org.eclipse.persistence.internal.helper.XMLHelper
 
allowExternalDTDAccess(DocumentBuilderFactory, String, boolean) - Static method in class org.eclipse.persistence.internal.helper.XMLHelper
 
allowExternalDTDAccess(SchemaFactory, String, boolean) - Static method in class org.eclipse.persistence.internal.helper.XMLHelper
 
allowExternalDTDAccess(XMLReader, String, boolean) - Static method in class org.eclipse.persistence.internal.helper.XMLHelper
 
allowNativeSQLQueries - Variable in class org.eclipse.persistence.sessions.Project
Flag that allows native queries or not
allowNativeSQLQueries() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return true if native sql is allowed on this project.
allowNativeSQLQuery - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Property used to override a persistence unit level that disallows native SQL queries.
allowNull() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
PUBLIC: If all the fields in the database row for the aggregate object are NULL, then, by default, the mapping will place a null in the appropriate source object (as opposed to an aggregate object filled with nulls).
allowSQLDeferral - Variable in class org.eclipse.persistence.sessions.Project
Flag that allows call deferral to be disabled
allowSQLDeferral() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return true if SQL calls can defer to EOT on this project.
allowsSizeInProcedureArguments() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for stored procedure definitions.
allowsSizeInProcedureArguments() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
 
allowTablePerMultitenantDDLGeneration - Variable in class org.eclipse.persistence.sessions.Project
Flag that allows DDL generation of table per tenant multitenant descriptors
allowTablePerMultitenantDDLGeneration() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return true if native sql is allowed on this project.
allQueries() - Method in annotation type org.eclipse.persistence.annotations.QueryRedirectors
This AllQueries Query Redirector will be applied to any executing object query that does not have a more precise redirector (like the ReadObjectQuery Redirector) or a redirector set directly on the query.
allSelectionFields - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
allsubclasses - Variable in class org.eclipse.persistence.core.queries.CoreAttributeGroup
This attribute is used to store all of the classes in this hierarchy keyed by type.
allTables - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
ALREADY_LOGGED_IN - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
alreadyLoggedIn(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
alter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.SequenceDefinition
INTERNAL: Execute the SQL required to alter sequence.
alterIncrement(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.SequenceObjectDefinition
INTERNAL: Execute the SQL required to alter sequence increment.
alterOnDatabase(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.SequenceDefinition
INTERNAL: By default does nothing.
alterOnDatabase(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.SequenceObjectDefinition
INTERNAL: Execute the SQL required to alter sequence increment.
alterSequence(SequenceDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Use the definition to alter sequence.
Always - org.eclipse.persistence.sessions.server.ConnectionPolicy.ExclusiveMode
 
Always - Static variable in class org.eclipse.persistence.config.ExclusiveConnectionMode
The value causes creation of ExclusiveIsolatedClientSession in both isolated and non-isolated cases.
alwaysConformResultsInUnitOfWork() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Used to set the descriptor to always conform in any unit of work query.
alwaysIncludeAttribute(Class<?>, String) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: Always considers the value for a particular attribute as meaningful in a query by example.
alwaysRefresh() - Method in annotation type org.eclipse.persistence.annotations.Cache
(Optional) Force all queries that go to the database to always refresh the cache.
alwaysRefreshCache() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This method is the equivalent of calling ClassDescriptor.setShouldAlwaysRefreshCache(boolean) with an argument of true: it configures a ClassDescriptor to always refresh the cache if data is received from the database by any query.
alwaysRefreshCacheOnRemote() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This method is the equivalent of calling ClassDescriptor.setShouldAlwaysRefreshCacheOnRemote(boolean) with an argument of true: it configures a ClassDescriptor to always remotely refresh the cache if data is received from the database by any query in a RemoteSession.
amendmentClass - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
amendmentClassName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
amendmentMethodName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
AMP - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
AN_EXCEPTION_OCCURRED - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
and() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the AND operator.
and(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that is the boolean logical combination of both expressions.
And - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
Logical operators
Annotation - Class in org.eclipse.persistence.internal.oxm.schema.model
 
Annotation() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Annotation
 
ANNOUNCEMENT_DELAY_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
announcementDelay - Variable in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
Delay time in millis between initialization and when the announcement is sent
announceSession() - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
INTERNAL: Send out an announcement that we are here.
ANTLR - Static variable in class org.eclipse.persistence.config.ParserType
Deprecated.
any() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the ANY operator.
any(boolean[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
any(byte[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that is used with a comparison expression.
any(char[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
any(double[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
any(float[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
any(int[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
any(long[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
any(short[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
any(Object[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
any(List) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
any(Expression) - Method in class org.eclipse.persistence.expressions.Expression
 
any(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
 
Any - Class in org.eclipse.persistence.internal.oxm.schema.model
 
Any - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
Any() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Any
 
ANY - org.eclipse.persistence.oxm.annotations.XmlVirtualAccessMethodsSchema
An XML <any> element will be written to the schema to represent all of the defined virtual properties.
ANY - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
ANY_ATTRIBUTE_ON_NON_MAP_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
ANY_FRAGMENT - Static variable in class org.eclipse.persistence.internal.oxm.XPathFragment
 
ANY_NAMESPACE_ANY - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
ANY_NAMESPACE_LOCAL - Static variable in class org.eclipse.persistence.oxm.XMLConstants
 
ANY_NAMESPACE_OTHER - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
ANY_NAMESPACE_TARGETNS - Static variable in class org.eclipse.persistence.oxm.XMLConstants
 
ANY_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
ANY_SIMPLE_TYPE - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
ANY_SIMPLE_TYPE_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
ANY_TYPE - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
ANY_TYPE_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
ANY_URI - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
ANY_URI_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
AnyAttribute - Class in org.eclipse.persistence.internal.oxm.schema.model
 
AnyAttribute() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.AnyAttribute
 
AnyAttributeMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
anyAttributeOnNonMap(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
AnyCollectionMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​CONVERTER extends CoreConverter,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​SESSION extends CoreSession,​UNMARSHAL_KEEP_AS_ELEMENT_POLICY extends UnmarshalKeepAsElementPolicy,​UNMARSHALLER extends Unmarshaller,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
AnyObjectMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​CONVERTER extends CoreConverter,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​SESSION extends CoreSession,​UNMARSHAL_KEEP_AS_ELEMENT_POLICY extends UnmarshalKeepAsElementPolicy,​UNMARSHALLER extends Unmarshaller,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
anyOf(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression representing traversal of a 1:many or many:many relationship.
anyOf(String, boolean) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression representing traversal of a 1:many or many:many relationship.
anyOf(String, boolean) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
PUBLIC: Return an expression representing traversal of a 1:many or many:many relationship.
anyOfAllowingNone(String) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression representing traversal of a 1:many or many:many relationship.
anyOfAllowingNone(String, boolean) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression representing traversal of a 1:many or many:many relationship.
anyOfAllowingNone(String, boolean) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
ADVANCED: Return an expression representing traversal of a 1:many or many:many relationship.
AOBJECT - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
APBYTE - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
APCHAR - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
APP_LOCATION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The property "eclipselink.application-location" specifies the file system directory location where DDL files are written (output) to.
APP_SERVER_CLASSLOADER_APPLICATION_PU_SEARCH_STRING_POSTFIX - Static variable in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
 
APP_SERVER_CLASSLOADER_APPLICATION_PU_SEARCH_STRING_PREFIX - Static variable in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
 
APP_SERVER_CLASSLOADER_MODULE_EJB_SEARCH_STRING_PREFIX - Static variable in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
Override by subclass: Search String in application server session for ejb modules
APP_SERVER_CLASSLOADER_MODULE_EJB_WAR_SEARCH_STRING_POSTFIX - Static variable in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
 
APP_SERVER_CLASSLOADER_MODULE_WAR_SEARCH_STRING_PREFIX - Static variable in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
Override by subclass: Search String in application server session for war modules
append(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.StrBuffer
 
append(Writer) - Method in interface org.eclipse.persistence.internal.databaseaccess.AppendCallCustomParameter
INTERNAL: Called only by DatabasePlatform.appendParameter()
append(Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.SimpleAppendCallCustomParameter
 
append(String) - Method in class org.eclipse.persistence.internal.oxm.StrBuffer
 
appendBoolean(Boolean, Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Appends a Boolean value as a number
appendBoolean(Boolean, Writer) - Method in class org.eclipse.persistence.platform.database.Informix11Platform
Fixes EclipseLink bug 401746 by writing out either 't' or 'f'—with single quotes— instead of 1 or 0.
appendBoolean(Boolean, Writer) - Method in class org.eclipse.persistence.platform.database.PointBasePlatform
Appends a Boolean value as true/false instead of 0/1
appendBoolean(Boolean, Writer) - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
Appends a Boolean value.
appendByteArray(byte[], Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Append the ByteArray in ODBC literal format ({b hexString}).
appendByteArray(byte[], Writer) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Append a byte[] in native DB@ format BLOB(hexString) if usesNativeSQL(), otherwise use ODBC format from DatabasePLatform.
appendByteArray(byte[], Writer) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL: TODO: Need to find out how can byte arrays be inlined in Derby
appendByteArray(byte[], Writer) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: If using native SQL then print a byte[] literally as a hex string otherwise use ODBC format as provided in DatabasePlatform.
appendByteArray(byte[], Writer) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
If using native SQL then print a byte[] as '0xFF...'
appendByteArray(byte[], Writer) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
If using native SQL then print a byte[] as '0xFF...'
appendByteArray(byte[], Writer) - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
If using native SQL then print a byte[] literally as a hex string otherwise use ODBC format as provided in DatabasePlatform.
appendCalendar(Calendar, Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Answer a platform correct string representation of a Calendar as a Timestamp, suitable for SQL generation.
appendCalendar(Calendar, Writer) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Append the Timestamp in native format if usesNativeSQL() is true otherwise use ODBC format from DatabasePlatform.
appendCalendar(Calendar, Writer) - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
appendCalendar(Calendar, Writer) - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Answer a platform correct string representation of a Calendar, suitable for SQL generation.
appendCalendar(Calendar, Writer) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
Appends an MySQL specific Timestamp, if usesNativeSQL is true otherwise use the ODBC format.
appendCalendar(Calendar, Writer) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Appends an Oracle specific Timestamp, if usesNativeSQL is true otherwise use the ODBC format.
appendCalendar(Calendar, Writer) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Answer a platform correct string representation of a Calendar, suitable for SQL generation.
appendCalendar(Calendar, Writer) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Answer a platform correct string representation of a Calendar, suitable for SQL generation.
appendCalendar(Calendar, Writer) - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Write a Calendar in Symfoware specific format.
Note that Symfoware does not support nanoseconds.
Symfoware: CNV_TIMESTAMP(calendar, 'YYYY-MM-DD hh24:mm:ss')
appendCalendar(Calendar, Writer) - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
Appends an TimesTen specific Timestamp, if usesNativeSQL is true otherwise use the ODBC format.
appendCall(AbstractSession, DatabaseCall) - Method in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
INTERNAL: This method is called by the DatabaseAccessor to add this statement to the list of statements being batched.
appendCall(AbstractSession, DatabaseCall) - Method in class org.eclipse.persistence.internal.databaseaccess.DynamicSQLBatchWritingMechanism
INTERNAL: This method is called by the DatabaseAccessor to add this statement to the list of statements being batched.
appendCall(AbstractSession, DatabaseCall) - Method in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
INTERNAL: This method is called by the DatabaseAccessor to add this statement to the list of statements being batched.
AppendCallCustomParameter - Interface in org.eclipse.persistence.internal.databaseaccess
INTERNAL:
appendChildNode(Node, Node) - Method in class org.eclipse.persistence.internal.oxm.SAXFragmentBuilder
 
appendChildNode(Node, Node) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
appendDate(Date, Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Answer a platform correct string representation of a Date, suitable for SQL generation.
appendDate(Date, Writer) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Appends the Date in native format if usesNativeSQL() otherwise use ODBC format from DatabasePlatform.
appendDate(Date, Writer) - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
appendDate(Date, Writer) - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Answer a platform correct string representation of a Date, suitable for SQL generation.
appendDate(Date, Writer) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
Appends an MySQL specific date if usesNativeSQL is true otherwise use the ODBC format.
appendDate(Date, Writer) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Appends an Oracle specific date if usesNativeSQL is true otherwise use the ODBC format.
appendDate(Date, Writer) - Method in class org.eclipse.persistence.platform.database.PointBasePlatform
Write a Date in PointBase specific format.
appendDate(Date, Writer) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Answer a platform correct string representation of a Date, suitable for SQL generation.
appendDate(Date, Writer) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Answer a platform correct string representation of a Date, suitable for SQL generation.
appendDate(Date, Writer) - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Appends a Date in Symfoware specific format.
Symfoware: DATE'YYYY-MM-DD'
appendDate(Date, Writer) - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
Appends an TimesTen specific date if usesNativeSQL is true otherwise use the ODBC format.
appendDB2Calendar(Calendar, Writer) - Method in class org.eclipse.persistence.platform.database.DB2Platform
Write a timestamp in DB2 specific format (yyyy-mm-dd-hh.mm.ss.ffffff).
appendDB2Date(Date, Writer) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Write a timestamp in DB2 specific format (mm/dd/yyyy).
appendDB2Timestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Write a timestamp in DB2 specific format (yyyy-mm-dd-hh.mm.ss.ffffff).
appendDBString(Writer, AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
INTERNAL: Append the database field definition string to the table creation statement.
appendDBString(Writer, AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.UniqueKeyConstraint
INTERNAL: Append the database field definition string to the table creation statement.
appendDBString(Writer, AbstractSession, TableDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
INTERNAL: Append the database field definition string to the table creation statement.
appendForUpdateClause(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
This method will append the for update clause to the end of the select statement.
appendFromClauseForInformixOuterJoin(ExpressionSQLPrinter, List<DatabaseTable>) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
ADVANCED: If a platform is Informix, then the outer join must be in the FROM clause.
appendFromClauseForOuterJoin(ExpressionSQLPrinter, List<DatabaseTable>, Collection, boolean) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
ADVANCED: Appends the SQL standard outer join clause, and some variation per platform.
appendFromClauseToWriter(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Print the from clause.
appendGroupByClauseToWriter(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
This method will append the group by clause to the end of the select statement.
appendHierarchicalQueryClauseToWriter(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
This method will append the Hierarchical Query Clause to the end of the select statement
appendIn(Writer, DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: All values are printed as ? to allow for parameter binding or translation during the execute of the call.
appendIn(Object) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendIn(Object, Boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendInformixCalendar(Calendar, Writer) - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Write a timestamp in Informix specific format ( yyyy-mm-dd hh:mm:ss.fff)
appendInformixTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Write a timestamp in Informix specific format (yyyy-mm-dd hh:mm:ss.fff).
appendInOut(Writer, DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: All values are printed as ? to allow for parameter binding or translation during the execute of the call.
appendInOut(Object, DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendInOut(Object, DatabaseField, Boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendInOut(DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendInOut(DatabaseField, Boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendLiteral(Writer, Object) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: All values are printed as ? to allow for parameter binding or translation during the execute of the call.
appendLiteral(Writer, Object) - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
All values are printed as ? to allow for parameter binding or translation during the execute of the call.
appendLiteral(Object) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendLiteral(Object, Boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendLiteralToCall(Call, Writer, Object, Boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: In case shouldBindLiterals is true, instead of null value a DatabaseField value may be passed (so that it's type could be used for binding null).
appendLiteralToCallWithBinding(Call, Writer, Object) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Override this method in case the platform needs to do something special for binding literals.
appendLock(Object, Object, ClassDescriptor, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.internal.helper.WriteLockManager
INTERNAL: This method will be called by a merging thread that is attempting to lock a new object that was not locked previously.
appendLogParameters(Collection, Accessor, StringWriter, AbstractSession) - Static method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Print the parameters to the write for logging purposes.
appendModify(Writer, DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: All values are printed as ? to allow for parameter binding or translation during the execute of the call.
appendModify(Writer, DatabaseField) - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
All values are printed as ? to allow for parameter binding or translation during the execute of the call.
appendModify(DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendModify(DatabaseField, Boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
AppendNewElementsOrderingPolicy - Class in org.eclipse.persistence.oxm.documentpreservation
INTERNAL:
AppendNewElementsOrderingPolicy() - Constructor for class org.eclipse.persistence.oxm.documentpreservation.AppendNewElementsOrderingPolicy
 
AppendNewElementsOrderingPolicyConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.login
 
AppendNewElementsOrderingPolicyConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.login.AppendNewElementsOrderingPolicyConfig
Default constructor.
appendNode(Node, Node, Node) - Method in class org.eclipse.persistence.oxm.documentpreservation.AppendNewElementsOrderingPolicy
 
appendNode(Node, Node, Node) - Method in class org.eclipse.persistence.oxm.documentpreservation.IgnoreNewElementsOrderingPolicy
 
appendNode(Node, Node, Node) - Method in class org.eclipse.persistence.oxm.documentpreservation.NodeOrderingPolicy
 
appendNode(Node, Node, Node) - Method in class org.eclipse.persistence.oxm.documentpreservation.RelativePositionOrderingPolicy
 
appendNumber(Number, Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Write number to SQL string.
appendOrderClauseToWriter(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
This method will append the order clause to the end of the select statement.
appendOut(Writer, DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: All values are printed as ? to allow for parameter binding or translation during the execute of the call.
appendOut(DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendOut(DatabaseField, Boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendOutCursor(DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendOutCursor(DatabaseField, Boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendParameter(Writer, Object, boolean, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Add the parameter.
appendParameter(Writer, Object, boolean, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Add the parameter using the DatasourcePlatform.
appendParameter(Writer, Object, boolean, AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
Add the parameter.
appendParameter(Call, Writer, Object) - Method in class org.eclipse.persistence.eis.EISPlatform
Add the parameter.
appendParameter(Call, Writer, Object) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Write a database-friendly representation of the given parameter to the writer.
appendParameter(Call, Writer, Object) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Add the parameter.
appendParameter(Call, Writer, Object) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Add the parameter.
appendParameterInternal(Call, Writer, Object) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Returns the number of parameters that used binding.
appendParameterInternal(Call, Writer, Object) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Returns the number of parameters that used binding.
appendString(String, Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Write the string.
appendSybaseCalendar(Calendar, Writer) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Write a timestamp in Sybase specific format ( yyyy-mm-dd-hh.mm.ss.fff)
appendSybaseCalendar(Calendar, Writer) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Write a timestamp in Sybase specific format ( yyyy-mm-dd-hh.mm.ss.fff)
appendSybaseTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Write a timestamp in Sybase specific format ( yyyy-mm-dd-hh.mm.ss.fff)
appendSybaseTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Write a timestamp in Sybase specific format (yyyy-mm-dd-hh.mm.ss.fff).
appendTime(Time, Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Answer a platform correct string representation of a Time, suitable for SQL generation.
appendTime(Time, Writer) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Append the Time in Native format if usesNativeSQL() otherwise use ODBC format from DAtabasePlatform.
appendTime(Time, Writer) - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
appendTime(Time, Writer) - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Answer a platform correct string representation of a Time, suitable for SQL generation.
appendTime(Time, Writer) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
Appends an MySQL specific time if usesNativeSQL is true otherwise use the ODBC format.
appendTime(Time, Writer) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Appends an Oracle specific time if usesNativeSQL is true otherwise use the ODBC format.
appendTime(Time, Writer) - Method in class org.eclipse.persistence.platform.database.PointBasePlatform
Write a Time in PointBase specific format.
appendTime(Time, Writer) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Answer a platform correct string representation of a Time, suitable for SQL generation.
appendTime(Time, Writer) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Answer a platform correct string representation of a Time, suitable for SQL generation.
appendTime(Time, Writer) - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Appends a Time in Symfoware specific format.
Symfoware: TIME'hh:mm:ss'
appendTime(Time, Writer) - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
Appends an TimesTen specific time if usesNativeSQL is true otherwise use the ODBC format.
appendTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Answer a platform correct string representation of a Timestamp, suitable for SQL generation.
appendTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Append the Timestamp in native format if usesNativeSQL() is true otherwise use ODBC format from DatabasePlatform.
appendTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
appendTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Answer a platform correct string representation of a Timestamp, suitable for SQL generation.
appendTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
Appends an MySQL specific Timestamp, if usesNativeSQL is true otherwise use the ODBC format.
appendTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Appends an Oracle specific Timestamp, if usesNativeSQL is true otherwise use the ODBC format.
appendTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.PointBasePlatform
Write a TimeStamp in PointBase specific format.
appendTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Answer a platform correct string representation of a Timestamp, suitable for SQL generation.
appendTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Answer a platform correct string representation of a Timestamp, suitable for SQL generation.
appendTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Appends a TimeStamp in Symfoware specific format.
Note that Symfoware does not support the milli- and nanoseconds.
Symfoware: TIMESTAMP'YYYY-MM-DD hh:mm:ss'
appendTimestamp(Timestamp, Writer) - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
Appends an TimesTen specific Timestamp, if usesNativeSQL is true otherwise use the ODBC format.
appendToDDLWriter(Writer, String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
appendToDDLWriter(String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
PUBLIC: If the schema manager is writing to a writer, append this string to that writer.
appendTranslation(Writer, DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: All values are printed as ? to allow for parameter binding or translation during the execute of the call.
appendTranslation(Writer, DatabaseField) - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
All values are printed as ? to allow for parameter binding or translation during the execute of the call.
appendTranslation(DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendTranslation(DatabaseField, Boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL:
appendTranslationParameter(Writer, ParameterExpression, DatabasePlatform, AbstractRecord) - Method in class org.eclipse.persistence.queries.SQLCall
INTERNAL: All values are printed as ? to allow for parameter binding or translation during the execute of the call.
appendTypeString(Writer, AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
INTERNAL: Append the database field definition string to the type creation statement.
appendTypeString(Writer, AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.NestedTableDefinition
INTERNAL: Append the type to the statement
appendTypeString(Writer, AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.ObjectVarrayDefinition
INTERNAL: Append the type.
appendTypeString(Writer, AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
INTERNAL: Append the type.
appendUnionClauseToWriter(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
This method will append the union clause to the end of the select statement.
appendWithAllSubclassesExpression(SQLSelectStatement) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Append the branch with all subclasses expression to the statement.
APPLICATION_JSON - org.eclipse.persistence.oxm.MediaType
 
APPLICATION_JSON - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
APPLICATION_XML - org.eclipse.persistence.oxm.MediaType
 
APPLICATION_XML - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
applyAmendmentMethod() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Call the descriptor amendment method.
applyAmendmentMethod(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Call the descriptor amendment method.
applyAttributeValuesIntoRow(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
PUBLIC: Re-populate the database row with the values from the source object based upon the attribute's mapping.
applyFunction(Object, List) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Apply this to an object in memory.
applyLogin() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Default apply login implementation.
applyORMMetadata(AbstractSession) - Method in class org.eclipse.persistence.oxm.XMLContext
ADVANCED: Adjust the OXM metadata to take into account ORM mapping metadata,
ARCHIVE_FACTORY - Static variable in class org.eclipse.persistence.config.SystemProperties
Configures the factory class we use to produce instances of org.eclispe.persistence.jpa.Archive These instances are used to examine persistence units and the files within them and are used for discovery of classes in the persistence unit Allows user-provided ArchiveFactory and Archive
areAllResourcesFreedOnClose() - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: Indicates whether all the resources used by connection are freed after close method returns.
areAllResourcesFreedOnClose() - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: Indicates whether all the resources used by connection are freed after close method returns.
areCollectionsEqualAsSets(Collection<? extends ReturningPolicy.Info>, Collection<? extends ReturningPolicy.Info>) - Static method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL: Compares two Collections as sets (ignoring the order of the elements).
areManyRowsReturned() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The return type is one of, NoReturn, ReturnOneRow or ReturnManyRows.
areNamespacesEqual(String, String) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Indicates if two namespaces are equal.
areObjectsToBeProcessedInstantiated(Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: The referenced object is checked if it is instantiated or not
arePrimaryKeyFields(Vector) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Used to determine if a foreign key references the primary key.
areTypesAssignable(List<Class<?>>, List<Class<?>>) - Static method in class org.eclipse.persistence.internal.helper.Helper
PUBLIC: Compare two vectors of types.
ARGNAME_SIZE_LIMIT - Static variable in interface org.eclipse.persistence.internal.helper.DatabaseType
 
ARGUMENT_SIZE_MISMATCH_IN_QUERY_AND_QUERY_DEFINITION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
argumentFields - Variable in class org.eclipse.persistence.queries.DatabaseQuery
PERF: Argument fields are cached in prepare to avoid rebuilding on each execution.
argumentIndices - Variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
ArgumentListFunctionExpression - Class in org.eclipse.persistence.internal.expressions
INTERNAL: This an extended FunctionExpression that allows the argument list to grow after it is created.
ArgumentListFunctionExpression() - Constructor for class org.eclipse.persistence.internal.expressions.ArgumentListFunctionExpression
 
ArgumentListFunctionExpression_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
argumentMarker() - Method in class org.eclipse.persistence.eis.interactions.XQueryInteraction
INTERNAL: Return the character to use for the argument marker.
argumentMarker() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: Return the character to use for the argument marker.
argumentName - Variable in class org.eclipse.persistence.internal.descriptors.InteractionArgument
The type of the query argument
argumentNames - Variable in class org.eclipse.persistence.eis.interactions.MappedInteraction
 
argumentNames - Variable in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
argumentNames() - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
argumentNamesSize() - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
argumentParameterTypes - Variable in class org.eclipse.persistence.queries.DatabaseQuery
 
arguments - Variable in class org.eclipse.persistence.eis.interactions.EISInteraction
Defines the arguments to the interaction, these can be the values or argument names/fields the values come from.
arguments - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
List of procedure IN/OUT/INOUT arguments.
arguments - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Arguments can be given and specified to predefined queries to allow reuse.
arguments - Variable in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
 
argumentsEqual(MethodDefinition) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
argumentsEqual(MethodDefinition) - Method in class org.eclipse.persistence.internal.codegen.NonreflectiveMethodDefinition
 
argumentsEqual(MethodDefinition) - Method in class org.eclipse.persistence.internal.codegen.ReflectiveMethodDefinition
 
argumentSizeMismatchInQueryAndQueryDefinition(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
argumentTypeNames - Variable in class org.eclipse.persistence.internal.codegen.NonreflectiveMethodDefinition
 
argumentTypeNames - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Used to build a list of argumentTypes by name pre-initialization
argumentTypes - Variable in class org.eclipse.persistence.internal.codegen.ReflectiveMethodDefinition
 
argumentTypes - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Needed to differentiate queries with the same name.
argumentTypes - Variable in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
 
argumentValues - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Arguments values can be given and specified to predefined queries to allow reuse.
Array - Annotation Type in org.eclipse.persistence.annotations
Array types are extended object-relational data-types supported by some databases.
Array - Static variable in class org.eclipse.persistence.config.ResultType
An Object array of values is returned (List<Object[]> or Object[]).
ARRAY - Static variable in class org.eclipse.persistence.queries.DataReadQuery
An Object[] of values is returned for each row.
ARRAY_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
ArrayCollectionMapping - Interface in org.eclipse.persistence.mappings.structures
Interface used by the ArrayCollectionMappingHelper to interact with the assorted array collection mappings.
ArrayCollectionMappingHelper - Class in org.eclipse.persistence.mappings.structures
Helper class to consolidate all the heinous comparing and merging code for the Array collection mappings.
ArrayCollectionMappingHelper(ArrayCollectionMapping) - Constructor for class org.eclipse.persistence.mappings.structures.ArrayCollectionMappingHelper
Constructor.
arrayFromVector(Vector<?>) - Static method in class org.eclipse.persistence.internal.helper.Helper
Convert the specified vector into an array.
ArrayList_class - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
ArrayListContainerPolicy - Class in org.eclipse.persistence.internal.queries
PERF: Avoids reflection usage for ArrayList.
ArrayListContainerPolicy() - Constructor for class org.eclipse.persistence.internal.queries.ArrayListContainerPolicy
INTERNAL: Construct a new policy.
ArrayListContainerPolicy(Class<?>) - Constructor for class org.eclipse.persistence.internal.queries.ArrayListContainerPolicy
INTERNAL: Construct a new policy for the specified class.
ArrayListContainerPolicy(String) - Constructor for class org.eclipse.persistence.internal.queries.ArrayListContainerPolicy
INTERNAL: Construct a new policy for the specified class name.
ArrayMapping - Class in org.eclipse.persistence.mappings.structures
Purpose: In an object-relational data model, structures can contain "Arrays" or collections of other data-types.
ArrayMapping() - Constructor for class org.eclipse.persistence.mappings.structures.ArrayMapping
Default constructor.
ArrayRecord - Class in org.eclipse.persistence.internal.sessions
PERF: Optimized record implementation using arrays instead of Vector.
ArrayRecord() - Constructor for class org.eclipse.persistence.internal.sessions.ArrayRecord
 
ArrayRecord(Vector, DatabaseField[], Object[]) - Constructor for class org.eclipse.persistence.internal.sessions.ArrayRecord
 
as() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the AS operator.
as(String) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Assign an alias to the expression in the select clause.
As - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
AS_OF - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.history.as-of"
AS_OF_SCN - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.history.as-of.scn"
ascending() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This can only be used within an ordering expression.
ascending() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the ASCENDING operator.
Ascending - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
Ordering operators
ascendingOperator() - Method in class org.eclipse.persistence.platform.database.DB2Platform
Disable binding support.
ascii() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
Ascii - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
asciiValue() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the single character strings ascii value.
asin() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
asin(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Asin - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
asOf(AsOfClause) - Method in class org.eclipse.persistence.expressions.Expression
Sets all tables represented by this expression to be queried as of a past time.
asOf(AsOfClause) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
asOf(AsOfClause) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
asOf(AsOfClause) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
asOfClause - Variable in class org.eclipse.persistence.internal.expressions.DataExpression
 
AsOfClause - Class in org.eclipse.persistence.history
Purpose:Wraps an immutable value for a past time.
AsOfClause() - Constructor for class org.eclipse.persistence.history.AsOfClause
 
AsOfClause(long) - Constructor for class org.eclipse.persistence.history.AsOfClause
 
AsOfClause(Long) - Constructor for class org.eclipse.persistence.history.AsOfClause
 
AsOfClause(Number) - Constructor for class org.eclipse.persistence.history.AsOfClause
 
AsOfClause(Timestamp) - Constructor for class org.eclipse.persistence.history.AsOfClause
 
AsOfClause(Calendar) - Constructor for class org.eclipse.persistence.history.AsOfClause
 
AsOfClause(Date) - Constructor for class org.eclipse.persistence.history.AsOfClause
 
AsOfClause(Expression) - Constructor for class org.eclipse.persistence.history.AsOfClause
 
AsOfClause(AsOfClause) - Constructor for class org.eclipse.persistence.history.AsOfClause
 
AsOfSCNClause - Class in org.eclipse.persistence.history
Purpose:Wraps an immutable value for a past time, represented as a database system change number.
AsOfSCNClause(long) - Constructor for class org.eclipse.persistence.history.AsOfSCNClause
 
AsOfSCNClause(Long) - Constructor for class org.eclipse.persistence.history.AsOfSCNClause
 
AsOfSCNClause(Number) - Constructor for class org.eclipse.persistence.history.AsOfSCNClause
 
AsOfSCNClause(Expression) - Constructor for class org.eclipse.persistence.history.AsOfSCNClause
 
assignAlias(String, DatabaseTable) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Alias a particular table within this node
assignAlias(String, DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL: Alias a particular table within this node
assignAlias(DatabaseTable, DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL: Alias a particular table within this node
assignAlias(DatabaseTable, DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.TableExpression
INTERNAL: Alias a particular table within this node
assignAlias(DatabaseTable, DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
INTERNAL: Alias a particular table within this node
assignAliases(Vector) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Alias the tables in all of our nodes.
assignDefaultValues(AbstractSession) - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Some attributes have default values defined in Project.
assignDefaultValues(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Some attributes have default values defined in Project.
assignedFields - Variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForTempTable
 
assignIndices() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
INTERNAL compute the re-ordered indices - Do the IN args first, then the 'IN-half' of the INOUT args next, the OUT args, then the 'OUT-half' of the INOUT args
assignReturnRow(Object, AbstractSession, AbstractRecord, ObjectChangeSet) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Assign the fields in the row back into the object.
assignReturnValueForField(Object, ReadObjectQuery, AbstractRecord, DatabaseField, Collection, ObjectChangeSet) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Assign the field value from the row to the object for all the mappings using field (read or write).
assignReturnValueToMapping(Object, ReadObjectQuery, AbstractRecord, DatabaseField, DatabaseMapping, Collection, ObjectChangeSet) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Assign values from objectRow to the object through the mapping.
AssignSequence - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
assignSequenceNumber(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Assign sequence number to the object.
assignSequenceNumber(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Assign sequence number to the object.
assignSequenceNumber(Object, Object, AbstractSession, WriteObjectQuery) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Update the object primary key by fetching a new sequence number from the accessor.
assignSequenceNumber(Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Assign sequence number to the object.
assignSequenceNumber(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Update the object primary key by fetching a new sequence number from the accessor.
assignSequenceNumber(WriteObjectQuery) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Update the writeQuery's object primary key by fetching a new sequence number from the accessor.
assignSequenceNumber(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Update the writeQuery's object primary key by fetching a new sequence number from the accessor.
assignSequenceNumbers() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Assign sequence numbers to all new objects registered in this unit of work, or any new objects reference by any objects registered.
assignSequenceNumbers() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Assign sequence numbers to all new objects registered in this unit of work, or any new objects reference by any objects registered.
assignSequenceNumbers(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Assign sequence numbers to all of the objects.
assignTableAliasesStartingAt(int) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Assign aliases to any tables which I own.
assignTableAliasesStartingAt(int) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Assign aliases to any tables which I own.
assignTableAliasesStartingAt(int) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL: Assign aliases to any tables which I own.
assignTableAliasesStartingAt(int) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
INTERNAL: Assign aliases to any tables which I own.
Association - Class in org.eclipse.persistence.mappings
Purpose: Generic association object.
Association() - Constructor for class org.eclipse.persistence.mappings.Association
Default constructor.
Association(Object, Object) - Constructor for class org.eclipse.persistence.mappings.Association
PUBLIC: Create an association.
ASSUME_EXISTENCE - org.eclipse.persistence.annotations.ExistenceType
Assume that if the objects primary key does not include null then it must exist.
ASSUME_NON_EXISTENCE - org.eclipse.persistence.annotations.ExistenceType
Assume that the object does not exist.
AssumeExistence - Static variable in class org.eclipse.persistence.queries.DoesExistQuery
 
assumeExistenceForDoesExist() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Assume that if the objects primary key does not include null then it must exist.
assumeExistenceForDoesExist() - Method in class org.eclipse.persistence.queries.DoesExistQuery
PUBLIC: Assume that if the objects primary key does not include null then it must exist.
assumeExistenceForDoesExist() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Switch all descriptors to assume existence for non-null primary keys.
AssumeNonExistence - Static variable in class org.eclipse.persistence.queries.DoesExistQuery
 
assumeNonExistenceForDoesExist() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Assume that the object does not exist.
assumeNonExistenceForDoesExist() - Method in class org.eclipse.persistence.queries.DoesExistQuery
PUBLIC: Assume that the object does not exist.
ASTRING - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
asynchronousPropagateCommand() - Method in class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
INTERNAL: Asynchronously propagate the command
atan() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
atan(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Atan - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
atan2(Expression, int) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
atan2(Expression, Object) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
atan2(Expression, Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Atan2 - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
atEnd() - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Return whether the cursored stream is at its end.
atEndOfCursor - Variable in class org.eclipse.persistence.queries.ScrollableCursor
Internal flag indicating if the end of the cursor has been reached
atLeast(JavaSEPlatform) - Static method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Check whether current Java SE is at least (greater or equal) provided platform.
attachmentMarshaller - Variable in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
ATTEMPT_TO_REGISTER_DEAD_INDIRECTION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ATTEMPT_TO_RESET_APP_RESOLVER - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ATTEMPTED_LOAD_SESSION_WITHOUT_NAME_PROVIDED - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
ATTEMPTED_REDEPLOY_WITHOUT_CLOSE - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
attemptedRedeployWithoutClose(String) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
attemptToAcquireLock(ClassDescriptor, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.helper.WriteLockManager
INTERNAL: This method performs the operations of finding the cacheKey and locking it if possible.
attemptToRegisterDeadIndirection(Object, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
attemptToResetApplicationResolver() - Static method in exception org.eclipse.persistence.exceptions.SDOException
 
attribute - Variable in class org.eclipse.persistence.internal.expressions.SubSelectExpression
 
attribute - Variable in class org.eclipse.persistence.internal.sessions.ChangeRecord
This is the attribute name that this change record represents
attribute() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlVariableNode
 
attribute(String, String, String, String) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
attribute(String, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
attribute(String, String, String, String) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
attribute(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
INTERNAL:
attribute(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
attribute(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
attribute(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Receive notification of an attribute.
attribute(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL:
attribute(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL:
attribute(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
attribute(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL:
attribute(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
attribute(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
Marshal an attribute for the give namespaceURI, localName, qualifiedName and value
attribute(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.FieldTransformerNodeValue
 
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL:
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.TypeNodeValue
 
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
 
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
Handle swaRef and inline attribute cases.
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
The underlying choice element node value will handle attributes.
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceObjectMappingNodeValue
The underlying choice element node value will handle attributes.
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
Handle attribute operation.
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLDirectMappingNodeValue
 
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentMappingNodeValue
 
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectReferenceMappingNodeValue
Handle attribute operation.
attribute(UnmarshalRecord, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathMappingNodeValue
 
attribute(XPathFragment, NAMESPACE_RESOLVER, Object, QName) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
attribute(XPathFragment, NAMESPACE_RESOLVER, String) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
attribute(XPathFragment, NamespaceResolver, Object, QName) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
attribute(XPathFragment, NamespaceResolver, Object, QName) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
attribute(XPathFragment, NamespaceResolver, Object, QName) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Convert the value if necessary and write out the attribute and converted value.
attribute(XPathFragment, NamespaceResolver, String) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
INTERNAL:
attribute(XPathFragment, NamespaceResolver, String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
attribute(XPathFragment, NamespaceResolver, String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
attribute(XPathFragment, NamespaceResolver, String) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Receive notification of an attribute.
attribute(XPathFragment, NamespaceResolver, String) - Method in class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL:
attribute(XPathFragment, NamespaceResolver, String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL:
attribute(XPathFragment, NamespaceResolver, String) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
attribute(XPathFragment, NamespaceResolver, String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL:
attribute(XPathFragment, NamespaceResolver, String) - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
attribute(XPathFragment, NamespaceResolver, String) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
Attribute - Class in org.eclipse.persistence.internal.oxm.schema.model
 
Attribute - Static variable in class org.eclipse.persistence.config.ResultType
A List of the first selected value is returned.
Attribute() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Attribute
 
Attribute(String, String, String, String) - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.Attribute
 
ATTRIBUTE - org.eclipse.persistence.annotations.ChangeTrackingType
An ATTRIBUTE change tracking type allows change tracking at the attribute level of an object.
ATTRIBUTE - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
ATTRIBUTE - Static variable in class org.eclipse.persistence.queries.DataReadQuery
A single value is returned for each row.
ATTRIBUTE_AND_MAPPING_WITH_INDIRECTION_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ATTRIBUTE_AND_MAPPING_WITH_TRANSPARENT_INDIRECTION_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ATTRIBUTE_AND_MAPPING_WITHOUT_INDIRECTION_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ATTRIBUTE_COULD_NOT_BE_FOUND_FOR_ENTITY - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
ATTRIBUTE_COULD_NOT_BE_UPDATED - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
ATTRIBUTE_FORM_QUALIFIED_KEY - Static variable in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGeneratorProperties
 
ATTRIBUTE_NAME_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ATTRIBUTE_TRANSFORMER_CLASS_INVALID - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ATTRIBUTE_TRANSFORMER_CLASS_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ATTRIBUTE_TYPE_NOT_VALID - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
attributeAccessor - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
Wrapper to store the reference objects.
AttributeAccessor - Class in org.eclipse.persistence.mappings
Purpose: This provides an abstract class for setting and retrieving the attribute value for the mapping from an object.
AttributeAccessor() - Constructor for class org.eclipse.persistence.mappings.AttributeAccessor
Default constructor.
attributeAndMappingWithIndirectionMismatch(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
attributeAndMappingWithoutIndirectionMismatch(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
attributeAndMappingWithTransparentIndirectionMismatch(DatabaseMapping, Class<?>, String) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
AttributeChangeListener - Class in org.eclipse.persistence.internal.descriptors.changetracking
Purpose: Define a listener for attribute change tracking.
AttributeChangeListener(ClassDescriptor, UnitOfWorkImpl, Object) - Constructor for class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
INTERNAL: Create a AttributeChangeListener with a descriptor and unit of work
AttributeChangeTrackingPolicy - Class in org.eclipse.persistence.descriptors.changetracking
PUBLIC: An AttributeChangeTrackingPolicy allows change tracking at the attribute level of an object by implementing ChangeTracker.
AttributeChangeTrackingPolicy() - Constructor for class org.eclipse.persistence.descriptors.changetracking.AttributeChangeTrackingPolicy
 
attributeClassification - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
attributeClassification - Variable in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
To specify the conversion type
attributeClassificationName - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
attributeClassificationName - Variable in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
 
attributeConverter - Variable in class org.eclipse.persistence.mappings.converters.ConverterClass
 
attributeConverterClassName - Variable in class org.eclipse.persistence.mappings.converters.ConverterClass
 
AttributeDefinition - Class in org.eclipse.persistence.internal.codegen
INTERNAL:
AttributeDefinition() - Constructor for class org.eclipse.persistence.internal.codegen.AttributeDefinition
 
attributeExpression - Variable in class org.eclipse.persistence.internal.queries.ReportItem
Expression (partial) describing the attribute wanted
attributeExpressions - Variable in class org.eclipse.persistence.queries.BatchFetchPolicy
Define the attributes to be batch fetched.
attributeField - Variable in class org.eclipse.persistence.internal.descriptors.InstanceVariableAttributeAccessor
The attribute name of an object is converted to Field type to access it reflectively
AttributeGroup - Class in org.eclipse.persistence.internal.oxm.schema.model
 
AttributeGroup - Class in org.eclipse.persistence.queries
Purpose: An AttributeGroup represents a set of mappings and nested AttributeGroups for relationship mappings for an entity type.
AttributeGroup() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.AttributeGroup
 
AttributeGroup() - Constructor for class org.eclipse.persistence.queries.AttributeGroup
 
AttributeGroup(String) - Constructor for class org.eclipse.persistence.queries.AttributeGroup
 
AttributeGroup(String, Class<?>, boolean) - Constructor for class org.eclipse.persistence.queries.AttributeGroup
INTERNAL: This constructer is to only be used by EclipseLink internally
AttributeGroup(String, String, boolean) - Constructor for class org.eclipse.persistence.queries.AttributeGroup
 
attributeGroups - Variable in class org.eclipse.persistence.core.descriptors.CoreDescriptor
 
attributeGroups - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Stores predefined reusable AttributeGroups.
attributeGroups - Variable in class org.eclipse.persistence.sessions.Project
List of named AttributeGroups - once Project is initialized, these are copied to the Session.
AttributeItem - Class in org.eclipse.persistence.internal.queries
Purpose: Elements stored in AttributeGroup
AttributeItem() - Constructor for class org.eclipse.persistence.internal.queries.AttributeItem
 
AttributeItem(AttributeGroup, String) - Constructor for class org.eclipse.persistence.internal.queries.AttributeItem
 
attributeMappingIsMissingForEntityBean(String, String) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
attributeName - Variable in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
attributeName - Variable in class org.eclipse.persistence.descriptors.CMPPolicy.KeyIsElementAccessor
 
attributeName - Variable in class org.eclipse.persistence.mappings.AttributeAccessor
Stores the name of the attribute
attributeName - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
PERF: Cache the mappings attribute name.
attributeName - Variable in class org.eclipse.persistence.queries.FieldResult
Stores the name of the bean attribute
attributeNameNotSpecified() - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
AttributeNamePrefix - Enum in org.eclipse.persistence.internal.mappings.converters
INTERNAL: Attribute name prefixes.
AttributeNameTokenizer - Class in org.eclipse.persistence.internal.mappings.converters
INTERNAL: Attribute name tokenizer.
AttributeNameTokenizer(String) - Constructor for class org.eclipse.persistence.internal.mappings.converters.AttributeNameTokenizer
INTERNAL: Creates an instance of attribute name tokenizer.
AttributeNameTokenizer.TokensIterator - Class in org.eclipse.persistence.internal.mappings.converters
INTERNAL: Attribute name tokenizer parser implemented as an Iterator<String> over individual attribute name tokens.
attributeNodes() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNamedObjectGraph
The list of properties to be marshalled/unmarshalled for this graph.
attributeNodes() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNamedSubgraph
The list of properties to include in this graph
attributeObjectClassification - Variable in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
PERF: Also store object class of attribute in case of primitive.
attributePrefix - Variable in class org.eclipse.persistence.oxm.record.JsonRecord
 
attributePrefix - Variable in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
attributes - Variable in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
attributes - Variable in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
attributes - Variable in class org.eclipse.persistence.queries.BatchFetchPolicy
PERF: Cache the local batch read attribute names.
attributes() - Method in annotation type org.eclipse.persistence.annotations.FetchGroup
(Required) The list of attributes to fetch.
attributes() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
attributesToAlwaysInclude - Variable in class org.eclipse.persistence.queries.QueryByExamplePolicy
 
attributesToChanges - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
attributeToFieldValues - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
attributeTransformationMethod - Variable in class org.eclipse.persistence.mappings.transformers.MethodBasedAttributeTransformer
 
attributeTransformer - Variable in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
attributeTransformerClassName is converter to an instance of AttributeTransformer
AttributeTransformer - Interface in org.eclipse.persistence.mappings.transformers
PUBLIC:
AttributeTransformerAdapter - Class in org.eclipse.persistence.mappings.transformers
Purpose: Provides an empty implementation of AttributeTransformer.
AttributeTransformerAdapter() - Constructor for class org.eclipse.persistence.mappings.transformers.AttributeTransformerAdapter
Default constructor.
attributeTransformerClassInvalid(String, AbstractTransformationMapping, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
attributeTransformerClassName - Variable in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
Name of the class which implements AttributeTransformer to be used to retrieve the attribute value
attributeTransformerClassNotFound(String, AbstractTransformationMapping, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
attributeTypeNotValid(CollectionMapping, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
attributeWithoutQName(String, String, String, String) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
attributeWithoutQName(String, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
attributeWithoutQName(String, String, String, String) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
attributeWithoutQName(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
attributeWithoutQName(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
Marshal an attribute for the give namespaceURI, localName, preifx and value
attributeWithoutQName(String, String, String, String) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
Attunity - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
AttunityPlatform - Class in org.eclipse.persistence.platform.database
TopLink Platform class which works with Attunity's Connect JDBC driver.
AttunityPlatform() - Constructor for class org.eclipse.persistence.platform.database.AttunityPlatform
 
Auto - Static variable in class org.eclipse.persistence.config.QueryType
 
Auto - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
AUTO - org.eclipse.persistence.annotations.CacheKeyType
The cache key type is automatically configured depending on what is optimal for the class.
AUTO - org.eclipse.persistence.annotations.ChangeTrackingType
Will not set any change tracking policy, and the change tracking will be determined at runtime.
AUTO - Static variable in class org.eclipse.persistence.queries.DataReadQuery
Auto, a single value if a single field is selected, otherwise an Object[] (JPA default).
autoCommit(DatabaseAccessor) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used by JDBC drivers that do not support autocommit so simulate an autocommit.
available() - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Returns the number of objects that can be read from this input without blocking.
average() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, This represents the aggregate function Average.
average() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the AVERAGE operator.
Average - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
avgOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
avgOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Disable binding support.

B

BACKUP_CLONE_DELETED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
BACKUP_CLONE_IS_ORIGINAL_FROM_PARENT - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
BACKUP_CLONE_IS_ORIGINAL_FROM_SELF - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
backupAttributeValueIsNull(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return whether the query's backup object has an attribute value of null.
backupClone - Variable in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
 
backupCloneAttribute(Object, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return a backup clone of the attribute.
backupCloneAttribute(Object, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return a backup clone of the attribute.
backupCloneAttribute(Object, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return a backup clone of the attribute.
backupCloneAttribute(Object, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Return a backup clone of the attribute.
backupCloneAttribute(Object, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return a backup clone of the attribute.
backupCloneIsDeleted(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
backupCloneIsOriginalFromParent(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
backupCloneIsOriginalFromSelf(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
backupValueHolder - Variable in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
The value holder stored in the backup copy, should not be transient.
BackupValueHolder<T> - Class in org.eclipse.persistence.internal.indirection
Used as the backup value holder in the unit of work for transparent indirection.
BackupValueHolder(ValueHolderInterface<T>) - Constructor for class org.eclipse.persistence.internal.indirection.BackupValueHolder
 
bannerText() - Method in class org.eclipse.persistence.tools.PackageRenamer
 
BASE_64_BINARY - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
BASE_64_BINARY_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
Base64 - Class in org.eclipse.persistence.internal.oxm.conversion
INTERNAL:
base64Decode(byte[]) - Static method in class org.eclipse.persistence.internal.oxm.conversion.Base64
base64Binary data is likely to be long, and decoding requires each character to be accessed twice (once for counting length, another for decoding.) This method decodes the given byte[] using the java.util.Base64
base64Encode(byte[]) - Static method in class org.eclipse.persistence.internal.oxm.conversion.Base64
This method encodes the given byte[] using java.util.Base64
base64EncodeToString(byte[]) - Static method in class org.eclipse.persistence.internal.oxm.conversion.Base64
This method encodes the given byte[] using java.util.Base64.
baseExpression - Variable in class org.eclipse.persistence.internal.expressions.BaseExpression
The base expression is what this was derived from.
BaseExpression - Class in org.eclipse.persistence.internal.expressions
Generic class for an expression with a base.
BaseExpression() - Constructor for class org.eclipse.persistence.internal.expressions.BaseExpression
 
BaseExpression(Expression) - Constructor for class org.eclipse.persistence.internal.expressions.BaseExpression
 
baseExpressionBuilder - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Stores the base builder for resolving joined attributes by name.
baseQuery - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Stores the base query.
basicBeginTransaction() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Called by beginTransaction() to start a transaction.
basicBeginTransaction() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Begin the transaction on all child sessions.
basicBeginTransaction(Accessor) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Called by beginTransaction() to start a transaction.
basicBeginTransaction(AbstractSession) - Method in class org.eclipse.persistence.eis.EISAccessor
Begin a local transaction.
basicBeginTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Begin a transaction on the database.
basicBeginTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Begin the driver level transaction.
basicBeginTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLAccessor
Begin a transaction on the "data store".
BasicCollection - Annotation Type in org.eclipse.persistence.annotations
Deprecated. 
basicCommitTransaction() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Called by commitTransaction() to commit a transaction.
basicCommitTransaction() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Commit the transaction on all child sessions.
basicCommitTransaction() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: This is internal to the unit of work and should not be called otherwise.
basicCommitTransaction(AbstractSession) - Method in class org.eclipse.persistence.eis.EISAccessor
Commit the local transaction.
basicCommitTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Commit a transaction on the database.
basicCommitTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Commit the driver level transaction.
basicCommitTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLAccessor
Commit the transaction to the "data store".
basicDescription() - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
Return description.
basicExecuteCall(Call, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.eis.EISAccessor
Execute the interaction.
basicExecuteCall(Call, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Execute the call.
basicExecuteCall(Call, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Execute the call to driver level datasource.
basicExecuteCall(Call, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLAccessor
 
basicExecuteCall(Call, AbstractRecord, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Execute the call.
basicExecuteCall(Call, AbstractRecord, DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Execute the call on each accessors and merge the results.
BasicIndirectionPolicy - Class in org.eclipse.persistence.internal.indirection
Purpose
BasicIndirectionPolicy() - Constructor for class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Construct a new indirection policy.
basicLog(int, String, String) - Method in class org.eclipse.persistence.platform.server.ServerLog
Log message to a writer by default.
BasicMap - Annotation Type in org.eclipse.persistence.annotations
Deprecated. 
basicPrintRegisteredObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Print the objects in the unit of work.
basicRollbackTransaction() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Called by rollbackTransaction() to rollback a transaction.
basicRollbackTransaction() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Rollback the transaction on all child sessions.
basicRollbackTransaction() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: This is internal to the unit of work and should not be called otherwise.
basicRollbackTransaction(AbstractSession) - Method in class org.eclipse.persistence.eis.EISAccessor
Rollback the local transaction on the datasource.
basicRollbackTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Rollback a transaction on the database.
basicRollbackTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Rollback the driver level transaction.
basicRollbackTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLAccessor
Rollback the transaction on the "data store".
BasicTypeHelperImpl - Class in org.eclipse.persistence.internal.helper
INTERNAL This class is a helper class providing type information.
BasicTypeHelperImpl() - Constructor for class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
 
BATCH - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.batch"
BATCH_FETCH_PROPERTY - Static variable in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Property used for batch fetching in non object queries.
BATCH_IN_REQUIRES_SINGLETON_PK - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
BATCH_READING_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
BATCH_READING_NOT_SUPPORTED_WITH_CALL - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
BATCH_SIZE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.batch.size"
BATCH_TYPE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.batch.type"
BATCH_WRITING - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jdbc.batch-writing" property configures the use of batch writing to optimize transactions with multiple writes.
BATCH_WRITING - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.jdbc.batch-writing"
BATCH_WRITING_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
BATCH_WRITING_SIZE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jdbc.batch-writing.size" property configures the batch size used for batch writing.
batchedMappings - Variable in class org.eclipse.persistence.queries.BatchFetchPolicy
Define the mapping to be batch fetched (from mapping settings).
batchedValueFromRow(AbstractRecord, ObjectLevelReadQuery, CacheKey) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Retrieve the value through using batch reading.
batchedValueFromRow(AbstractRecord, ObjectLevelReadQuery, CacheKey) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Possible for future development, not currently supported.
BatchFetch - Annotation Type in org.eclipse.persistence.annotations
A BatchFetch annotation can be used on any relationship mapping, (OneToOne, ManyToOne, OneToMany, ManyToMany, ElementCollection, BasicCollection, BasicMap).
batchFetchedAttributes - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Cache mapping that use batch fetching.
batchFetchPolicy - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Defines batch fetching configuration.
BatchFetchPolicy - Class in org.eclipse.persistence.queries
BatchFetchPolicy defines batch reading configuration.
BatchFetchPolicy() - Constructor for class org.eclipse.persistence.queries.BatchFetchPolicy
 
BatchFetchPolicy(BatchFetchType) - Constructor for class org.eclipse.persistence.queries.BatchFetchPolicy
 
batchFetchType - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Indicates whether the referenced object should always be batch read on read all queries, and defines the type of batch fetch to use.
BatchFetchType - Enum in org.eclipse.persistence.annotations
Enum used with the BatchFetch annotation, or "eclipselink.batch.type" query hint.
batchObjects - Variable in class org.eclipse.persistence.queries.BatchFetchPolicy
Stores temporary map of batched objects (this queries results).
batchQueries - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
When in transaction batch read objects must use query local to the unit of work.
batchReadingInRequiresSingletonPrimaryKey(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
batchReadingNotSupported(DatabaseMapping, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
batchReadingNotSupported(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
batchSize - Variable in class org.eclipse.persistence.internal.databaseaccess.DynamicSQLBatchWritingMechanism
This attribute is used to store the maximum length of all strings batched together
batchStatementExecutionFailure() - Static method in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
BatchValueHolder<T> - Class in org.eclipse.persistence.internal.indirection
BatchValueHolder is used by the mappings that use indirection when using query optimization (batch reading).
BatchValueHolder(ReadQuery, AbstractRecord, ForeignReferenceMapping, ObjectLevelReadQuery, CacheKey) - Constructor for class org.eclipse.persistence.internal.indirection.BatchValueHolder
Initialize the query-based value holder.
BatchWriting - Class in org.eclipse.persistence.config
Specify the use of batch writing to optimize transactions with multiple writes, by default batch writing is not used.
BatchWriting() - Constructor for class org.eclipse.persistence.config.BatchWriting
 
batchWritingMechanism - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allow for a custom batch writing mechanism.
BatchWritingMechanism - Class in org.eclipse.persistence.internal.databaseaccess
INTERNAL:
BatchWritingMechanism() - Constructor for class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
 
BEAN_VALIDATION_NO_OPTIMISATION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property for disabling Bean Validation optimisations.
beanManager - Variable in class org.eclipse.persistence.internal.sessions.cdi.InjectionManagerImpl
 
BeanValidationException - Exception in org.eclipse.persistence.exceptions
BeanValidationException should be used to represent any exception that happens during Bean Validation in MOXy.
BeanValidationException(String) - Constructor for exception org.eclipse.persistence.exceptions.BeanValidationException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
BeanValidationException(String, Throwable) - Constructor for exception org.eclipse.persistence.exceptions.BeanValidationException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
BeanValidationExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for BeanValidationException messages.
BeanValidationExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.BeanValidationExceptionResource
Default constructor.
BEFORE_INSERT - Static variable in interface org.eclipse.persistence.internal.sequencing.Sequencing
 
beforeCompletion() - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
INTERNAL: This method performs the logic that occurs at transaction completion time.
beforeCompletion() - Method in class org.eclipse.persistence.transaction.JTASynchronizationListener
INTERNAL: Called by the JTA transaction manager prior to the start of the transaction completion process.
beforeContainmentMarshal(Object) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
beforeContainmentMarshal(Object) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
beforeContainmentMarshal(Object) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
beforeFirst() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
Moves the cursor to the front of the result set, just before the first row
beforeFirst() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Moves the cursor to the front of the result set, just before the first row
beforeMarshal(Object) - Method in interface org.eclipse.persistence.internal.oxm.Marshaller.Listener
This event will be called before an object is marshalled.
beforeUnmarshal(Object, Object) - Method in interface org.eclipse.persistence.internal.oxm.Unmarshaller.Listener
Event that will be called before objects are unmarshalled.
beginAddingConstructorArguments(Class<?>) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Call a constructor for the given class with the results of this query.
beginAddingConstructorArguments(Class<?>, Class<?>[]) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Call a constructor for the given class with the results of this query.
beginEarlyTransaction() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Begin an early unit of work transaction.
beginEarlyTransaction() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Begin an early unit of work transaction.
beginEarlyTransaction() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
PUBLIC: Tell the unit of work to begin a transaction now.
beginEarlyTransaction() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Tell the unit of work to begin a transaction now.
beginEarlyTransaction() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Begin an early unit of work transaction.
beginEarlyTransaction() - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
 
beginEarlyTransaction() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Begin an early unit of work transaction.
beginEarlyTransaction() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Tell the unit of work to begin a transaction now.
beginExternalTransaction() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Attempts to begin an external transaction.
beginTransaction() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Begin a transaction on the database.
beginTransaction() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Begin a transaction on the database.
beginTransaction() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Begin a transaction on the database.
beginTransaction() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This is internal to the uow, transactions should not be used explicitly in a uow.
beginTransaction() - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Begin a transaction on the database.
beginTransaction() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Start a transaction on the server.
beginTransaction() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Begin a transaction on the database.
beginTransaction() - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
 
beginTransaction() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Begin a transaction on the database.
beginTransaction(DatabaseAccessor) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for jdbc drivers which do not support autocommit to explicitly begin a transaction This method is a no-op for databases which implement autocommit as expected.
beginTransaction(AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Begin a transaction on the data store.
beginTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Begin a transaction on the database.
beginTransaction(AbstractSession) - Method in interface org.eclipse.persistence.sessions.ExternalTransactionController
INTERNAL: Begin a transaction externally.
beginTransaction(AbstractSession) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Begin an external transaction.
beginTransaction_impl() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Begin an external transaction.
beginTransaction_impl() - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Begin an external transaction.
bePostfix() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Tell the operator to be postfix, i.e.
bePrefix() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Tell the operator to be pretfix, i.e.
beRepeating() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Make this a repeating argument.
between() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the BETWEEN Operator
between(byte, byte) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, between two bytes
between(char, char) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, between two chars
between(double, double) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, between two doubles
between(float, float) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, between two floats
between(int, int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, between two ints
between(long, long) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, between two longs
between(short, short) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, between two shorts
between(Object, Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receiver's value is between two other values.
between(Expression, Expression) - Method in class org.eclipse.persistence.expressions.Expression
 
Between - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
betweenOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
DB2 z/OS requires that at least one argument be a known type
betweenOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
BidirectionalPolicy - Class in org.eclipse.persistence.oxm.mappings
Purpose: Provides a means to configure bidirectional relationship maintenance for OXM mappings.
BidirectionalPolicy() - Constructor for class org.eclipse.persistence.oxm.mappings.BidirectionalPolicy
 
BIGDECIMAL - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
BIGINT_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
BIGINTEGER - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
BINARY_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
binaryCopy(File, File) - Method in class org.eclipse.persistence.tools.PackageRenamer
Do a binary copy of the file byte buffer by byte buffer.
BinaryDataCollectionMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​CONVERTER extends CoreConverter,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​MIME_TYPE_POLICY extends MimeTypePolicy,​SESSION extends CoreSession,​UNMARSHALLER extends Unmarshaller,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
binaryDataHelper - Static variable in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
BinaryDataMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​CONVERTER extends CoreConverter,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​MIME_TYPE_POLICY extends MimeTypePolicy,​SESSION extends CoreSession,​UNMARSHALLER extends Unmarshaller,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
BinaryDataUnmarshalRecord - Class in org.eclipse.persistence.internal.oxm.record
 
BinaryDataUnmarshalRecord(ObjectBuilder, UnmarshalRecord, XMLBinaryDataMappingNodeValue, BinaryDataMapping) - Constructor for class org.eclipse.persistence.internal.oxm.record.BinaryDataUnmarshalRecord
 
BinaryInteger - org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
binaryNumericPromotion(Object, Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Implements binary numeric promotion as defined in JLS.
bind(Object, Object) - Method in class org.eclipse.persistence.internal.oxm.IDResolver
Bind the object obj to the identifier id.
bind(Map<String, Object>, Object) - Method in class org.eclipse.persistence.internal.oxm.IDResolver
Bind the object obj to the composite key information specified in the id Map.
BIND_ALL_PARAMETERS_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
BIND_ALL_PARAMETERS_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
BIND_PARAMETERS - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.jdbc.bind-parameters"
bindAllParameters() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Bind all arguments to any SQL statement.
bindAllParameters() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Bind all arguments to any SQL statement.
BindCallCustomParameter - Class in org.eclipse.persistence.internal.databaseaccess
INTERNAL:
BindCallCustomParameter() - Constructor for class org.eclipse.persistence.internal.databaseaccess.BindCallCustomParameter
 
BindCallCustomParameter(Object) - Constructor for class org.eclipse.persistence.internal.databaseaccess.BindCallCustomParameter
INTERNAL: Binds the custom parameter (obj) into the passed PreparedStatement for the passed DatabaseCall.
BINDINGS_PKG_NOT_SET - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
bindParameter(Writer, Object) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Bind the parameter.
bindParameter(Writer, Object) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
Bind the parameter.
bindToCurrentTransaction(UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Associate the given unit of work and EclipseLink session with the active external transaction.
Birth - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
BIT_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
BLOB - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
BLOB_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
BOOLEAN - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
BOOLEAN - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
BOOLEAN_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
BOOLEAN_STRING_FALSE - Static variable in class org.eclipse.persistence.oxm.XMLConstants
 
BOOLEAN_STRING_TRUE - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
BOOLEAN_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
BRACKET_END - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
BroadcastRemoteConnection - Class in org.eclipse.persistence.internal.sessions.coordination.broadcast
Purpose: Base class extending RemoteConnection for broadcasting RCM protocols: JMS and Oc4jJGroups.
BroadcastRemoteConnection(RemoteCommandManager) - Constructor for class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
 
BroadcastTransportManager - Class in org.eclipse.persistence.sessions.coordination.broadcast
Purpose: Base class transport manager for broadcasting RCM protocols: JMS and Oc4jJGroups.
BroadcastTransportManager() - Constructor for class org.eclipse.persistence.sessions.coordination.broadcast.BroadcastTransportManager
 
BroadcastTransportManager(RemoteCommandManager) - Constructor for class org.eclipse.persistence.sessions.coordination.broadcast.BroadcastTransportManager
 
broker - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Support being owned by a session broker.
bufferContainsNullChar(byte[], int) - Method in class org.eclipse.persistence.tools.PackageRenamer
 
Buffered - Static variable in class org.eclipse.persistence.config.BatchWriting
 
BUILD_FIELD_VALUE_METHOD - Static variable in interface org.eclipse.persistence.core.mappings.transformers.CoreFieldTransformer
Method name should be same as the value of this field.
BUILD_OBJECT_IS_COMPLETE_TRUE - Static variable in class org.eclipse.persistence.internal.helper.type.IsBuildObjectCompleteOutcome
Algorithm can return null when it detects that the object is fully built ant the thread should be allowed to progresses.
buildAbstractCompositeCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildAbstractCompositeDirectCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildAbstractCompositeObjectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildAbstractDirectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildAbstractDirectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildAbstractDirectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildAbstractNullPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildAbstractTransformationMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildAbstractTransformationMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildAccessor() - Method in class org.eclipse.persistence.eis.EISLogin
Build and return the EIS accessorr.
buildAccessor() - Method in class org.eclipse.persistence.oxm.XMLLogin
INTERNAL: Returns the appropriate accessor
buildAccessor() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
INTERNAL: Build and return an appropriate Accessor.
buildAccessor() - Method in interface org.eclipse.persistence.sessions.Login
INTERNAL: Build the correct datasource Accessor for this login instance.
buildAddedElementFromChangeSet(Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Build and return a new element based on the change set.
buildAddedElementFromChangeSet(Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Build and return a new element based on the change set.
buildAddedElementFromChangeSet(Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Build and return a new element based on the change set.
buildAddedElementFromChangeSet(Object, MergeManager, AbstractSession) - Method in interface org.eclipse.persistence.mappings.structures.ArrayCollectionMapping
Build and return a newly-added element based on the change set.
buildAddFieldWriter(AbstractSession, FieldDefinition, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Return the alter table statement to add a field to the table.
buildAggregateCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildAggregateCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildAggregateDeleteQuery(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateMapping
Make a copy of the sourceQuery for the attribute.
buildAggregateFromRow(AbstractRecord, Object, CacheKey, JoinedAttributeManager, ObjectBuildingQuery, boolean, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Build and return an aggregate object from the specified row.
buildAggregateMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildAggregateMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildAggregateModifyQuery(ObjectLevelModifyQuery, ObjectLevelModifyQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateMapping
Initialize the aggregate query with the settings from the source query.
buildAggregateObjectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildAggregateWriteQuery(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateMapping
Make a copy of the sourceQuery for the attribute.
buildAllFieldsLockingPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildAllNonPrimaryKeyFields() - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Returns the fields that should be compared in the where clause.
buildAllTypesToAClassVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildAlterIncrementWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.SequenceObjectDefinition
INTERNAL: Return the SQL required to alter INCREMENT BY
buildAndCheckDestinationFile(String) - Method in class org.eclipse.persistence.tools.PackageRenamer
INTERNAL Creates a destination directory File object under the path passed, verifying correctness.
buildAndCheckExistingDirFile(String) - Method in class org.eclipse.persistence.tools.PackageRenamer
 
buildAndCheckLogWriter(String) - Method in class org.eclipse.persistence.tools.PackageRenamer
 
buildAndExecuteCall(DatabaseCall, AbstractSession) - Method in class org.eclipse.persistence.internal.helper.LOBValueWriter
 
buildAndExecuteSelectCalls(AbstractSession) - Method in class org.eclipse.persistence.internal.helper.LOBValueWriter
Build and execute the deferred select calls.
buildAndRegisterObject(AbstractRecord) - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: builds and registers an object from a row for cursors.
buildAppendNewElementsOrderingPolicyConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
buildAppendNewElementsOrderingPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildArgumentFields() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Build the list of arguments fields from the argument names and types.
buildArrayMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildArrayObjectFromArray(Object) - Static method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Build array of objects for Array data type.
buildArrayObjectFromStruct(Object) - Static method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Build array of objects for Struct data type.
buildAssociationDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildAttribute(DirectMapping, String) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Build and return an Attribute for a given XMLDirectMapping.
buildAttribute(XPathFragment, String) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Build and return an Attribute for a given XPathFragment.
buildAttributeChangeTrackingPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildAttributeList(Element) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
buildAttributeNode(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.SAXFragmentBuilder
 
buildAttributesIntoObject(Object, CacheKey, AbstractRecord, ObjectBuildingQuery, JoinedAttributeManager, FetchGroup, boolean, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Each mapping is recursed to assign values from the Record to the attributes in the domain object.
buildAttributesIntoObject(Object, CacheKey, AbstractRecord, ObjectBuildingQuery, JoinedAttributeManager, FetchGroup, boolean, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
Override method in superclass in order to set the session on the record.
buildAttributesIntoObjectSOP(Object, CacheKey, AbstractRecord, ObjectBuildingQuery, JoinedAttributeManager, FetchGroup, boolean, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Each mapping is recursed to assign values from the Record to the attributes in the domain object.
buildAttributesIntoShallowObject(Object, AbstractRecord, ObjectBuildingQuery) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: For reading through the write connection when in transaction, We need a partially populated original, so that we can build a clone using the copy policy, even though we can't put this original in the shared cache yet; just build a shallow original (i.e.
buildAttributesIntoWorkingCopyClone(Object, CacheKey, ObjectBuildingQuery, JoinedAttributeManager, AbstractRecord, UnitOfWorkImpl, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: For reading through the write connection when in transaction, populate the clone directly from the database row.
buildAttributesIntoWorkingCopyCloneSOP(Object, CacheKey, ObjectBuildingQuery, JoinedAttributeManager, AbstractRecord, UnitOfWorkImpl, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
For reading through the write connection when in transaction, populate the clone directly from the database row.
buildAttributeValue(DataRecord, Object, Session) - Method in interface org.eclipse.persistence.mappings.transformers.AttributeTransformer
 
buildAttributeValue(DataRecord, Object, Session) - Method in class org.eclipse.persistence.mappings.transformers.AttributeTransformerAdapter
 
buildAttributeValue(DataRecord, Object, Session) - Method in class org.eclipse.persistence.mappings.transformers.MethodBasedAttributeTransformer
INTERNAL: Build the attribute value by invoking the user's transformation method.
buildBackupClone(Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Clone the attribute from the clone and assign it to the backup.
buildBackupClone(Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Clone the attribute from the clone and assign it to the backup.
buildBackupClone(Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Clone the attribute from the clone and assign it to the backup.
buildBackupClone(Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Clone the attribute from the clone and assign it to the backup.
buildBackupClone(Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Clone the attribute from the clone and assign it to the backup.
buildBackupClone(Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Clone the attribute from the clone and assign it to the backup.
buildBackupClone(Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL: Clone the attribute from the clone and assign it to the backup.
buildBackupClone(Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL: Clone the attribute from the clone and assign it to the backup.
buildBackupClone(Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL: Clone the attribute from the clone and assign it to the backup.
buildBackupClone(Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
INTERNAL: Clone the attribute from the clone and assign it to the backup.
buildBackupClone(Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL: Clone the attribute from the clone and assign it to the backup.
buildBackupClone(Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
INTERNAL: Clone the attribute from the clone and assign it to the backup.
buildBackupClone(Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
buildBackupClone(Object, ObjectBuilder, UnitOfWorkImpl) - Method in class org.eclipse.persistence.descriptors.changetracking.AttributeChangeTrackingPolicy
INTERNAL: Only build backup clone
buildBackupClone(Object, ObjectBuilder, UnitOfWorkImpl) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: Build back up clone.
buildBackupClone(Object, ObjectBuilder, UnitOfWorkImpl) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: Build back up clone.
buildBackupClone(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Returns the backup clone of the specified object.
buildBackupClone(IndirectContainer) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return a backup clone of a clone container that has not been read from the database yet.
buildBackupCloneFor(Object) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkQueryValueHolder
Backup the clone attribute value.
buildBackupCloneFor(Object) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkTransformerValueHolder
Backup the clone attribute value.
buildBackupCloneFor(Object) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
Backup the clone attribute value.
buildBackupCloneForPartObject(Object, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Used during building the backup shallow copy to copy the vector without re-registering the target objects.
buildBackupCloneForPartObject(Object, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Used during building the backup shallow copy to copy the vector without re-registering the target objects.
buildBackupCloneForPartObject(Object, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Require for cloning, the part must be cloned.
buildBackupCloneForPartObject(Object, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Used during building the backup shallow copy to copy the target object without re-registering it.
buildBackupCloneForPartObject(Object, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Used during building the backup shallow copy to copy the vector without re-registering the target objects.
buildBackupCloneForPartObject(Object, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Used during building the backup shallow copy to copy the vector without re-registering the target objects.
buildBackupClonePart(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Build and return a backup clone of the attribute.
buildBackupClonePart(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
Build and return a backup clone of the attribute.
buildBase64StringFromBytes(byte[]) - Method in interface org.eclipse.persistence.internal.oxm.ConversionManager
 
buildBase64StringFromBytes(byte[]) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
buildBase64StringFromObjectBytes(Byte[]) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
buildBaseSelectionCriteria(boolean, Map) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Create the appropriate where clause.
buildBaseSelectionCriteria(boolean, Map, boolean) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Create the appropriate where clause.
buildBaseSelectStatement(boolean, Map) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return the appropriate select statement containing the fields in the table.
buildBaseSelectStatement(boolean, Map, boolean) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return the appropriate select statement containing the fields in the table.
buildBasicIndirectionPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildBatchCriteria(ExpressionBuilder, Expression) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Return the selection criteria used to IN batch fetching.
buildBatchCriteria(ExpressionBuilder, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Return the selection criteria used to IN batch fetching.
buildBatchCriteria(ExpressionBuilder, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return the selection criteria used to IN batch fetching.
buildBatchCriteria(ExpressionBuilder, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return the selection criteria used to IN batch fetching.
buildBatchCriteria(ExpressionBuilder, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Return the selection criteria used to IN batch fetching.
buildBatchCriteria(ExpressionBuilder, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Return the selection criteria used to IN batch fetching.
buildBatchCriteria(ExpressionBuilder, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return the selection criteria used to IN batch fetching.
buildBatchCriteria(ExpressionBuilder, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Return the selection criteria used to IN batch fetching.
buildBatchCriteriaByPK(ExpressionBuilder, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return the selection criteria used to IN batch fetching.
buildBatchCriteriaForComplexId(ExpressionBuilder, List<Expression>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Return the selection criteria used to IN batch fetching.
buildBeginBlock(StringBuilder, List<PLSQLargument>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
INTERNAL Generate portion of the Anonymous PL/SQL block that assigns fields at the beginning of the BEGIN block (before invoking the target procedure).
buildBeginBlock(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
buildBeginBlock(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
buildBeginBlock(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
buildBeginBlock(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
 
buildBeginBlock(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
buildBeginBlock(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
INTERNAL: Append any code or translation required for the type.
buildBeginBlock(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCursor
 
buildBeginBlock(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
buildBuilderString(String, NonreflectiveMethodDefinition, int, String) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
buildBytesFromHexString(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Convert the HEX string to a byte array.
buildCacheCoordinationMergeChangeSet(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Return a new UnitOfWorkChangeSet that only includes data require for the remote merge, for cache coordination.
buildCacheInvalidationPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildCall(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
Return SQL call for the statement, through generating the SQL string.
buildCall(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteStatement
Append the string containing the SQL insert string for the given table.
buildCall(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
Append the string containing the SQL insert string for the given table.
buildCall(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.SQLModifyStatement
 
buildCall(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Print the SQL representation of the statement on a stream.
buildCall(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.SQLStatement
Return SQL call for the statement, through generating the SQL string.
buildCall(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
Append the string containing the SQL insert string for the given table.
buildCall(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
Append the string containing the SQL insert string for the given table.
buildCall(AbstractSession, DatabaseQuery) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Build the call, setting the query first, this is required in some cases when the query info is required to print the SQL.
buildCallDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildCallDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildCallFromStatement(SQLStatement, DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return a call built from a statement.
buildCallFromStatement(SQLStatement, DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: Override this method to throw an exception.
buildCallFromStatement(SQLStatement, DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.eis.EISPlatform
INTERNAL: Override this method to throw an exception by default.
buildCallWithoutReturning(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.SQLInsertStatement
Append the string containing the SQL insert string for the given table.
buildCallWithoutReturning(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.SQLModifyStatement
 
buildCallWithoutReturning(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateStatement
Append the string containing the SQL insert string for the given table.
buildCallWithReturning(SQLCall, Vector<DatabaseField>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL Returns null unless the platform supports call with returning
buildCallWithReturning(SQLCall, Vector<DatabaseField>) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Returns null unless the platform supports call with returning
buildCallWithReturning(SQLCall, Vector<DatabaseField>) - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Uses the returning clause on Postgres.
buildCascadeQuery(MergeManager) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL Return true if the refresh should refresh on this mapping or not.
buildChangedFieldsLockingPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildChangePolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildChangeRecord(Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Directly build a change record without comparison
buildChangeRecord(Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Directly build a change record without comparison
buildChangeRecord(Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Directly build a change record without comparison
buildChangeRecord(Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Directly build a change record without comparison
buildChangeRecord(Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Directly build a change record without comparison
buildChangeSet(Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Build and return a change set for the specified element.
buildChangeSet(Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Build and return a change set for the specified element.
buildChangeSet(Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Build and return a change set for the specified element.
buildChangeSet(Object, ObjectChangeSet, AbstractSession) - Method in interface org.eclipse.persistence.mappings.structures.ArrayCollectionMapping
Build and return a change set for the specified element.
buildChangeSetForNewObjectInCollection(Object, ClassDescriptor, UnitOfWorkChangeSet, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
buildChangeSetForNewObjectInCollection(Object, ClassDescriptor, UnitOfWorkChangeSet, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Ensure the new key is set for the change set for a new map object
buildClassDescriptorDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildClassDescriptorDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildClassDescriptorDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildClassIndicatorSelectStatement(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return a select statement that will be used to query the class indicators required to query.
buildClassTypes() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return the mapping of class types to database types for the schema framework.
buildClassTypes() - Method in class org.eclipse.persistence.platform.database.AccessPlatform
 
buildClassTypes() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
 
buildClassTypes() - Method in class org.eclipse.persistence.platform.database.PointBasePlatform
 
buildClassTypes() - Method in class org.eclipse.persistence.platform.database.PostgreSQL10Platform
Build the mapping of database types to class types for the schema framework.
buildClassTypes() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
 
buildClassTypes() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Return the mapping of database types to class types for the schema framework.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
buildClone(Object, Session) - Method in class org.eclipse.persistence.descriptors.copying.AbstractCopyPolicy
 
buildClone(Object, Session) - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Clone through calling the clone method.
buildClone(Object, Session) - Method in interface org.eclipse.persistence.descriptors.copying.CopyPolicy
Return a shallow clone of the object for usage with object copying, or unit of work backup cloning.
buildClone(Object, Session) - Method in class org.eclipse.persistence.descriptors.copying.InstantiationCopyPolicy
 
buildClone(Object, Session) - Method in class org.eclipse.persistence.descriptors.copying.PersistenceEntityCopyPolicy
 
buildCloneCopyPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildCloneFor(Object) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkQueryValueHolder
Clone the original attribute value.
buildCloneFor(Object) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkTransformerValueHolder
Clone the original attribute value.
buildCloneFor(Object) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
Clone the original attribute value.
buildCloneForKey(Object, Object, CacheKey, Integer, AbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
Build a clone for the key of a Map represented by this container policy if necessary.
buildCloneForKey(Object, Object, CacheKey, Integer, AbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
Build a clone for the key of a Map represented by this container policy.
buildCloneForPartObject(Object, Object, CacheKey, Object, AbstractSession, Integer, boolean, boolean) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Require for cloning, the part must be cloned.
buildCloneForPartObject(Object, Object, CacheKey, Object, AbstractSession, Integer, boolean, boolean) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Require for cloning, the part must be cloned.
buildCloneForPartObject(Object, Object, CacheKey, Object, AbstractSession, Integer, boolean, boolean) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Require for cloning, the part must be cloned.
buildCloneForPartObject(Object, Object, CacheKey, Object, AbstractSession, Integer, boolean, boolean) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Require for cloning, the part must be cloned.
buildCloneForPartObject(Object, Object, CacheKey, Object, AbstractSession, Integer, boolean, boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Require for cloning, the part must be cloned.
buildCloneForPartObject(Object, Object, CacheKey, Object, AbstractSession, Integer, boolean, boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Require for cloning, the part must be cloned.
buildCloneForPartObject(Object, Object, CacheKey, Object, AbstractSession, Integer, boolean, boolean) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Require for cloning, the part must be cloned.
buildCloneForValue(Object, Object, CacheKey, CollectionMapping, Integer, AbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
Build a clone for the value in a mapping.
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: A combination of readFromRowIntoObject and buildClone.
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: A combination of readFromRowIntoObject and buildClone.
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A combination of readFromRowIntoObject and buildClone.
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: A combination of readFromRowIntoObject and buildClone.
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Extract value from the row and set the attribute to this value in the working copy clone.
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Extract value from the row and set the attribute to this value in the working copy clone.
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Extract value from the row and set the attribute to this value in the working copy clone.
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL: Extract value from the row and set the attribute to this value in the working copy clone.
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
buildCloneFromRow(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
buildClonePart(Object, Object, CacheKey, Integer, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: * Build and return a clone of the attribute.
buildClonePart(Object, Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Build and return a clone of the attribute.
buildClonePart(Object, Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
Build and return a clone of the attribute.
buildClonePart(Object, CacheKey, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
Build and return a clone of the specified attribute value.
buildCloneValue(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Clone the attribute from the original and assign it to the clone.
buildCloneValue(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Clone the actual value represented by this mapping.
buildCloneValue(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.xdb.DirectToXMLTypeMapping
INTERNAL: Clone the DOM Document if required.
buildCMPPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildCollectionContainerPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildCollectionEntry(Object, ObjectChangeSet) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return an object representing an entry in the collection represented by this container policy This method will be overridden to allow MapContainerPolicy to return a construct that contains the key and the value
buildCollectionEntry(Object, ObjectChangeSet) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return an object representing an entry in the collection represented by this container policy This method will returns an Association containing the key and the value for a Map
buildCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildColsAndValuesBindingsFromMappings(StringBuilder, Collection<DatabaseMapping>, Collection<DatabaseField>, int, String, String) - Static method in class org.eclipse.persistence.internal.descriptors.DescriptorHelper
Append list of column to value bindings from descriptor class to provided StringBuilder.
buildColsFromMappings(StringBuilder, Collection<DatabaseMapping>, String) - Static method in class org.eclipse.persistence.internal.descriptors.DescriptorHelper
Append list of columns from descriptor class to provided StringBuilder.
buildCommandsConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildCompatible(PLSQLargument) - Method in enum org.eclipse.persistence.internal.helper.DatabaseType.DatabaseTypeHelper
 
buildComplexType(boolean, Descriptor, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties, List<Descriptor>) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Create and return a ComplexType for a given XMLDescriptor.
buildCompositeCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildCompositeObject(ClassDescriptor, AbstractRecord, ObjectBuildingQuery, CacheKey, JoinedAttributeManager, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeCollectionMapping
 
buildCompositeObject(ClassDescriptor, AbstractRecord, ObjectBuildingQuery, CacheKey, JoinedAttributeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
 
buildCompositeObject(ClassDescriptor, AbstractRecord, ObjectBuildingQuery, CacheKey, JoinedAttributeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ObjectArrayMapping
 
buildCompositeObject(ClassDescriptor, AbstractRecord, ObjectBuildingQuery, CacheKey, JoinedAttributeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
buildCompositeObject(ObjectBuilder, AbstractRecord, ObjectBuildingQuery, CacheKey, JoinedAttributeManager, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeObjectMapping
 
buildCompositeObject(ObjectBuilder, AbstractRecord, ObjectBuildingQuery, CacheKey, JoinedAttributeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
 
buildCompositeObject(ObjectBuilder, AbstractRecord, ObjectBuildingQuery, CacheKey, JoinedAttributeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.StructureMapping
 
buildCompositeObject(ObjectBuilder, AbstractRecord, ObjectBuildingQuery, CacheKey, JoinedAttributeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
buildCompositeObjectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildCompositeRow(Object, AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
buildCompositeRow(Object, AbstractSession, AbstractRecord, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeCollectionMapping
 
buildCompositeRow(Object, AbstractSession, AbstractRecord, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeObjectMapping
 
buildCompositeRow(Object, AbstractSession, AbstractRecord, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
 
buildCompositeRow(Object, AbstractSession, AbstractRecord, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
 
buildCompositeRow(Object, AbstractSession, AbstractRecord, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.structures.ObjectArrayMapping
 
buildCompositeRow(Object, AbstractSession, AbstractRecord, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.structures.StructureMapping
 
buildCompositeRow(Object, AbstractSession, AbstractRecord, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
buildCompositeRow(Object, AbstractSession, AbstractRecord, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
buildCompositeRow(Object, AbstractSession, XMLDescriptor, AbstractRecord, DatabaseField, Object, boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
buildCompositeRow(Object, AbstractSession, XMLDescriptor, AbstractRecord, DatabaseField, Object, boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
buildCompositeRow(XMLField, Object, AbstractSession, AbstractRecord, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
buildCompositeRow(XMLField, Object, AbstractSession, AbstractRecord, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
buildCompositeRowForDescriptor(ClassDescriptor, Object, AbstractSession, XMLRecord, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
buildCompositeRowForDescriptor(ClassDescriptor, Object, AbstractSession, XMLRecord, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
buildConcreteSelectStatement() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return the appropriate select statement containing the fields in the table.
buildConnection() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: Create a new connection, accessors are used as connections.
buildConnectionPolicyConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildConnectionPoolConfig(ConnectionPoolConfig, ServerSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Build a connection pool from the config to store on the server session.
buildConnectionPoolConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildConnectLog(AbstractSession) - Method in class org.eclipse.persistence.eis.EISAccessor
If logging is turned on and the CCI implementation supports meta data then display connection info.
buildConnectLog(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
If logging is turned on and the JDBC implementation supports meta data then display connection info.
buildConnectLog(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Build a log string of any driver metadata that can be obtained.
buildConnectLog(AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLAccessor
Log any driver level connection meta-data if available.
buildConstantExpressionDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildConstraintCreationWriter(AbstractSession, ForeignKeyConstraint, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Return the alter table statement to add the constraints.
buildConstraintDeletionWriter(AbstractSession, ForeignKeyConstraint, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Return the alter table statement to drop the constraints.
buildConstraints(SchemaManager, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Convert any field constraint to constraint objects.
buildConstructor() - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
buildConstructor() - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
 
buildContainer(ValueHolderInterface<?>) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
Build a container with the initialized constructor.
buildContainerClone(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Performs a first level clone of the attribute.
buildContainerClone(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Performs a first level clone of the attribute.
buildContainerFromArray(Array, ObjectRelationalDatabaseField, AbstractSession) - Static method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Build and return the nested rows from the specified field value.
buildContainerFromVector(Vector, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ArrayListContainerPolicy
INTERNAL: Return an ArrayList from the Vector.
buildContainerFromVector(Vector, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
INTERNAL: Return a container populated with the contents of the specified Vector.
buildContainerFromVector(Vector, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return a container populated with the contents of the specified Vector.
buildContainerFromVector(Vector, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.IndirectListContainerPolicy
INTERNAL: Just return the Vector.
buildContainerFromVector(Vector, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Return a container populated with the contents of the specified Vector.
buildContainerFromVector(Vector, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.VectorContainerPolicy
INTERNAL: Just return the Vector.
buildContainerIndirectionPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildContainerPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildContainerPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildConverterDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildConverterDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildCopy(Object, Object, CopyGroup) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Copy of the attribute of the object.
buildCopy(Object, Object, CopyGroup) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Copy of the attribute of the object.
buildCopy(Object, Object, CopyGroup) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Copy of the attribute of the object.
buildCopy(Object, Object, CopyGroup) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Copy of the attribute of the object.
buildCopy(Object, Object, CopyGroup) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Copy of the attribute of the object.
buildCopy(Object, Object, CopyGroup) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Copy of the attribute of the object.
buildCopy(Object, Object, CopyGroup) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Copy of the attribute of the object.
buildCopy(Object, Object, CopyGroup) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Copy of the attribute of the object.
buildCopyOfAttributeValue(Object, CopyGroup) - Method in class org.eclipse.persistence.mappings.AggregateMapping
Copy of the attribute of the object.
buildCopyOfAttributeValue(Object, CopyGroup) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
Copy of the attribute of the object.
buildCopyPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildCountDistinctExpression(List, ExpressionBuilder) - Method in class org.eclipse.persistence.queries.CursoredStream
INTERNAL: Must build the count on the primary key fields, not * as * is not allowed if there was a distinct.
buildCreateIndex(String, String, String...) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Don't override this method.
buildCreateIndex(String, String, String, boolean, String...) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Override this method with the platform's CREATE INDEX statement.
buildCreateIndex(String, String, String, boolean, String...) - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Return the CREATE INDEX string for this platform.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Returns the writer used for creation of this object.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.IndexDefinition
INTERNAL: Return the create type statement.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.NestedTableDefinition
INTERNAL: Return the DDL to create the varray.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.PackageDefinition
INTERNAL: Return the create table statement.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.SequenceObjectDefinition
INTERNAL: Return the SQL required to create the Oracle sequence object.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.StoredFunctionDefinition
INTERNAL: Return the create statement.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
INTERNAL: Return the create table statement.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Return the create table statement.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
INTERNAL: Return the SQL required to insert the sequence row into the sequence table.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TypeDefinition
INTERNAL: Return the create type statement.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TypeTableDefinition
INTERNAL: Return the create table statement.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.UnaryTableSequenceDefinition
INTERNAL: Return the SQL required to create the unary sequence table.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
INTERNAL: Return the DDL to create the VARRAY.
buildCreationWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.ViewDefinition
INTERNAL: Return the DDL to create the view.
buildCursoredStreamPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildCustomServerPlatformConfig(CustomServerPlatformConfig, DatabaseSessionImpl) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
buildCustomServerPlatformConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildDailyCacheInvalidationPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDatabaseFieldDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildDatabaseFieldDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildDatabaseFieldDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDatabaseLoginConfig(DatabaseLoginConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Build a DatabaseLogin for the given Session Wrapped by the getLogin() call, therefore, config can't be null at this point.
buildDatabaseLoginConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
buildDatabaseLoginConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildDatabaseLoginDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildDatabaseLoginDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDatabaseMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildDatabaseMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDatabaseQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDatabaseSchemaCreationWriter(AbstractSession, Writer, Set<String>) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Build the create schema DDL.
buildDatabaseSchemaDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Build the drop schema DDL.
buildDatabaseSessionConfig(DatabaseSessionConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Wrapped by the getSession() call, therefore, config can't be null at this point.
buildDatabaseSessionConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildDatabaseTableDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDatabaseTypeWrapperDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildDataModifyQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDataReadQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDatasourceLoginDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDataTypesConvertedFromAClass() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildDataTypesConvertedToAClass() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildDateTimeVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildDeclareBlock(StringBuilder, List<PLSQLargument>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
INTERNAL Generate portion of the Anonymous PL/SQL block that declares the temporary variables in the DECLARE section.
buildDefaultConstructor() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Build and return the default (zero-argument) constructor for the descriptor class.
buildDefaultConstructorFor(Class<?>) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Build and return the default (zero-argument) constructor for the specified class.
buildDefaultPolicy() - Static method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the appropriate container policy for the default container class.
buildDefaultQueryBuilder() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL Build the JPQL builder based on session properties.
buildDefaultSelectionCriteriaAndAddFieldsToQuery() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
The selection criteria are created with target foreign keys and source "primary" keys.
buildDefaultSequenceConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildDefaultSequenceDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDefaultSessionLogConfig(DefaultSessionLogConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Wrapped by the getSessionLog() call, therefore, config can't be null at this point.
buildDefaultSessionLogConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildDeferredChangeDetectionPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDelegate() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Return the freshly-built delegate.
buildDelegate() - Method in class org.eclipse.persistence.indirection.IndirectMap
Return the freshly-built delegate.
buildDelegate() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Return the freshly-built delegate.
buildDeleteAllQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDeleteAllStatement(DatabaseTable, Expression, SQLCall, SQLSelectStatement, SQLCall, SQLSelectStatement, Collection) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return the appropriate delete statement Passing of a call/ statement pair is used because the same pair may be used several times.
buildDeleteAllStatementForMapping(SQLCall, SQLSelectStatement, Vector, Vector) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Create SQLDeleteAllStatements for mappings that may be responsible for references to the objects to be deleted in the tables NOT mapped to any class: ManyToManyMapping and DirectCollectionMapping NOTE: A similar pattern also used in method buildDeleteAllStatementsForMappingsWithTempTable(): if you are updating this method consider applying a similar update to that method as well.
buildDeleteAllStatementsForMappings(SQLCall, SQLSelectStatement, boolean) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
NOTE: A similar pattern also used in method buildDeleteAllStatementsForMappingsWithTempTable: if you are updating this method consider applying a similar update to that method as well.
buildDeleteAllStatementsForMappingsWithTempTable(ClassDescriptor, DatabaseTable, boolean) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Build delete statements with temporary table for ManyToMany and DirectCollection mappings.
buildDeleteExpression(DatabaseTable, Expression, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.ChangedFieldsLockingPolicy
INTERNAL: When given an expression, this method will return a new expression with the optimistic locking values included.
buildDeleteExpression(DatabaseTable, Expression, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: When given an expression, this method will return a new expression with the optimistic locking values included.
buildDeleteExpression(DatabaseTable, Expression, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: When given an expression, this method will return a new expression with the optimistic locking values included.
buildDeleteExpression(DatabaseTable, Expression, AbstractRecord) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: When given an expression, this method will return a new expression with the optimistic locking values included.
buildDeleteExpression(DatabaseTable, AbstractRecord, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build and return the expression to use as the where clause to delete an object.
buildDeleteObjectQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDeleteStatement(DatabaseTable) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return the appropriate delete statement
buildDeleteStatementForDeleteAllQuery(DatabaseTable) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Used by DeleteAllQuery to create DeleteStatement in a simple case when selectionCriteria==null.
buildDeleteStatementForDeleteAllQuery(DatabaseTable, Expression) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Used by DeleteAllQuery to create DeleteStatement in a simple case when selectionCriteria==null.
buildDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Returns the writer used for deletion of this object.
buildDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.IndexDefinition
INTERNAL: Return the drop type statement.
buildDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.NestedTableDefinition
INTERNAL: Return the DDL to drop the varray.
buildDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.PackageDefinition
INTERNAL: Return the drop table statement.
buildDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.SequenceObjectDefinition
INTERNAL: Return the SQL required to drop the Oracle sequence object.
buildDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.StoredFunctionDefinition
INTERNAL: Return the drop statement.
buildDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
INTERNAL: Return the drop table statement.
buildDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Return the drop table statement.
buildDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
INTERNAL: Return the SQL to delete the row from the sequence table.
buildDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TypeDefinition
INTERNAL: Return the drop type statement.
buildDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.UnaryTableSequenceDefinition
INTERNAL: Return the SQL to delete the unary sequence table.
buildDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
INTERNAL: Return the DDL to drop the varray.
buildDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.ViewDefinition
INTERNAL: Return the DDL to drop the view.
buildDescriptorLevelDocumentPreservationPolicyConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
buildDescriptorLevelDocumentPreservationPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildDescriptorMethod(ClassDescriptor) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
buildDescriptors() - Method in class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
buildDescriptors() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildDescriptors() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
buildDescriptors() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildDescriptors() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDescriptors() - Method in class org.eclipse.persistence.internal.sessions.factories.OXMObjectPersistenceRuntimeXMLProject
 
buildDirectCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildDirectCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDirectCollectionTableDefinition(DirectCollectionMapping, ClassDescriptor) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Build direct collection table definitions in a EclipseLink descriptor
buildDirectMapContainerPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDirectMapMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDirectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDirectQueryKeyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDirectReadQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDirectToFieldMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDirectValuesFromFieldValue(Object) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Extract the direct values from the specified field value.
buildDirectValuesFromFieldValue(Object) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: Extract the direct values from the specified field value.
buildDirectValuesFromFieldValue(Object) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Extract the direct values from the specified field value.
buildDirectValuesFromFieldValue(Object) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Extract the direct values from the specified field value.
buildDiscoveryConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildDocumentPreservationPolicyConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
buildDocumentPreservationPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildDoesExistQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildDropIndex(String, String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Don't override this method.
buildDropIndex(String, String, String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Override this method with the platform's DROP INDEX statement.
buildDropIndex(String, String, String) - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Return the DROP INDEX string for this platform.
buildEISCompositeCollectionMappingDescriptor() - Method in class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
buildEISCompositeDirectCollectionMappingDescriptor() - Method in class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
buildEISCompositeObjectMappingDescriptor() - Method in class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
buildEISDescriptorDescriptor() - Method in class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
buildEISDirectMappingDescriptor() - Method in class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
buildEISLoginConfig(EISLoginConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Wrapped by the getLogin() call, therefore, config can't be null at this point.
buildEISLoginConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildEISLoginDescriptor() - Method in class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
buildEISOneToManyMappingDescriptor() - Method in class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
buildEISOneToOneMappingDescriptor() - Method in class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
buildEISTransformationMappingDescriptor() - Method in class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
buildElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Build and return an Element based on a given name, minOccurs and maxOccurs.
buildElement(Descriptor, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties, List<Descriptor>, boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Create and return an Element for a given XMLDescriptor.
buildElement(XPathFragment, String, String, String) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Build and return an Element for a given XPathFragment.
buildElementBackupClone(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Clone the aggregate collection, if necessary.
buildElementClone(Object, Object, CacheKey, Integer, AbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Clone the aggregate collection, if necessary.
buildElementClone(Object, Object, CacheKey, Integer, AbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Build a clone of the given element in a unitOfWork
buildElementClone(Object, Object, CacheKey, Integer, AbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Clone the element, if necessary.
buildElementClone(Object, Object, CacheKey, Integer, AbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Clone the element, if necessary.
buildElementClone(Object, Object, CacheKey, Integer, AbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
Build a clone of the given element in a unitOfWork.
buildElementClone(Object, Object, CacheKey, Integer, AbstractSession, boolean, boolean) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
Build a clone of the given element in a unitOfWork
buildElementClone(Object, Object, CacheKey, Integer, AbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
Build a clone of the given element in a unitOfWork.
buildElementFromChangeSet(Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
Build and return a new element based on the change set.
buildElementFromChangeSet(Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
Build and return a new element based on the change set.
buildElementFromChangeSet(Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
Build and return a new element based on the change set.
buildElementFromElement(Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Build and return a new element based on the specified element.
buildElementFromElement(Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Build and return a new element based on the specified element.
buildElementFromElement(Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Build and return a new element based on the specified element.
buildElementFromElement(Object, MergeManager, AbstractSession) - Method in interface org.eclipse.persistence.mappings.structures.ArrayCollectionMapping
Build and return a new element based on the specified element.
buildElementUnitOfWorkClone(Object, Object, Integer, UnitOfWorkImpl, boolean, boolean) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Clone the element, if necessary.
builder - Variable in class org.eclipse.persistence.internal.expressions.BaseExpression
PERF: Used to cache the builder.
builder - Variable in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
builder - Variable in class org.eclipse.persistence.internal.expressions.SQLStatement
 
builder - Variable in class org.eclipse.persistence.oxm.record.WriterRecord
 
builderString - Variable in class org.eclipse.persistence.internal.expressions.ExpressionJavaPrinter
 
buildEventManagerDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildExpression() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Returns an expression that will be used for both the update and delete where clause
buildExpression(Object, QueryByExamplePolicy, Expression, Map, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: In case Query By Example is used, this method builds and returns an expression that corresponds to a single attribute and it's value.
buildExpression(Object, QueryByExamplePolicy, Expression, Map, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: In case Query By Example is used, this method builds and returns an expression that corresponds to a single attribute and it's value.
buildExpression(Object, QueryByExamplePolicy, Expression, Map, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: In case Query By Example is used, this method generates an expression from a attribute value pair.
buildExpression(Object, QueryByExamplePolicy, Expression, Map, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: In case Query By Example is used, this method generates an expression from a attribute value pair.
buildExpression(Object, QueryByExamplePolicy, Expression, Map, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: In case Query By Example is used, this method builds and returns an expression that corresponds to a single attribue and it's value.
buildExpression(Object, QueryByExamplePolicy, Expression, Map, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: In case Query By Example is used, this method builds and returns an expression that corresponds to a single attribute and it's value.
buildExpression(Object, QueryByExamplePolicy, Expression, Map, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: In case Query By Example is used, this method builds and returns an expression that corresponds to a single attribute and it's value.
buildExpression(Object, QueryByExamplePolicy, Expression, Map, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: In case Query By Example is used, this method builds and returns an expression that corresponds to a single attribute and it's value.
buildExpression(Object, QueryByExamplePolicy, Expression, Map, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: In case Query By Example is used, this method builds and returns an expression that corresponds to a single attribute and it's value for a directToField mapping.
buildExpression(Object, QueryByExamplePolicy, Expression, Map, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: In case Query By Example is used, this method generates an expression from a attribute value pair.
buildExpression(Object, QueryByExamplePolicy, Expression, Map, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: In case Query By Example is used, this method builds and returns an expression that corresponds to a single attribute and it's value.
buildExpression(Object, QueryByExamplePolicy, Expression, Map, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: In case Query By Example is used, this method builds and returns an expression that corresponds to a single attribute and it's value.
buildExpression(DatabaseTable, AbstractRecord, AbstractRecord, ExpressionBuilder) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: returns the expression to be used in both the delete and update where clause.
buildExpressionBuilderDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildExpressionDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildExpressionFromExample(Object, QueryByExamplePolicy, Expression, Map, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: This method is used when Query By Example is used.
buildExpressionString(String, NonreflectiveMethodDefinition, String, Expression, String) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
buildFactory() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
buildFactoryDefaultConstructor() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Build and return the default (zero-argument) constructor for the factory class.
buildFactoryUsingDefaultConstructor() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Build and return the factory, using its default constructor.
buildFactoryUsingStaticMethod() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Build and return the factory, using the specified static method.
buildFetchGroupDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildFetchGroupManagerDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildField(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: A DatabaseField is built from the given field name.
buildField(String) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: XML type descriptors should use XMLFields.
buildField(String) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: A DatabaseField is built from the given field name.
buildField(DatabaseField) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: The table of the field is ensured to be unique from the descriptor's tables.
buildField(DatabaseField) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: If the field is an XMLField then set the namespace resolver from the descriptor.
buildField(DatabaseField) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: This is used only in initialization.
buildField(DatabaseField, DatabaseTable) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
 
buildFieldExpressionDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildFieldTransformationDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildFieldTranslationDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildFieldTypes() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return the mapping of class types to database types for the schema framework.
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.AccessPlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.AttunityPlatform
Create a table which can translate between java types and Attunity Connect data types.
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.CloudscapePlatform
seems compatible with informix
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.DB2MainframePlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.DB2Platform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.DBasePlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.H2Platform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
Return the mapping of class types to database types for the schema framework.
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.Oracle10Platform
INTERNAL: Add XMLType as the default database type for org.w3c.dom.Documents.
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
INTERNAL:
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL:
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.PointBasePlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.PostgreSQL10Platform
Build the mapping of class types to database types for the schema framework.
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Return the mapping of Java class types to database types for the schema framework.
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.TimesTen7Platform
Return the mapping of class types to database types for the schema framework.
buildFieldTypes() - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
Return the mapping of class types to database types for the schema framework.
buildFieldTypes(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Build the foreign key constraints.
buildFieldTypes(TableDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
INTERNAL: builds the field names based on the type read in from the builder
buildFieldValue(Object, String, Session) - Method in class org.eclipse.persistence.mappings.transformers.ConstantTransformer
INTERNAL: Always return the constant value.
buildFieldValue(Object, String, Session) - Method in interface org.eclipse.persistence.mappings.transformers.FieldTransformer
 
buildFieldValue(Object, String, Session) - Method in class org.eclipse.persistence.mappings.transformers.FieldTransformerAdapter
 
buildFieldValue(Object, String, Session) - Method in class org.eclipse.persistence.mappings.transformers.MethodBasedFieldTransformer
 
buildFieldValue(Object, String, SESSION) - Method in interface org.eclipse.persistence.core.mappings.transformers.CoreFieldTransformer
 
buildFieldValue(Object, XMLField, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
INTERNAL: Retrieve the target object's primary key value that is mapped to a given source xpath (in the source-target key field association list).
buildFieldValue(Object, XMLField, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
INTERNAL: Retrieve the target object's primary key value that is mapped to a given source xpath (in the source-target key field association list).
buildFieldValue(Object, XML_FIELD, ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ObjectReferenceMapping
 
buildFieldValueFromDirectValues(Vector, String, AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Build the appropriate field value for the specified set of direct values.
buildFieldValueFromDirectValues(Vector, String, AbstractSession) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: Build the appropriate field value for the specified set of direct values.
buildFieldValueFromDirectValues(Vector, String, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Build the appropriate field value for the specified set of direct values.
buildFieldValueFromDirectValues(Vector, String, AbstractSession) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Build the appropriate field value for the specified set of direct values.
buildFieldValueFromForeignKeys(Vector, String, AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Build and return the appropriate field value for the specified set of foreign keys (i.e.
buildFieldValueFromNestedRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Build and return the field value from the specified nested database row.
buildFieldValueFromNestedRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: Build and return the field value from the specified nested database row.
buildFieldValueFromNestedRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Build and return the field value from the specified nested database row.
buildFieldValueFromNestedRows(Vector, String, AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Build and return the appropriate field value for the specified set of nested rows.
buildFieldValueFromNestedRows(Vector, String, AbstractSession) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: Build and return the appropriate field value for the specified set of nested rows.
buildFieldValueFromNestedRows(Vector, String, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Build and return the appropriate field value for the specified set of nested rows.
buildFieldValueFromNestedRows(Vector, String, AbstractSession) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Build and return the appropriate field value for the specified set of nested rows.
buildFirstRowsHint(int) - Method in class org.eclipse.persistence.platform.database.Oracle10Platform
Build the hint string used for first rows.
buildFirstRowsHint(int) - Method in class org.eclipse.persistence.platform.database.Oracle9Platform
Build the hint string used for first rows.
buildFirstRowsHint(int) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Build the hint string used for first rows.
buildForeignKeyConstraint(List<String>, List<String>, TableDefinition, DatabasePlatform) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
Build a foreign key constraint.
buildForeignKeyConstraint(FieldDefinition, DatabasePlatform) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
Build a foreign key constraint using FieldDefinition.getForeignKeyFieldName().
buildForeignKeyConstraintName(String, String, int, DatabasePlatform) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
Return foreign key constraint name built from the table and field name with the specified maximum length.
buildForeignReferenceMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildForeignReferenceMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildFromBigDecimalVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromBigIntegerVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromBlobVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromBooleanVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromByteArrayVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromByteObjectArraryVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromByteVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromCalendarVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromCharacterArrayVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromCharacterVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromCharArrayVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromClobVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromDateVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromDoubleVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromFloatVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromIntegerVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromLongVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromNumberVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromShortVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromStringVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromTimestampVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromTimeVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFromUtilDateVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildFunctionExpressionDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildHexStringFromBytes(byte[]) - Static method in class org.eclipse.persistence.internal.helper.Helper
Convert the byte array to a HEX string.
buildHexStringFromObjectBytes(Byte[]) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
buildHistoryPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildHistoryTableDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildIgnoreNewElementsOrderingPolicyConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
buildIgnoreNewElementsOrderingPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildInDeclare(StringBuilder, PLSQLargument) - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
buildInDeclare(StringBuilder, PLSQLargument) - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
buildInDeclare(StringBuilder, PLSQLargument) - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
buildInDeclare(StringBuilder, PLSQLargument) - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
 
buildInDeclare(StringBuilder, PLSQLargument) - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
buildInDeclare(StringBuilder, PLSQLargument) - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
INTERNAL: Append the variable declaration for the type.
buildInDeclare(StringBuilder, PLSQLargument) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCursor
 
buildInDeclare(StringBuilder, PLSQLargument) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
buildIndex(AbstractSession, String, List<String>, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Return the index creation statement.
buildIndexDeletionWriter(AbstractSession, String, Writer, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Return the index drop statement.
buildIndexName(String, String, String, int, DatabasePlatform) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
Return key constraint name built from the table and key name with the specified maximum length and index prefix.
buildIndirectContainer() - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
Construct and return an instance of the specified indirect container class.
buildIndirectContainer(ValueHolderInterface) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
Return a new IndirectContainer with the specified value holder.
buildIndirectionPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildIndirectObject(ValueHolderInterface) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: This method can be used when an Indirection Object is required to be built from a provided ValueHolderInterface object.
buildIndirectObject(ValueHolderInterface) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: This method can be used when an Indirection Object is required to be built from a provided ValueHolderInterface object.
buildIndirectObject(ValueHolderInterface) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: This method can be used when an Indirection Object is required to be built from a provided ValueHolderInterface object.
buildIndirectObject(ValueHolderInterface) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: This method can be used when an Indirection Object is required to be built from a provided ValueHolderInterface object.
buildIndirectObject(ValueHolderInterface) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: This method can be used when an Indirection Object is required to be built from a provided ValueHolderInterface object.
buildInheritanceHierarchyTree(Project) - Static method in class org.eclipse.persistence.internal.codegen.InheritanceHierarchyBuilder
 
buildInheritancePolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildInheritancePolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildInheritancePolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildInMemoryQueryIndirectionPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildInsertObjectQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildInsertStatement(DatabaseTable) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return the appropriate insert statement
buildInstantiationCopyPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildInstantiationPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildInstantiationPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildInteractionArgumentDescriptor() - Method in class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
buildInteractionSpec(EISInteraction) - Method in class org.eclipse.persistence.eis.EISPlatform
Allow the platform to build the interaction spec based on properties defined in the interaction.
buildInterfaceContainerPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildInterfaceContainerPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildInterfacePolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildInterfacePolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildIntoNestedRow(AbstractRecord, Object, Object, AbstractSession, Descriptor, Field, boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
buildIntoNestedRow(AbstractRecord, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
buildIntoNestedRow(AbstractRecord, Object, AbstractSession, Descriptor, Field) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
buildIntToTypeConverterHash() - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Build all conversions based on JDBC return values.
buildIsSetNullPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildJavaLogConfig(JavaLogConfig, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
buildJavaLogConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildJDBCTypeWrapperDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildJMSPublishingTransportManagerConfig(JMSPublishingTransportManagerConfig, RemoteCommandManager) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
buildJMSPublishingTransportManagerConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildJMSTopicTransportManagerConfig(JMSTopicTransportManagerConfig, RemoteCommandManager) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
buildJMSTopicTransportManagerConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildJNDINamingServiceConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildJPQLCallDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildKey(AbstractRecord, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
Extract the key for the map from the provided row overridden by subclasses that deal with map keys
buildKey(AbstractRecord, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
Extract the key for the map from the provided row.
buildKeyFromJoinedRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
Extract the key for the map from the provided row overridden by subclasses that deal with map keys
buildKeyFromJoinedRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
Extract the key for the map from the provided row.
buildKeyRowForTargetUpdate(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
 
buildKeyRowForTargetUpdate(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL: Build a row containing the keys for use in the query that updates the row for the target object during an insert or update
buildListContainerPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildListOrderField() - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Verifies listOrderField's table, if none found sets the default one.
buildListOrderField() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Verifies listOrderField's table: it must be reference table.
buildListOrderField() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Verifies listOrderField's table: it must be relation table.
buildListOrderField() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Verifies listOrderField's table: it must be the same table that contains all target foreign keys.
buildLogConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildLogConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigToplinkProject
 
buildLoggingOptionsConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildLogicalExpressionDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildLogin(LoginConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Build the correct login based on the login config type
buildLoginConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildLoginMethod(DatabaseLogin) - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
 
buildLoginMethod(Login) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
buildManyToManyMappingMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildManyToManyMappingMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildMapContainerPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildMessage(Class<?>, int, Object[]) - Static method in class org.eclipse.persistence.exceptions.i18n.ExceptionMessageGenerator
Return the message for the given exception class and error number.
buildMessage(String) - Static method in class org.eclipse.persistence.internal.localization.DMSLocalization
 
buildMessage(String) - Static method in class org.eclipse.persistence.internal.localization.ExceptionLocalization
 
buildMessage(String) - Static method in class org.eclipse.persistence.internal.localization.JAXBLocalization
 
buildMessage(String) - Static method in class org.eclipse.persistence.internal.localization.LoggingLocalization
 
buildMessage(String) - Static method in class org.eclipse.persistence.internal.localization.ToStringLocalization
 
buildMessage(String) - Static method in class org.eclipse.persistence.internal.localization.TraceLocalization
 
buildMessage(String, boolean) - Static method in class org.eclipse.persistence.internal.localization.TraceLocalization
 
buildMessage(String, Object[]) - Static method in class org.eclipse.persistence.internal.localization.DMSLocalization
 
buildMessage(String, Object[]) - Static method in class org.eclipse.persistence.internal.localization.ExceptionLocalization
 
buildMessage(String, Object[]) - Static method in class org.eclipse.persistence.internal.localization.JAXBLocalization
 
buildMessage(String, Object[]) - Static method in class org.eclipse.persistence.internal.localization.LoggingLocalization
 
buildMessage(String, Object[]) - Static method in class org.eclipse.persistence.internal.localization.ToStringLocalization
 
buildMessage(String, Object[]) - Static method in class org.eclipse.persistence.internal.localization.TraceLocalization
 
buildMessage(String, Object[], boolean) - Static method in class org.eclipse.persistence.internal.localization.TraceLocalization
 
buildMessage(String, String, Object[]) - Static method in class org.eclipse.persistence.internal.localization.EclipseLinkLocalization
Return the message for the given exception class and error number.
buildMessage(String, String, Object[], boolean) - Static method in class org.eclipse.persistence.internal.localization.EclipseLinkLocalization
INTERNAL: Return the message for the given exception class and error number.
buildMethod(Class<?>, String, Class<?>[]) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Build the specified method.
buildMethodBasedFieldTransformationDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildMethodBaseQueryRedirectorDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildMethodBaseQueryRedirectorDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildNamespaceDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildNamespaceResolver() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildNamespaceResolver() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
buildNamespaceResolverDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildNamespaceResolverDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildNativeCall(String) - Method in class org.eclipse.persistence.eis.EISPlatform
INTERNAL: Return the correct call type for the native query string.
buildNativeCall(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Return the correct call type for the native query string.
buildNativeSequenceConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildNativeSequenceDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildNestedFunctions(StringBuilder, List<PLSQLargument>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
INTERNAL Generate portion of the Anonymous PL/SQL block with PL/SQL conversion routines as nested functions.
buildNestedRow(Element) - Method in class org.eclipse.persistence.eis.EISDOMRecord
INTERNAL: Build the nested record, this can be overwriten by subclasses to use their subclass instance.
buildNestedRow(Element) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Build the nested record, this can be overwriten by subclasses to use their subclass instance.
buildNestedRowFromFieldValue(Object) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Build and return the nested database row from the specified field value.
buildNestedRowFromFieldValue(Object) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: Build the nested row.
buildNestedRowFromFieldValue(Object) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Build and return the nested database row from the specified field value.
buildNestedRowFromFieldValue(Object) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Build(if necessary) and return the nested XMLRecord from the specified field value.
buildNestedRowsFromFieldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Build and return the nested rows from the specified field value.
buildNestedRowsFromFieldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: Build the nested rows.
buildNestedRowsFromFieldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Build and return the nested rows from the specified field value.
buildNestedRowsFromFieldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Build(if necessary) and return a Vector of the nested XMLRecords from the specified field value.
buildNestedTableMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildNewIdentityMap(Class<T>, int, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
INTERNAL: Return a new empty identity map of the class type.
buildNewIdentityMap(ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
INTERNAL: (Public to allow testing to access) Return a new empty identity map to cache instances of the class.
buildNewInstance() - Method in class org.eclipse.persistence.internal.core.descriptors.CoreInstantiationPolicy
Build and return a new instance, using the appropriate mechanism.
buildNewInstance() - Method in class org.eclipse.persistence.internal.core.descriptors.CoreObjectBuilder
Return a new instance of the receiver's javaClass.
buildNewInstance() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Build and return a new instance, using the appropriate mechanism.
buildNewInstance() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return a new instance of the receiver's javaClass.
buildNewInstance() - Method in class org.eclipse.persistence.internal.descriptors.PersistenceObjectInstantiationPolicy
Build and return a new instance, using the factory
buildNewInstance() - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
buildNewInstance() - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
Return a new instance of the receiver's javaClass.
buildNewInstanceUsingDefaultConstructor() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Build and return a new instance, using the default (zero-argument) constructor.
buildNewInstanceUsingFactory() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Build and return a new instance, using the factory.
buildNewMergeInstanceOf(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Build and return a new instance of the specified attribute.
buildNewQueryMechanism(DatabaseQuery) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Return the appropriate mechanism, with the call added as necessary.
buildNewQueryMechanism(DatabaseQuery) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Return the appropriate mechanism, with the call added as necessary.
buildNewQueryMechanism(DatabaseQuery) - Method in interface org.eclipse.persistence.queries.Call
INTERNAL: Return the appropriate mechanism, with the call set as necessary.
buildNewQueryMechanism(DatabaseQuery) - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: Return the appropriate mechanism, with the call added as necessary.
buildNewSchema(String, NamespaceResolver, int, SchemaModelGeneratorProperties) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Create and return a new schema for the given namespace.
buildNewSimpleType(String) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Create and return a SimpleType with name set to the given name.
buildNodeOrderingPolicyConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
buildNodeOrderingPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildNoDocumentPreservationPolicyConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
buildNoDocumentPreservationPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildNoExpiryCacheInvalidationPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildNormalSelectStatement() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return the appropriate select statement containing the fields in the table.
buildNullPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildNumberVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildObject(boolean, ObjectBuildingQuery, AbstractRecord, AbstractSession, Object, CacheKey, ClassDescriptor, JoinedAttributeManager) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return an instance of the receivers javaClass.
buildObject(AbstractRecord) - Method in class org.eclipse.persistence.queries.DataReadQuery
INTERNAL: Build the result value for the row.
buildObject(AbstractRecord) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Used to build the object, and register it if in the context of a unit of work.
buildObject(AbstractRecord) - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: By default return the row.
buildObject(AbstractRecord) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: By default return the row.
buildObject(AbstractRecord, Vector) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Construct a result from a row.
buildObject(ObjectBuildingQuery, AbstractRecord, JoinedAttributeManager) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return an instance of the receivers javaClass.
buildObject(ObjectBuildingQuery, AbstractRecord, JoinedAttributeManager) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
INTERNAL: Override the parent's buildObject to allow for the caching of aggregate objects in OX.
buildObject(ObjectBuildingQuery, AbstractRecord, JoinedAttributeManager, AbstractSession, ClassDescriptor, InheritancePolicy, boolean, boolean, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return an instance of the receivers javaClass.
buildObject(ObjectLevelReadQuery, AbstractRecord) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return an instance of the receivers javaClass.
buildObjectAndWrapInXMLRoot(ClassDescriptor, XMLConverter, ObjectBuildingQuery, DOMRecord, DOMRecord, JoinedAttributeManager, AbstractSession, Node, Object, ContainerPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLAbstractAnyMapping
Uses a given reference descriptor to build an object based on a given DOMRecord.
buildObjectArrayMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildObjectChangeTrackingPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildObjectDescriptor(Object) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
build and return an object descriptor to be sent to the client
buildObjectDescriptor(Object) - Method in class org.eclipse.persistence.internal.sessions.remote.ReplaceValueHoldersIterator
build and return an object descriptor for the specified object
buildObjectForNonXMLRoot(ClassDescriptor, XMLConverter, ObjectBuildingQuery, DOMRecord, DOMRecord, JoinedAttributeManager, AbstractSession, Node, Object, ContainerPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLAbstractAnyMapping
 
buildObjectFromNestedRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, AbstractSession, boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
buildObjectFromResultSet(ObjectBuildingQuery, JoinedAttributeManager, ResultSet, AbstractSession, DatabaseAccessor, ResultSetMetaData, DatabasePlatform, Vector, DatabaseField[]) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Builds a working copy clone directly from a result set.
buildObjectInUnitOfWork(ObjectBuildingQuery, JoinedAttributeManager, AbstractRecord, UnitOfWorkImpl, Object, CacheKey, ClassDescriptor) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
For executing all reads on the UnitOfWork, the session when building objects from rows will now be the UnitOfWork.
buildObjectJoinExpression(Expression, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Used to allow object level comparisons.
buildObjectJoinExpression(Expression, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Used to allow object level comparisons.
buildObjectJoinExpression(Expression, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Used to allow object level comparisons.
buildObjectJoinExpression(Expression, Expression, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Used to allow object level comparisons.
buildObjectJoinExpression(Expression, Expression, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Used to allow object level comparisons.
buildObjectJoinExpression(Expression, Expression, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Used to allow object level comparisons.
buildObjectLevelReadQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildObjectLevelReadQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildObjectLevelReadQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildObjectNoReferenceDescriptor(DOMRecord, XMLConverter, AbstractSession, Node, Object, ContainerPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLAbstractAnyMapping
Convenience method that takes a given Node and applies namespace information, converts it if necessary, and adds the resulting object to the given ContainerPolicy if non-null.
buildObjectReferenceMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildObjectRelationalDatabaseFieldDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildObjectRelationalDataTypeDescriptorDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildObjects(Vector) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Construct a container of ReportQueryResult from the rows.
buildObjectsFromCursorInto(ReadAllQuery, List, Object) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return a container which contains the instances of the receivers javaClass.
buildObjectsFromRecords(List) - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
INTERNAL: This method is used to build the results.
buildObjectsFromRecords(List, int) - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
INTERNAL: This method is used to build the results with the SQLResultSetMapping at the given index.
buildObjectsFromRecords(List, SQLResultSetMapping) - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
INTERNAL: This method is used to build the results.
buildObjectsFromResultSetInto(ReadAllQuery, ResultSet, Vector, DatabaseField[], Object) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Version of buildObjectsInto method that takes call instead of rows.
buildObjectsInto(ReadAllQuery, List, Object) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return a container which contains the instances of the receivers javaClass.
buildObjectTypeConverterDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildObjectTypeFieldAssociationDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
Builds a descriptor for the ObjectTypeFieldAssociation class.
buildOneToManyMappingMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildOneToManyMappingMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildOneToManyQueryKeyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildOneToOneMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildOneToOneMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildOneToOneQueryKeyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildOptimisticLockingPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildOracleArrayTypeDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildOracleArrayTypeWrapperDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildOracleObjectTypeDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
Builds a descriptor for the OracleObjectType class.
buildOracleObjectTypeWrapperDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildOriginal(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Unregistered new objects have no original so we must create one for commit and resume and to put into the parent.
buildOutAssignment(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
buildOutAssignment(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
buildOutAssignment(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in enum org.eclipse.persistence.internal.helper.DatabaseType.DatabaseTypeHelper
 
buildOutAssignment(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
buildOutAssignment(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
 
buildOutAssignment(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
buildOutAssignment(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
INTERNAL: Append any code or translation for assigning the output value.
buildOutAssignment(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCursor
 
buildOutAssignment(StringBuilder, PLSQLargument, PLSQLStoredProcedureCall) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
buildOutAssignments(StringBuilder, List<PLSQLargument>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
INTERNAL Generate portion of the Anonymous PL/SQL block after the target procedures has been invoked and OUT parameters must be handled.
buildOutDeclare(StringBuilder, PLSQLargument) - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
buildOutDeclare(StringBuilder, PLSQLargument) - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
buildOutDeclare(StringBuilder, PLSQLargument) - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
buildOutDeclare(StringBuilder, PLSQLargument) - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
 
buildOutDeclare(StringBuilder, PLSQLargument) - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
buildOutDeclare(StringBuilder, PLSQLargument) - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
INTERNAL: Append the variable declaration for the type.
buildOutDeclare(StringBuilder, PLSQLargument) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCursor
 
buildOutDeclare(StringBuilder, PLSQLargument) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
buildOutputRow(CallableStatement, DatabaseAccessor, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Return Record containing output fields and values.
buildOutputRow(CallableStatement, DatabaseAccessor, AbstractSession) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
Translate the SQL procedure output row, into the row expected by the PLSQL procedure.
buildOutputRow(CallableStatement, DatabaseCall, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Build a row from the output parameters of a sp call.
buildOutputRow(PLSQLargument, AbstractRecord, DatabaseRecord, List<DatabaseField>, List) - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
buildOutputRow(PLSQLargument, AbstractRecord, DatabaseRecord, List<DatabaseField>, List) - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
buildOutputRow(PLSQLargument, AbstractRecord, DatabaseRecord, List<DatabaseField>, List) - Method in enum org.eclipse.persistence.internal.helper.DatabaseType.DatabaseTypeHelper
 
buildOutputRow(PLSQLargument, AbstractRecord, DatabaseRecord, List<DatabaseField>, List) - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
buildOutputRow(PLSQLargument, AbstractRecord, DatabaseRecord, List<DatabaseField>, List) - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
INTERNAL: Build the query output row from the call output row.
buildOutputRow(PLSQLargument, AbstractRecord, DatabaseRecord, List<DatabaseField>, List) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
buildOXXMLDescriptorDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildOXXMLDescriptorDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildOXXMLDescriptorDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildParameterExpressionDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildPessimisticLockingPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildPhantomRowFrom(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL Build a phantom row that contains only the fields for the mapping, populated with the values generated by invoking the field methods on the specified object.
buildPLSQLargumentDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildPLSQLCollectionDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildPLSQLCollectionDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildPLSQLCollectionWrapperDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildPLSQLCursorDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildPLSQLCursorWrapperDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildPLSQLrecordDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildPLSQLrecordDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildPLSQLrecordWrapperDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildPLSQLStoredFunctionCallDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildPLSQLStoredProcedureCallDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildPolicyFor(Class<?>) - Static method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the appropriate container policy for the specified concrete container class.
buildPolicyFor(Class<?>, boolean) - Static method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the appropriate container policy for the specified concrete container class.
buildPoolsConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildPrimaryKeyAttributesIntoObject(Object, AbstractRecord, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Build just the primary key mappings into the object.
buildPrimaryKeyExpression(DatabaseTable) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the primary key expression for the secondary table.
buildPrimaryKeyExpressionFromKeys(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the primary key expression from the specified primary key values.
buildPrimaryKeyExpressionFromObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the primary key expression from the specified domain object.
buildProcedureCallString(StoredProcedureCall, AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return the proc syntax for this platform.
buildProcedureCallString(StoredProcedureCall, AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
INTERNAL: Used for sp calls.
buildProcedureCallString(StoredProcedureCall, AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
Return the stored procedure syntax for this platform.
buildProcedureCallString(StoredProcedureCall, AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Used for sp calls.
buildProcedureInvocation(StringBuilder, List<PLSQLargument>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredFunctionCall
INTERNAL Generate portion of the Anonymous PL/SQL block that invokes the target function.
buildProcedureInvocation(StringBuilder, List<PLSQLargument>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
INTERNAL Generate portion of the Anonymous PL/SQL block that invokes the target procedure.
buildProcedureString(SQLCall) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Given a call, this method produces the stored procedure string based on the SQL string inside the call.
buildProfileSummary() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
INTERNAL: Return a summary profile reporting on the profiles contained.
buildProfileSummaryByClass() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
INTERNAL: Return a map of summary profiles reporting on the profile contained.
buildProfileSummaryByQuery() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
INTERNAL: Return a map of summary profiles reporting on the profile contained.
buildProjectClassConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildProjectConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildProjectDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildProjectDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildProjectDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildProjectXMLConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildPropertyAssociationDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildPropertyConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildProtectedObject(boolean, ObjectBuildingQuery, AbstractRecord, AbstractSession, Object, CacheKey, ClassDescriptor, JoinedAttributeManager) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return an instance of the receivers javaClass.
buildProxyIndirectionPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildQNameFromString(String, AbstractUnmarshalRecord) - Method in interface org.eclipse.persistence.internal.oxm.ConversionManager
 
buildQNameFromString(String, AbstractUnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
buildQNameInheritancePolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildQuery(CharSequence, AbstractSession) - Method in class org.eclipse.persistence.internal.jpa.jpql.HermesParser
 
buildQuery(CharSequence, AbstractSession) - Method in interface org.eclipse.persistence.queries.JPAQueryBuilder
Creates a fully initialized DatabaseQuery by parsing the given JPQL query.
buildQueryArgumentDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildQueryArgumentDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildQueryKeyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildQueryKeyExpressionDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildQueryKeyReferenceDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildQueryManagerDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildQueryMechanism(DatabaseQuery, DatabaseQueryMechanism) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Return the appropriate mechanism, with the call added as necessary.
buildQueryMechanism(DatabaseQuery, DatabaseQueryMechanism) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Return the appropriate mechanism, with the call added as necessary.
buildQueryMechanism(DatabaseQuery, DatabaseQueryMechanism) - Method in interface org.eclipse.persistence.queries.Call
INTERNAL: Return the appropriate mechanism, with the call added as necessary.
buildQueryMechanism(DatabaseQuery, DatabaseQueryMechanism) - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: Return the appropriate mechanism, with the call added as necessary.
buildQueryResultCachePolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildReadAllObjectQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildReadConnectionPoolConfig(ReadConnectionPoolConfig, ServerSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Build a read connection pool from the config to store on the server session.
buildReadConnectionPoolConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildReadObjectQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildReadQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildReference(Object) - Method in class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap
Allows subclass to create a SoftReference to the object.
buildReference(Object) - Method in class org.eclipse.persistence.internal.identitymaps.SoftCacheWeakIdentityMap
Creates a Soft reference to the object.
buildReference(Object, XMLField, Object, AbstractSession, Object, ReferenceResolver) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
INTERNAL: Create (if necessary) and populate a reference object that will be used during the mapping reference resolution phase after unmarshalling is complete.
buildReference(UnmarshalRecord, XMLField, Object, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
INTERNAL: Create (if necessary) and populate a reference object that will be used during the mapping reference resolution phase after unmarshalling is complete.
buildReference(UnmarshalRecord, XMLField, Object, AbstractSession, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
INTERNAL: Create (if necessary) and populate a reference object that will be used during the mapping reference resolution phase after unmarshalling is complete.
buildReference(UNMARSHAL_RECORD, XML_FIELD, Object, ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ObjectReferenceMapping
 
buildReference(UNMARSHAL_RECORD, XML_FIELD, Object, ABSTRACT_SESSION, Object) - Method in interface org.eclipse.persistence.internal.oxm.mappings.CollectionReferenceMapping
 
buildReferenceMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildReferencesPKList(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: This method will access the target relationship and create a list of information to rebuild the relationship.
buildReferencesPKList(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: This method will access the target relationship and create a list of information to rebuild the relationship.
buildReferencesPKList(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: This method will access the target relationship and create a list of PKs of the target entities.
buildReferencesPKList(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: This method will access the target relationship and create a list of information to rebuild the collection.
buildReferencesPKList(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: This method will access the target relationship and create a list of information to rebuild the collection.
buildReferencesPKList(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: This method will access the target relationship and create a list of information to rebuild the collection.
buildRelationalDescriptorDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildRelationalDescriptorDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildRelationExpressionDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildRelationshipQueryKeyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildRelationshipQueryKeyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildRelationTableDefinition(ForeignReferenceMapping, RelationTableMechanism, DatabaseField, ContainerPolicy) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Build relation table definitions for all many-to-many relationships in a EclipseLink descriptor.
buildRelationTableFields(ForeignReferenceMapping, TableDefinition, List<DatabaseField>, List<DatabaseField>) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Build field definitions and foreign key constraints for all many-to-many relation table.
buildRelationTableSourceAndTargetRow(Object, Object, AbstractSession, ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Create a row that contains source relation fields with values extracted from the source object and target relation fields with values extracted from the target object.
buildRelationTableSourceAndTargetRow(AbstractRecord, Object, AbstractSession, ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Create a row that contains source relation fields with values extracted from the source row and target relation fields with values extracted from the target object.
buildRelationTableSourceRow(Object, AbstractSession, ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Create a row that contains source relation fields with values extracted from the source object.
buildRelationTableSourceRow(AbstractRecord) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Create a row that contains source relation fields with values extracted from the source row.
buildRelativePositionOrderingPolicyConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
buildRelativePositionOrderingPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildRemoteCommandManagerConfig(RemoteCommandManagerConfig, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
buildRemoteCommandManagerConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildRemoteValueHolderFor(ValueHolderInterface) - Method in class org.eclipse.persistence.internal.sessions.remote.ReplaceValueHoldersIterator
build a properly initialized remote value holder
buildRemovedElementFromChangeSet(Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Build and return a new element based on the change set.
buildRemovedElementFromChangeSet(Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Build and return a new element based on the change set.
buildRemovedElementFromChangeSet(Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Build and return a new element based on the change set.
buildRemovedElementFromChangeSet(Object, MergeManager, AbstractSession) - Method in interface org.eclipse.persistence.mappings.structures.ArrayCollectionMapping
Build and return a recently-removed element based on the change set.
buildReportItemDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildReportQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildReportQuerySelectStatement(boolean) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return the appropriate select statement containing the fields in the table.
buildReportQuerySelectStatement(boolean, boolean, Expression, boolean) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Customary inheritance expression is required for DeleteAllQuery and UpdateAllQuery preparation.
buildResult(ReportQuery, AbstractRecord, Vector) - Method in class org.eclipse.persistence.queries.ReportQueryResult
INTERNAL: Create an array of attribute values (converted from raw field values using the mapping).
buildReturningFieldInfoDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildReturningFieldInfoDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildReturningPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildRMIIIOPTransportManagerConfig(RMIIIOPTransportManagerConfig, RemoteCommandManager) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Left this in for now since in the future we may add more IIOP specific configurations?
buildRMIIIOPTransportManagerConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildRMIRegistryNamingServiceConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildRMITransportManagerConfig(RMITransportManagerConfig, RemoteCommandManager) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
buildRMITransportManagerConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildRow(Record, EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
INTERNAL: Build a database row from the record returned from the interaction.
buildRow(Record, EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.IndexedInteraction
Build a database row from the record returned from the interaction.
buildRow(Record, EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.MappedInteraction
Build a database row from the record returned from the interaction.
buildRow(Record, EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.XMLInteraction
Build a database row from the record returned from the interaction.
buildRow(Record, EISInteraction, EISAccessor) - Method in class org.eclipse.persistence.eis.EISPlatform
INTERNAL: Allow the platform to handle record to row conversion.
buildRow(Object, AbstractSession, DatabaseField, XMLRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
Build the nested row into the parent dom.
buildRow(Object, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of an object.
buildRow(XMLRecord, Object, CoreAbstractSession, MARSHALLER, XPathFragment) - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
buildRow(XMLRecord, Object, CoreAbstractSession, Marshaller, XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
buildRow(XMLRecord, Object, CoreAbstractSession, XMLMarshaller, XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
buildRow(AbstractRecord, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
buildRow(AbstractRecord, Object, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
buildRow(AbstractRecord, Object, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of an object.
buildRow(AbstractRecord, Object, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
buildRowForShallowInsert(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of the object for update.
buildRowForShallowInsert(AbstractRecord, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of the object for update.
buildRowForTranslation(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of an object.
buildRowForUpdate(AbstractRecord, WriteObjectQuery) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build into the row representation of the object for update.
buildRowForUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of the object for update.
buildRowForUpdateAfterShallowInsert(Object, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of the object that contains only the fields nullified by shallow insert.
buildRowForUpdateAfterShallowInsert(AbstractRecord, Object, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of the object that contains only the fields nullified by shallow insert.
buildRowForUpdateBeforeShallowDelete(Object, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of the object that contains only the fields nullified by shallow insert, with all values set to null.
buildRowForUpdateBeforeShallowDelete(AbstractRecord, Object, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of the object that contains only the fields nullified by shallow insert, with all values set to null.
buildRowForUpdateWithChangeSet(WriteObjectQuery) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of the object for update.
buildRowForWhereClause(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of an object.
buildRowFromPrimaryKeyValues(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row from the primary key values.
buildRowFromStructure(Struct) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Build a row representation from the ADT structure field array.
buildRows(Record, EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
Build a collection of database rows from the Record returned from the interaction.
buildRows(Record, EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.XMLInteraction
Build a collection of database rows from the Record returned from the interaction.
buildRows(Record, EISInteraction, EISAccessor) - Method in class org.eclipse.persistence.eis.EISPlatform
Allow the platform to handle record to row conversion.
buildRowWithChangeSet(AbstractRecord, ObjectChangeSet, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of an object.
buildSchemaComponentsForXPath(XPathFragment, Sequence, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
This method will build element/complexType/sequence components for a given XPath, and return the sequence that the target element of the mapping should be added to.
buildScrollableCursorPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildSelectedFieldsLockingPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildSelectionCriteria() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
This method would allow customers to get the potential selection criteria for a mapping prior to initialization.
buildSelectionCriteria() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
This method would allow customers to get the potential selection criteria for a mapping prior to initialization.
buildSelectionCriteria(boolean, boolean) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Build the selection criteria for this mapping.
buildSelectionCriteria(String, String, AbstractSession) - Method in class org.eclipse.persistence.internal.jpa.jpql.HermesParser
 
buildSelectionCriteria(String, String, AbstractSession) - Method in interface org.eclipse.persistence.queries.JPAQueryBuilder
Creates a new Expression that represents the given selection criteria.
buildSelectionCriteria(AbstractSession) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Internal: In the case of EJBQL, an expression needs to be generated.
buildSelectionCriteria(AbstractSession) - Method in class org.eclipse.persistence.internal.queries.JPQLCallQueryMechanism
Internal: In the case of EJBQL, an expression needs to be generated, and the query populated.
buildSelectionCriteria(AbstractSession) - Method in class org.eclipse.persistence.internal.queries.QueryByExampleMechanism
INTERNAL: In the case of EJBQL or query by example, an expression needs to be generated.
buildSelectionCriteria(AbstractSession) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: In the case of EJBQL, an expression needs to be generated.
buildSelectionCriteriaAndAddFieldsToQueryInternal(ForeignReferenceMapping, Expression, boolean, boolean) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Build the selection criteria to join the source, relation, and target tables.
buildSelectionQueryForDirectCollectionKeyMapping(ContainerPolicy) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Certain key mappings favor different types of selection query.
buildSelectionQueryForDirectCollectionKeyMapping(ContainerPolicy) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Certain key mappings favor different types of selection query.
buildSelectionQueryForDirectCollectionKeyMapping(ContainerPolicy) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Depending on the MapKeyMapping, a different selection query may be required to retrieve the map when the map is based on a DirectCollectionMapping
buildSelectionQueryForDirectCollectionKeyMapping(ContainerPolicy) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Certain key mappings favor different types of selection query.
buildSelectionQueryForDirectCollectionMapping() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: This Certain key mappings favor different types of selection query.
buildSelectionQueryForDirectCollectionMapping() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Certain key mappings favor different types of selection query.
buildSelectQuery() - Method in class org.eclipse.persistence.sequencing.NativeSequence
INTERNAL:
buildSelectQuery() - Method in class org.eclipse.persistence.sequencing.QuerySequence
INTERNAL:
buildSelectQuery() - Method in class org.eclipse.persistence.sequencing.TableSequence
 
buildSelectQuery(String, Integer) - Method in class org.eclipse.persistence.sequencing.NativeSequence
INTERNAL:
buildSelectQuery(String, Integer) - Method in class org.eclipse.persistence.sequencing.QuerySequence
INTERNAL:
buildSelectQuery(String, Integer) - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
buildSelectQueryForIdentity() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Returns query used to read back the value generated by Identity.
buildSelectQueryForIdentity() - Method in class org.eclipse.persistence.platform.database.AccessPlatform
INTERNAL: Build the identity query for native sequencing.
buildSelectQueryForIdentity() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Build the identity query for native sequencing.
buildSelectQueryForIdentity() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL: Build the identity query for native sequencing.
buildSelectQueryForIdentity() - Method in class org.eclipse.persistence.platform.database.H2Platform
 
buildSelectQueryForIdentity() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
 
buildSelectQueryForIdentity() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
INTERNAL: Build the identity query for native sequencing.
buildSelectQueryForIdentity() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Build the identity query for native sequencing.
buildSelectQueryForIdentity() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
INTERNAL: Build the identity query for native sequencing.
buildSelectQueryForIdentity() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Returns query used to read back the value generated by Identity.
buildSelectQueryForIdentity() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
INTERNAL: Build the identity query for native sequencing.
buildSelectQueryForIdentity() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Build the identity query for native sequencing.
buildSelectQueryForIdentity() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Build the identity query for native sequencing.
buildSelectQueryForIdentity(String, Integer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Returns query used to read back the value generated by Identity.
buildSelectQueryForIdentity(String, Integer) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Though Oracle doesn't support identity it could be imitated, see comment to setSupportsIdentity method.
buildSelectQueryForSequenceObject() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Returns query used to read value generated by sequence object (like Oracle sequence).
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Returns query used to read value generated by sequence object (like Oracle sequence).
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 added SEQUENCE support as of (I believe) v8.
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
 
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.platform.database.H2Platform
 
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
 
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.platform.database.InformixPlatform
INTERNAL: Returns query used to read value generated by sequence object (like Oracle sequence).
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.platform.database.MariaDBPlatform
 
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Produce a DataReadQuery which updates(!) the sequence number in the db and returns it.
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Returns query used to read value generated by sequence object (like Oracle sequence).
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Produce a DataReadQuery which updates(!) the sequence number in the database and returns it.
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Produce a DataReadQuery which updates(!) the sequence number in the DB and returns it.
buildSelectQueryForSequenceObject(String, Integer) - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
INTERNAL: Produce a DataReadQuery which updates(!) the sequence number in the db and returns it.
buildSelectStatementForDoesExist(DatabaseField) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return the appropriate select statement to perform a does exist check
buildSelectString1() - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
buildSelfRecord(UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL:
buildSelfRecord(UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
buildSelfRecord(UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
buildSequence(SequenceConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Builds a Sequence from the given SequenceConfig.
buildSequenceConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildSequenceDefinition(Sequence) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
buildSequenceDefinitions() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
INTERNAL: Build the sequence definitions.
buildSequenceDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildSequenceObjectAlterIncrementWriter(Writer, String, int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Returns sql used to alter sequence object's increment in the database.
buildSequenceObjectCreationWriter(Writer, String, int, int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Returns sql used to create sequence object in the database.
buildSequenceObjectCreationWriter(Writer, String, int, int) - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
INTERNAL: Returns sql used to create sequence object in the database.
buildSequenceObjectCreationWriter(Writer, String, int, int) - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
INTERNAL: HSQL requires START WITH first.
buildSequenceObjectCreationWriter(Writer, String, int, int) - Method in class org.eclipse.persistence.platform.database.MariaDBPlatform
INTERNAL: Returns query used to read value generated by sequence object (like Oracle sequence).
buildSequenceObjectDeletionWriter(Writer, String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Returns sql used to delete sequence object from the database.
buildSequenceObjectDeletionWriter(Writer, String) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL: Derby supports sequence objects as of 10.6.1.
buildSequenceObjectDeletionWriter(Writer, String) - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
INTERNAL: Returns sql used to delete sequence object from the database.
buildSequencingConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildSerializedObjectConverterDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildServerLogConfig(ServerLogConfig, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
buildServerLogConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildServerPlatformConfig(ServerPlatformConfig, DatabaseSessionImpl) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Build the appropriate server platform
buildServerPlatformConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
buildServerPlatformConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildServerPlatformConfigDescriptorFor(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildServerSessionConfig(ServerSessionConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Builds a server server from the given ServerSessionConfig.
buildServerSessionConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildSession(SessionConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Build the correct session based on the session config type
buildSessionBrokerConfig(SessionBrokerConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Builds a session broker from the given SessionBrokerConfig.
buildSessionBrokerConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildSessionConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildSessionConfigs(SessionConfigs, ClassLoader) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: To build EclipseLink sessions, users must call this method with a SessionConfigs object returned from an OX read in the XMLSessionConfigLoader.
buildSessionConfigsDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
buildSessionConfigsDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildSessionConfigsDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigToplinkProject
 
buildSessionEventManagerConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildSessionLog(LogConfig, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
buildShallowOriginalFromRow(AbstractRecord, Object, JoinedAttributeManager, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Builds a shallow original object.
buildShallowOriginalFromRow(AbstractRecord, Object, JoinedAttributeManager, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Builds a shallow original object.
buildShallowOriginalFromRow(AbstractRecord, Object, JoinedAttributeManager, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: Builds a shallow original object.
buildShallowOriginalFromRow(AbstractRecord, Object, JoinedAttributeManager, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Builds a shallow original object.
buildShallowOriginalFromRow(AbstractRecord, Object, JoinedAttributeManager, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Builds a shallow original object.
buildShallowOriginalFromRow(AbstractRecord, Object, JoinedAttributeManager, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Builds a shallow original object.
buildSimple(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
buildSimplePLSQLTypeWrapperDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildSimpleType(Descriptor, Schema, boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Create and return a SimpleType for a given XMLDescriptor.
buildsNewInstance() - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Return false as a shallow clone is returned, not a new instance.
buildsNewInstance() - Method in interface org.eclipse.persistence.descriptors.copying.CopyPolicy
Return if this copy policy creates a new instance, vs a clone.
buildsNewInstance() - Method in class org.eclipse.persistence.descriptors.copying.InstantiationCopyPolicy
 
buildsNewInstance() - Method in class org.eclipse.persistence.descriptors.copying.PersistenceEntityCopyPolicy
 
buildSortedCollectionContainerPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildSortedCollectionContainerPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildSortedFields(Vector<DatabaseField>, ResultSet, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return the field sorted in the correct order corresponding to the result set.
buildSQLCallDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildStatementsForDeleteAllForTempTables() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Build SQLStatements for delete all using temporary table.
buildStatementsForUpdateAllForTempTables(DatabaseTable, HashMap, List<DatabaseField>) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
buildStoredFunctionCallDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildStoredProcedureArgumentDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildStoredProcedureArgumentDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildStoredProcedureCallDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildStoredProcedureInOutArgumentsDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildStoredProcedureOutArgumentsDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildStoredProcedureOutCursorArgumentsDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildStructConverterConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildStructureFromRow(AbstractRecord, AbstractSession, Connection) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Build a ADT structure from the row data.
buildStructureMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildSunCORBATransportManagerConfig(SunCORBATransportManagerConfig, RemoteCommandManager) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Builds a Sun CORBA transport manager with the given remote command manager
buildSunCORBATransportManagerConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildTableDefinition() - Method in class org.eclipse.persistence.tools.schemaframework.SequenceDefinition
INTERNAL: Return a TableDefinition
buildTableDefinition() - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
INTERNAL: Return a TableDefinition specifying sequence table.
buildTableDefinition() - Method in class org.eclipse.persistence.tools.schemaframework.UnaryTableSequenceDefinition
INTERNAL: Return a TableDefinition specifying a unary sequence table.
buildTableMethod(TableDefinition) - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
 
buildTableSequenceConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildTableSequenceDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildTarget(PLSQLargument) - Method in enum org.eclipse.persistence.internal.helper.DatabaseType.DatabaseTypeHelper
 
buildTargetInterfaces(Class<?>, Collection) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Build a list of all the interfaces and super interfaces for a given class.
buildTemplateInsertRow(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row of all of the fields used for insertion.
buildTemplateInsertRow(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Build and return a "template" database row with all the fields set to null.
buildTemplateInsertRow(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
buildTemplateUpdateRow(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row representation of the object for update.
buildTextNode(String) - Method in class org.eclipse.persistence.internal.oxm.SAXFragmentBuilder
 
buildThreadCursoredResult(DatabaseCall, ResultSet, Statement, ResultSetMetaData, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
This allows for the rows to be fetched concurrently to the objects being built.
buildTimestmapLockingPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildTimeToLiveCacheInvalidationPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildToBigDecimalVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToBigIntegerVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToBlobVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToBooleanVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToByteArrayVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToByteObjectArrayVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToByteVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToCalendarVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToCharacterArrayVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToCharacterVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToCharArrayVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToClobVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToDateVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToDoubleVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToFloatVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToIntegerVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToLongVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToNumberVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToShortVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToStringVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToTimestampVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToTimeVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildToUtilDateVec() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
 
buildTransformationMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildTransformer() - Method in class org.eclipse.persistence.internal.descriptors.FieldTransformation
 
buildTransformer() - Method in class org.eclipse.persistence.internal.descriptors.MethodBasedFieldTransformation
 
buildTransformer() - Method in class org.eclipse.persistence.internal.descriptors.TransformerBasedFieldTransformation
 
buildTransformerBasedFieldTransformationDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildTransformerBasedFieldTransformationDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildTransparentIndirectionPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildTransportManager(TransportManagerConfig, RemoteCommandManager) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
buildTransportManagerConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildTypeConversionConverterDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildTypeConversionConverterDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildTypedAssociationDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildTypedAssociationDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
 
buildTypedField(String) - Method in class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
buildTypedField(String) - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildTypeMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildTypesafeEnumConverterDescriptor(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildUnaryTableSequenceConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildUnaryTableSequenceDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildUniqueConstraintCreationWriter(AbstractSession, UniqueKeyConstraint, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Return the alter table statement to add the constraints.
buildUniqueConstraintDeletionWriter(AbstractSession, UniqueKeyConstraint, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Return the alter table statement to drop the constraints.
buildUniqueKeyConstraint(String, List<String>, int, DatabasePlatform) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
 
buildUniqueKeyConstraintName(String, int, int) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
Return unique key constraint name built from the table name and sequence number with the specified maximum length.
buildUnitofWorkCloneForPartObject(Object, Object, Object, Integer, UnitOfWorkImpl, boolean) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Require for cloning, the part must be cloned.
buildUpdateAllStatement(DatabaseTable, HashMap, SQLCall, SQLSelectStatement, Collection) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
buildUpdateAllStatementForOracleAnonymousBlock(HashMap, HashMap) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
buildUpdateExpression(DatabaseTable, Expression, AbstractRecord, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: This method must be included in any locking policy.
buildUpdateExpression(DatabaseTable, Expression, AbstractRecord, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: When given an expression, this method will return a new expression with the optimistic locking values included.
buildUpdateExpression(DatabaseTable, Expression, AbstractRecord, AbstractRecord) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: When given an expression, this method will return a new expression with the optimistic locking values included.
buildUpdateExpression(DatabaseTable, AbstractRecord, AbstractRecord) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build and return the expression to use as the where clause to an update object.
buildUpdateObjectQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildUpdateQuery() - Method in class org.eclipse.persistence.sequencing.QuerySequence
INTERNAL:
buildUpdateQuery() - Method in class org.eclipse.persistence.sequencing.TableSequence
 
buildUpdateQuery(String, Number) - Method in class org.eclipse.persistence.sequencing.QuerySequence
INTERNAL:
buildUpdateQuery(String, Number) - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
buildUpdateStatement(DatabaseTable) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return the appropriate update statement
buildUpdateString1() - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
buildUpdateString2() - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
buildUserDefinedTransportManagerConfig(UserDefinedTransportManagerConfig, RemoteCommandManager) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
buildUserDefinedTransportManagerConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildValueReadQueryDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildValuesAsQMarksFromMappings(StringBuilder, Collection<DatabaseMapping>, String) - Static method in class org.eclipse.persistence.internal.descriptors.DescriptorHelper
Append list of values as list of question marks from descriptor class to provided StringBuilder.
buildVariableOneToOneMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildVectorFromMapElements(Map<?, T>) - Static method in class org.eclipse.persistence.internal.helper.Helper
Create a new Vector containing all of the map elements.
buildVersionLockingPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildViewSelectStatement(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Build a select statement for all subclasses on the view using the same selection criteria as the query.
buildVPDCreationFunctionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Sub classes should override.
buildVPDCreationFunctionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL:
buildVPDCreationPolicyWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Sub classes should override.
buildVPDCreationPolicyWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL:
buildVPDDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Sub classes should override.
buildVPDDeletionWriter(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL:
buildWorkingCopyClone(Object, Session) - Method in class org.eclipse.persistence.descriptors.copying.AbstractCopyPolicy
By default use the buildClone.
buildWorkingCopyClone(Object, Session) - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Clone through the workingCopyClone method, or if not specified the clone method.
buildWorkingCopyClone(Object, Session) - Method in interface org.eclipse.persistence.descriptors.copying.CopyPolicy
Return a shallow clone of the object for usage with the unit of work working copy.
buildWorkingCopyClone(Object, Session) - Method in class org.eclipse.persistence.descriptors.copying.PersistenceEntityCopyPolicy
 
buildWorkingCopyCloneFromRow(ObjectBuildingQuery, JoinedAttributeManager, AbstractRecord, UnitOfWorkImpl, Object, CacheKey) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Builds a working copy clone directly from the database row.
buildWorkingCopyCloneFromRow(DataRecord, ObjectBuildingQuery, Object, UnitOfWork) - Method in class org.eclipse.persistence.descriptors.copying.AbstractCopyPolicy
By default create a new instance.
buildWorkingCopyCloneFromRow(DataRecord, ObjectBuildingQuery, Object, UnitOfWork) - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Create a new instance, unless a workingCopyClone method is specified, then build a new instance and clone it.
buildWorkingCopyCloneFromRow(DataRecord, ObjectBuildingQuery, Object, UnitOfWork) - Method in interface org.eclipse.persistence.descriptors.copying.CopyPolicy
Return an instance with the primary key set from the row, used for building a working copy during a unit of work transactional read.
buildWorkingCopyCloneNormally(ObjectBuildingQuery, AbstractRecord, UnitOfWorkImpl, Object, CacheKey, ClassDescriptor, JoinedAttributeManager) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
buildWorkingCopyCloneFromRow is an alternative to this which is the normal behavior.
buildWrapperCacheKeyForAggregate(CacheKey, boolean) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Wrap the aggregate represented by this mapping in a cachekey so it can be processed my methods down the stack.
buildWriteConnectionPoolConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildXMLAnyAttributeMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildXMLAnyAttributeMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLAnyCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildXMLAnyCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLAnyCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLAnyObjectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildXMLAnyObjectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLAnyObjectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLBinaryDataCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.OXMObjectPersistenceRuntimeXMLProject
 
buildXMLBinaryDataMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.OXMObjectPersistenceRuntimeXMLProject
 
buildXMLBinderPolicyConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
buildXMLBinderPolicyDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLChoiceCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildXMLChoiceCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLChoiceFieldToClassAssociationDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildXMLChoiceFieldToClassAssociationDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLChoiceObjectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLCollectionReferenceMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildXMLCollectionReferenceMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLCompositeCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildXMLCompositeCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLCompositeDirectCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildXMLCompositeDirectCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLCompositeDirectCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLCompositeObjectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildXMLCompositeObjectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLCompositeObjectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLConversionPairDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLDirectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLDirectMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLFieldDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildXMLFieldDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLFieldDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLFileSequenceConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildXMLFileSequenceDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLFragmentCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildXMLFragmentCollectionMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLFragmentMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLInteractionDescriptor() - Method in class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
buildXMLListConverterDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
buildXMLLoginConfig(XMLLoginConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Wrapped by the getLogin() call, therefore, config can't be null at this point.
buildXMLLoginConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
buildXMLLoginConfigDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
buildXMLLoginDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLLoginDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLObjectReferenceMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
buildXMLRoot(Node, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLAbstractAnyMapping
Convenience method that builds an XMLRoot wrapping a given object.
buildXMLRootForText(Node, QName, XMLConverter, AbstractSession, DOMRecord) - Method in class org.eclipse.persistence.oxm.mappings.XMLAbstractAnyMapping
Convenience method that takes a given node and checks the first child for TEXT_NODE.
buildXMLSchemaClassPathReferenceDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLSchemaFileReferenceDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLSchemaReferenceDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLSchemaURLReferenceDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLTransformationMappingDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildXMLUnionFieldDescriptor() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
buildZeroPrefix(int, int) - Static method in class org.eclipse.persistence.internal.helper.Helper
Build a numerical string with leading 0s.
buildZeroPrefixAndTruncTrailZeros(int, int) - Static method in class org.eclipse.persistence.internal.helper.Helper
Build a numerical string with leading 0s and truncate trailing zeros.
buildZeroPrefixWithoutSign(int, int) - Static method in class org.eclipse.persistence.internal.helper.Helper
Build a numerical string with leading 0s.
bulk - Static variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
 
bulkUpdateListOrderFieldQuery - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
 
bypassDefaultNullValueCheck - Variable in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
PERF: Avoid default null value conversion check if not default null value set in conversion manager.
BYTE - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
BYTE - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
BYTE_ARRAY_BINDING_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
BYTE_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
ByteArrayDataSource - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
ByteArrayDataSource(byte[], String) - Constructor for class org.eclipse.persistence.internal.oxm.ByteArrayDataSource
 
ByteArraySource - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
ByteArraySource(byte[]) - Constructor for class org.eclipse.persistence.internal.oxm.ByteArraySource
 
ByteArraySource(byte[], String) - Constructor for class org.eclipse.persistence.internal.oxm.ByteArraySource
 
ByteArraySource(ByteArrayDataSource) - Constructor for class org.eclipse.persistence.internal.oxm.ByteArraySource
 

C

cache - Variable in class org.eclipse.persistence.internal.helper.ConcurrentFixedCache
 
Cache - Annotation Type in org.eclipse.persistence.annotations
The Cache annotation is used to configure the EclipseLink object cache.
CACHE - org.eclipse.persistence.annotations.CacheType
A cache identity map maintains a fixed number of objects specified by the application.
CACHE - org.eclipse.persistence.logging.LogCategory
 
CACHE - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
CACHE_ALL_STATEMENTS_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
CACHE_EXPIRY_AND_EXPIRY_TIME_OF_DAY_BOTH_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CACHE_EXTENDED_LOGGING - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.extended.logging" property control (enable/disable) usage logging of JPA L2 cache.
CACHE_ID - org.eclipse.persistence.annotations.CacheKeyType
Optimized cache key type that allows composite and complex values.
CACHE_KEY_INVALID - Static variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
CACHE_NOT_SUPPORTED_WITH_EMBEDDABLE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CACHE_QUERY_FORCE_DEFERRED_LOCKS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.query-force-deferred-locks" property force all queries and relationships to use deferred lock strategy during object building and L2 cache population.
CACHE_RETRIEVE_MODE - Static variable in class org.eclipse.persistence.config.QueryHints
"jakarta.persistence.cache.retrieveMode"
CACHE_SHARED_ - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property prefix "eclipselink.cache.shared." indicates whether entity's cache should be shared (non-isolated) for a specific entity type.
CACHE_SHARED_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Default caching properties - apply to all entities.
CACHE_SIZE_ - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property prefix "eclipselink.cache.size." is used to specify the cache size for a specific entity type.
CACHE_SIZE_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Default caching properties - apply to all entities.
CACHE_STATEMENTS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jdbc.cache-statements" property specifies whether JDBC statements should be cached.
CACHE_STATEMENTS_SIZE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jdbc.cache-statements.size" property specifies the number of statements held when using internal statement caching.
CACHE_STATMENT - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.jdbc.cache-statement"
CACHE_STORE_MODE - Static variable in class org.eclipse.persistence.config.QueryHints
"jakarta.persistence.cache.storeMode"
CACHE_SYNC_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
CACHE_TYPE_ - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property prefix "eclipselink.cache.type." sets the type of cache for a specific entity type.
CACHE_TYPE_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Default caching properties - apply to all entities.
CACHE_USAGE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.cache-usage"
cacheAllStatements() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Cache all prepared statements, this requires full parameter binding as well.
CacheBasedValueHolder<T> - Class in org.eclipse.persistence.internal.indirection
Purpose: In certain cases the contents of a relationship may be retrievable from a cache.
CacheBasedValueHolder(Object[], AbstractRecord, AbstractSession, ForeignReferenceMapping) - Constructor for class org.eclipse.persistence.internal.indirection.CacheBasedValueHolder
 
CacheCoordination - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
CacheCoordinationProtocol - Class in org.eclipse.persistence.config
Cache coordination protocol persistence property values.
CacheCoordinationProtocol() - Constructor for class org.eclipse.persistence.config.CacheCoordinationProtocol
 
CacheCoordinationSerialize - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
CacheCoordinationType - Enum in org.eclipse.persistence.annotations
An enum that is used within the Cache annotation.
cachedConnection - Variable in class org.eclipse.persistence.sessions.server.ExternalConnectionPool
 
cachedExpression - Variable in class org.eclipse.persistence.descriptors.VersionLockingPolicy
 
cachedExpressionQueries - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PERF: Expression query call cache for avoiding regenerated dynamic query SQL.
cachedUpdateCalls - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PERF: Update call cache for avoiding regenerated update SQL.
cacheExpiryAndExpiryTimeOfDayBothSpecified(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cacheForeignKeyValues(Object, CacheKey, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: This method is used to store the FK values used for this mapping in the cachekey.
cacheForeignKeyValues(AbstractRecord, CacheKey, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: This method is used to store the FK values used for this mapping in the cachekey.
cacheHits - Static variable in class org.eclipse.persistence.tools.profiler.QueryMonitor
 
CacheHits - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
CacheId - Class in org.eclipse.persistence.internal.identitymaps
Defines a wrapper for a primary key (Id) to use as a key in the cache.
CacheId() - Constructor for class org.eclipse.persistence.internal.identitymaps.CacheId
 
CacheId(Object[]) - Constructor for class org.eclipse.persistence.internal.identitymaps.CacheId
 
CacheIdentityMap - Class in org.eclipse.persistence.internal.identitymaps
Purpose: A fixed size LRU cache
CacheIdentityMap(int, ClassDescriptor, AbstractSession, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.CacheIdentityMap
 
CacheIdentityMap_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
CacheIndex - Class in org.eclipse.persistence.descriptors
Purpose: Define a secondary index on the cache.
CacheIndex - Annotation Type in org.eclipse.persistence.annotations
Allow a cache index to be define.
CacheIndex() - Constructor for class org.eclipse.persistence.descriptors.CacheIndex
 
CacheIndex(String...) - Constructor for class org.eclipse.persistence.descriptors.CacheIndex
 
CacheIndex(List<DatabaseField>) - Constructor for class org.eclipse.persistence.descriptors.CacheIndex
 
CacheIndex(DatabaseField[]) - Constructor for class org.eclipse.persistence.descriptors.CacheIndex
 
cacheIndexes - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
cacheIndexes - Variable in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
A map of indexes on the cache.
CacheIndexes - Annotation Type in org.eclipse.persistence.annotations
Allow a set of cache indexes to be define on an Entity.
CacheInterceptor - Class in org.eclipse.persistence.sessions.interceptors
Purpose: Define a class through which Cache access can be intercepted.
CacheInterceptor - Annotation Type in org.eclipse.persistence.annotations
A CacheInterceptor can be set on an Entity and allows all EclipseLink cache access to be intercepted by the developer provided interceptor.
CacheInterceptor(IdentityMap, AbstractSession) - Constructor for class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
 
cacheInterceptorClass - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
cacheInterceptorClassName - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
cacheInvalidationPolicy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
CacheInvalidationPolicy - Class in org.eclipse.persistence.descriptors.invalidation
PUBLIC: A CacheInvalidationPolicy is used to set objects in TopLink's identity maps to be invalid following given rules.
CacheInvalidationPolicy() - Constructor for class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
 
cacheIsolation - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
CacheIsolationType - Enum in org.eclipse.persistence.config
Options for how Entity instances should be shared within an EclipseLink Persistence Unit / ServerSession
cacheKey - Variable in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
CacheKey - Class in org.eclipse.persistence.internal.identitymaps
Purpose: Container class for storing objects in an IdentityMap.
CacheKey() - Constructor for class org.eclipse.persistence.internal.identitymaps.CacheKey
Internal: Only used by subclasses that may want to wrap the cache key.
CacheKey(Object) - Constructor for class org.eclipse.persistence.internal.identitymaps.CacheKey
 
CacheKey(Object, Object, Object) - Constructor for class org.eclipse.persistence.internal.identitymaps.CacheKey
 
CacheKey(Object, Object, Object, long, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.CacheKey
 
CacheKeyInterceptor - Class in org.eclipse.persistence.sessions.interceptors
The CacheKeyInterceptor allows a Cache Interceptor implementation to wrap the EclipseLink CacheKey.
CacheKeyInterceptor(CacheKey) - Constructor for class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
cacheKeys - Variable in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Map of CacheKeys stored using their key.
cacheKeysIterator - Variable in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMapEnumeration
CacheKey instances iterator.
CacheKeyToThreadRelationships - Class in org.eclipse.persistence.internal.helper.type
 
CacheKeyToThreadRelationships(ConcurrencyManager) - Constructor for class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
Create a new CacheKeyToThreadRelationships.
cacheKeyType - Variable in class org.eclipse.persistence.descriptors.CachePolicy
Allow cache key type to be configured.
cacheKeyType() - Method in annotation type org.eclipse.persistence.annotations.PrimaryKey
(Optional) Configures what cache key type is used to store the object in the cache.
CacheKeyType - Enum in org.eclipse.persistence.annotations
Configures what type of Id value is used to store the object in the cache.
cacheMisses - Static variable in class org.eclipse.persistence.tools.profiler.QueryMonitor
 
CacheMisses - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
cacheMutex - Variable in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Ensure mutual exclusion depending on the cache isolation.
cacheNotSupportedWithEmbeddable(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cachePolicy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
CachePolicy - Class in org.eclipse.persistence.descriptors
Purpose: CachePolicy defines the cache configuration.
CachePolicy() - Constructor for class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Return a new descriptor.
cacheQueryResults() - Method in class org.eclipse.persistence.queries.ReadQuery
ADVANCED:
cacheQueryTimeout(AbstractSession, DatabaseCall) - Method in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
INTERNAL: This function caches the largest query timeout encountered within all the calls in this batch, or uses the parent timeout if one of the calls references the parent.
cacheResult(Object) - Method in class org.eclipse.persistence.queries.DataReadQuery
INTERNAL:
cacheResult(Object) - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL:
cacheResult(Object) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL:
cacheResult(Object) - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL:
cacheResult(Object) - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
INTERNAL:
cacheSize - Variable in class org.eclipse.persistence.descriptors.CacheIndex
Allows the cache size to be set.
CacheSize - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
cacheStatement() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Cache the prepared statements, this requires full parameter binding as well.
cacheSynchronizationType - Variable in class org.eclipse.persistence.descriptors.CachePolicy
Configures how objects will be sent via cache synchronization, if synchronization is enabled.
cacheSynchronizationType - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Used to store the type of cache synchronization used for this object This variable is set just before the change set is serialized.
cacheTransactionIsolation - Variable in class org.eclipse.persistence.sessions.DatasourceLogin
By default concurrency is optimized and the cache is not locked during reads or writes, This allows for concurrent reading and writing and should never cause any problems.
cacheType - Variable in class org.eclipse.persistence.descriptors.CacheIndex
Allows the identity map class type to be set.
cacheType - Variable in class org.eclipse.persistence.queries.QueryResultsCachePolicy
Allows the identity map class type to be set.
CacheType - Class in org.eclipse.persistence.config
Cache type persistence property values.
CacheType - Enum in org.eclipse.persistence.annotations
The CacheType enum is used with the Cache annotation for a persistent class.
CacheType() - Constructor for class org.eclipse.persistence.config.CacheType
 
cacheUsage - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Allow for the cache usage to be specified to enable in-memory querying.
CacheUsage - Class in org.eclipse.persistence.config
Cache usage hint values.
CacheUsage() - Constructor for class org.eclipse.persistence.config.CacheUsage
 
CacheUsageIndirectionPolicy - Class in org.eclipse.persistence.config
In-memory querying and conforming indirection policy.
CacheUsageIndirectionPolicy() - Constructor for class org.eclipse.persistence.config.CacheUsageIndirectionPolicy
 
Caching - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
calculateChanges(Object, Object, boolean, UnitOfWorkChangeSet, UnitOfWorkImpl, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: calculateChanges creates a change set for a particular object.
calculateChanges(Object, Object, boolean, UnitOfWorkChangeSet, UnitOfWorkImpl, ClassDescriptor, boolean) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: CalculateChanges creates a change set for an existing object.
calculateChanges(Map, UnitOfWorkChangeSet, boolean, boolean) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
INTERNAL: Changes are calculated on the client, so avoid recalculating them on the server.
calculateChanges(Map, UnitOfWorkChangeSet, boolean, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL:
calculateChangesForExistingObject(Object, UnitOfWorkChangeSet, UnitOfWorkImpl, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.descriptors.changetracking.AttributeChangeTrackingPolicy
INTERNAL: PERF: Calculate change for the existing object, avoids check for new since already know.
calculateChangesForExistingObject(Object, UnitOfWorkChangeSet, UnitOfWorkImpl, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: PERF: Calculate change for the new object, avoids check for new since already know.
calculateChangesForExistingObject(Object, UnitOfWorkChangeSet, UnitOfWorkImpl, ClassDescriptor, boolean) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: CalculateChanges creates a change set for an existing object.
calculateChangesForNewObject(Object, UnitOfWorkChangeSet, UnitOfWorkImpl, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: PERF: Calculate change for the new object, avoids check for new since already know.
calculateChangesForNewObject(Object, UnitOfWorkChangeSet, UnitOfWorkImpl, ClassDescriptor, boolean) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: CalculateChanges creates a change set for a new object.
calculateDeferredChanges(ChangeRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Used by AttributeLevelChangeTracking to update a changeRecord with calculated changes as apposed to detected changes.
calculateDeferredChanges(ChangeRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Used by AttributeLevelChangeTracking to update a changeRecord with calculated changes as apposed to detected changes.
calculateDeferredChanges(ChangeRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Used by AttributeLevelChangeTracking to update a changeRecord with calculated changes as apposed to detected changes.
calculateDeferredChanges(ChangeRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Used by AttributeLevelChangeTracking to update a changeRecord with calculated changes as opposed to detected changes.
calculateImports() - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
Parses the class definition, pulls out fully qualified class names, adds imports for them, and un-fully qualifies the class names.
calculateMappingDependencies() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
Add to each node the dependent nodes
calculateSpecifiedDependencies() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
Add to each node the dependent nodes
CALENDAR - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
calendarCache - Static variable in class org.eclipse.persistence.internal.helper.Helper
PERF: Used to cache a set of calendars for conversion/printing purposes.
calendarFromUtilDate(Date) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Calendar from a date.
call - Variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
call - Variable in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
Stores the call being created.
call - Variable in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
 
call - Variable in class org.eclipse.persistence.sessions.SessionEvent
Some events may have a call associated with them (pre/postExecuteCall).
call() - Method in interface org.eclipse.persistence.internal.security.PrivilegedAccessHelper.PrivilegedCallable
 
call() - Method in interface org.eclipse.persistence.internal.security.PrivilegedAccessHelper.PrivilegedExceptionCallable
 
Call - Interface in org.eclipse.persistence.queries
Call defines the interface used primarily by EclipseLink queries and query mechanisms to perform the necessary actions (read, insert, update, delete) on the data store.
callbackName - Variable in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
callByIndex() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredFunctionQuery
(Optional) Defines if the stored procedure should be called by index or by name.
callByIndex() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredProcedureQuery
(Optional) Defines if the stored procedure should be called by index or by name.
callCount - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Keep track of the number of concurrent active calls.
callDoPrivileged(PrivilegedAccessHelper.PrivilegedCallable<T>) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
INTERNAL Executes provided PrivilegedAccessHelper.PrivilegedCallable task using AccessController.doPrivileged(PrivilegedAction) when privileged access is enabled.
callDoPrivilegedWithException(PrivilegedAccessHelper.PrivilegedExceptionCallable<T>) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
INTERNAL Executes provided PrivilegedAccessHelper.PrivilegedExceptionCallable task using AccessController.doPrivileged(PrivilegedExceptionAction) when privileged access is enabled.
callDoPrivilegedWithException(PrivilegedAccessHelper.PrivilegedExceptionCallable<T>, PrivilegedAccessHelper.CallableExceptionSupplier<E>) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
INTERNAL Executes provided PrivilegedAccessHelper.PrivilegedExceptionCallable task using AccessController.doPrivileged(PrivilegedExceptionAction) when privileged access is enabled.
callDoPrivilegedWithException(PrivilegedAccessHelper.PrivilegedExceptionConsumer) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
INTERNAL Executes provided PrivilegedAccessHelper.PrivilegedExceptionConsumer task using AccessController.doPrivileged(PrivilegedExceptionAction) when privileged access is enabled.
callDoPrivilegedWithException(PrivilegedAccessHelper.PrivilegedExceptionConsumer, PrivilegedAccessHelper.CallableExceptionSupplier<E>) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
INTERNAL Executes provided PrivilegedAccessHelper.PrivilegedExceptionConsumer task using AccessController.doPrivileged(PrivilegedExceptionAction) when privileged access is enabled.
callDoPrivilegedWithThrowable(PrivilegedAccessHelper.PrivilegedExceptionCallable<T>) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
INTERNAL Executes provided PrivilegedAccessHelper.PrivilegedExceptionCallable task using AccessController.doPrivileged(PrivilegedExceptionAction) when privileged access is enabled.
callDoPrivilegedWithThrowable(PrivilegedAccessHelper.PrivilegedExceptionCallable<T>, PrivilegedAccessHelper.CallableThrowableSupplier<E>) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
INTERNAL Executes provided PrivilegedAccessHelper.PrivilegedExceptionCallable task using AccessController.doPrivileged(PrivilegedExceptionAction) when privileged access is enabled.
CALLED_METHOD_THREW_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
calledMethodThrewException(Method, Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
CallQueryMechanism - Class in org.eclipse.persistence.internal.queries
Purpose: Mechanism used for custom SQL and stored procedure queries.
CallQueryMechanism() - Constructor for class org.eclipse.persistence.internal.queries.CallQueryMechanism
 
CallQueryMechanism(DatabaseQuery) - Constructor for class org.eclipse.persistence.internal.queries.CallQueryMechanism
Initialize the state of the query
CallQueryMechanism(DatabaseQuery, DatabaseCall) - Constructor for class org.eclipse.persistence.internal.queries.CallQueryMechanism
Initialize the state of the query
calls - Variable in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Normally only a single call is used, however multiple table may require multiple calls on write.
callSequencingCallback() - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
 
canBatchWriteWithOptimisticLocking(DatabaseCall) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Supports Batch Writing with Optimistic Locking.
canBatchWriteWithOptimisticLocking(DatabaseCall) - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
canBatchWriteWithOptimisticLocking(DatabaseCall) - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
canBatchWriteWithOptimisticLocking(DatabaseCall) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Supports Batch Writing with Optimistic Locking.
canBeginTransaction_impl(Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return true if the status indicates that a transaction can be started.
canBeginTransaction_impl(Object) - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Return true if the status indicates that a transaction can be started.
canBind - Variable in class org.eclipse.persistence.internal.expressions.ConstantExpression
 
canBind - Variable in class org.eclipse.persistence.internal.expressions.ParameterExpression
'True' indicates this expression can bind parameters 'False' indicates this expression cannot bind parameters Defaults to 'null' to indicate specific no preference
canBind() - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: true indicates this expression can bind parameters false indicates this expression cannot bind parameters Defaults to null to indicate no specific preference
canBind() - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: true indicates this expression can bind parameters false indicates this expression cannot bind parameters Defaults to null to indicate no specific preference
canBuildCallWithReturning() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL Indicates whether the platform can build call with returning.
canBuildCallWithReturning() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Indicates whether the platform can build call with returning.
canBuildCallWithReturning() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Postgres has a returning clause.
canChangeReadOnlySet() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Checks whether the receiver has been used.
canCommitTransaction_impl(Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return true if the status indicates that a transaction can be committed.
canCommitTransaction_impl(Object) - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Return true if the status indicates that a transaction can be committed.
canDoCacheCheck() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
If the reference object is mapped thru one to one mapping and the object derives its primary key value from this relationship then remote value holder has a primary key row for.
canIssueSQLToDatabase_impl(Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return true if the status indicates that the SQL should be issued to the db.
canIssueSQLToDatabase_impl(Object) - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Return true if the status indicates that the SQL should be issued to the db.
canMergeUnitOfWork_impl(Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return true if the status indicates that the unit of work should be merged into the shared cache.
canMergeUnitOfWork_impl(Object) - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Return true if the status indicates that the unit of work should be merged into the shared cache.
CANNOT_ACCESS_FIELD_ON_OBJECT - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_ACCESS_METHOD_ON_OBJECT - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
CANNOT_ACCESS_METHOD_ON_OBJECT - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_ACQUIRE_CLIENTSESSION_FROM_SESSION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_ACQUIRE_DATA_SOURCE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_ACQUIRE_HISTORICAL_SESSION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_ADD_DESCRIPTORS_TO_SESSION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_ADD_DESCRIPTORS_TO_SESSION_BROKER - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_ADD_ELEMENT - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_ADD_ELEMENT_WITHOUT_KEY_TO_MAP - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_ADD_SEQUENCES_TO_SESSION_BROKER - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_ADD_TO_CONTAINER - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_CACHE_CURSOR_RESULTS_ON_QUERY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_CACHE_ISOLATED_DATA_ON_QUERY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_CACHE_PARTIAL_OBJECT - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_CAST_TO_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_COMMIT_AND_RESUME_UOW_WITH_MODIFY_ALL_QUERIES - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_COMMIT_UOW_AGAIN - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_COMPARE_TABLES_IN_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_COMPARE_TARGET_FOREIGN_KEYS_TO_NULL - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_CONFORM_AND_CACHE_QUERY_RESULTS - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_CONFORM_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_CONFORM_UNFETCHED_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_CREATE_CLONE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_CREATE_DYNAMIC_CONTEXT_FROM_CLASSES - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
CANNOT_CREATE_EXTERNAL_TRANSACTION_CONTROLLER - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_DELETE_READ_ONLY_OBJECT - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_DEPLOY_WITHOUT_PREDEPLOY - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
CANNOT_ENLIST_MULTIPLE_DATASOURCES - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
CANNOT_INITIALIZE_FROM_NODE - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
CANNOT_INSTANTIATE_EXCEPTIONHANDLER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_INSTANTIATE_PROFILER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_INSTANTIATE_SESSIONEVENTLISTENER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_INVOKE_METHOD_ON_CONFIG_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_LOGIN_TO_A_SESSION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_LOGOUT_OF_A_SESSION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_MODIFY_READ_ONLY_CLASSES_SET_AFTER_USING_UNIT_OF_WORK - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_MODIFY_SCHEMA_IN_SESSION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_PERFORM_OP_WITH_NULL_PARAM - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
CANNOT_PERFORM_OPERATION_ON_NULL_ARGUMENT - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
CANNOT_PERFORM_OPERATION_ON_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
CANNOT_PERSIST_MANAGED_OBJECT - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_PREDEPLOY - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
CANNOT_QUERY_ACROSS_VARIABLE_ONE_TO_ONE_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_REFRESH_EMF_CREATED_FROM_SESSION - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
CANNOT_REFRESH_METADATA - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
CANNOT_REGISTER_AGGREGATE_OBJECT_IN_UNIT_OF_WORK - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_REGISTER_SYNCHRONIZATIONLISTENER_FOR_UNITOFWORK - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
CANNOT_RELEASE_NON_CLIENTSESSION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_REMOVE_FROM_CONTAINER - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_REMOVE_FROM_READ_ONLY_CLASSES_IN_NESTED_UNIT_OF_WORK - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_RESUME_SYNCHRONIZED_UOW - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_SET_CONVERTER_FOR_NON_DIRECT_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
CANNOT_SET_CURSOR_FOR_PARAMETER_TYPE_OTHER_THAN_OUT - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_SET_DEFAULT_SEQUENCE_AS_DEFAULT - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_SET_PROPERTY_TYPE_ANNOTATION_IF_TARGET_DATATYPE_TRUE - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
CANNOT_SET_READ_POOL_SIZE_AFTER_LOGIN - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_SET_REPORT_QUERY_TO_CHECK_CACHE_ONLY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_TRANSLATE_UNPREPARED_CALL - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_UNWRAP_NON_MAP_MEMBERS - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CANNOT_USE_ID_VALUE_FOR_COMPOSITE_ID - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
CANNOT_WRITE_CHANGES_ON_NESTED_UNIT_OF_WORK - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CANNOT_WRITE_CHANGES_TWICE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotAccessFieldOnObject(Field, Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotAccessMethodOnObject(Method, Object) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
cannotAccessMethodOnObject(Method, Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotAcquireClientSessionFromSession() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotAcquireDataSource(Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotAcquireHistoricalSession() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotAddDescriptorsToSessionBroker() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotAddElement(Object, Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotAddElementWithoutKeyToMap(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotAddSequencesToSessionBroker() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotAddToContainer(Object, Object, ContainerPolicy) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotCacheCursorResultsOnQuery(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotCacheIsolatedDataOnQuery(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotCachePartialObjects(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotCastToClass(Object, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotCommitAndResumeSynchronizedUOW(UnitOfWorkImpl) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotCommitAndResumeUOWWithModifyAllQueries() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotCommitUOWAgain() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotCompareTablesInExpression(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotCompareTargetForeignKeysToNull(Expression, Object, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotConformAndCacheQueryResults(ReadQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotConformExpression() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotConformUnfetchedAttribute(String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotCreateClone(ContainerPolicy, Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotCreateDynamicContextFromClasses() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception is thrown if the user tries to create a new instance of DynamicJAXBContext using an array of actual classes.
cannotCreateExternalTransactionController(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotDeleteReadOnlyObject(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotDeployWithoutPredeploy(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
cannotHaveUnboundInOutputArguments() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotInitializeFromNode() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception is thrown if the user tries to create a new instance of DynamicJAXBContext using an Node, that is not an instance of either Document or Element.
cannotInstantiateExceptionHandlerClass(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotInstantiateProfilerClass(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotInstantiateSessionEventListenerClass(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotInvokeMethodOnConfigClass(String, String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotIssueModifyAllQueryWithOtherWritesWithinUOW() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotModifyReadOnlyClassesSetAfterUsingUnitOfWork() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotPerformOperationOnNullArgument(String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when trying to perform an operation with a null argument
cannotPerformOperationOnProperty(String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when trying to set a property via path based access.
cannotPerformOperationWithNullInputParameter(String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to call a method with a null input parameter
cannotPersistExistingObject(Object, AbstractSession) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotPredeploy(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
cannotQueryAcrossAVariableOneToOneMapping(DatabaseMapping, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotRefreshEntityManagerFactoryCreatedFromSession(String) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
cannotRefreshMetadata() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
cannotRegisterAggregateObjectInUnitOfWork(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotRegisterSynchronizatonListenerForUnitOfWork(Exception) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
cannotReleaseNonClientSession() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotRemoveFromContainer(Object, Object, ContainerPolicy) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotRemoveFromReadOnlyClassesInNestedUnitOfWork() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotSetConverterForNonDirectMapping(ClassDescriptor, DatabaseMapping, String) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
cannotSetCursorForParameterTypeOtherThanOut(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotSetDefaultSequenceAsDefault(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotSetListenerClasses(Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotSetReadPoolSizeAfterLogin() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotSetShouldCheckCacheOnlyOnReportQuery() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotTranslateUnpreparedCall(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
cannotUnwrapNonMapMembers(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cannotUseIdValueForCompositeId(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
cannotWriteChangesTwice() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
CANONICAL_MODEL_GENERATE_COMMENTS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.canonicalmodel.generate_comments" optional property can be used to disable usage of comments in declaration of Generated annotation.
CANONICAL_MODEL_GENERATE_COMMENTS_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Default value for the "eclipselink.canonicalmodel.generate_comments" optional property.
CANONICAL_MODEL_GENERATE_GENERATED - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.canonicalmodel.use_generated" optional property can be used to disable generation of Generated annotation.
CANONICAL_MODEL_GENERATE_GENERATED_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Default value for the "eclipselink.canonicalmodel.use_generated" optional property.
CANONICAL_MODEL_GENERATE_TIMESTAMP - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.canonicalmodel.generate_timestamp" optional property can be used to disable usage of date in declaration of Generated annotation.
CANONICAL_MODEL_GENERATE_TIMESTAMP_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Default value for the "eclipselink.canonicalmodel.generate_timestamp" optional property.
CANONICAL_MODEL_LOAD_XML - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.canonicalmodel.load_xml" optional property can be used a performance enhancement between compile rounds.
CANONICAL_MODEL_LOAD_XML_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Default value for the "eclipselink.canonicalmodel.load_xml" optional property.
CANONICAL_MODEL_PREFIX - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.canonicalmodel.prefix" optional property specifies the prefix that will be added to the start of the class name of any canonical model class generated.
CANONICAL_MODEL_PREFIX_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Default prefix that will be added to the start of the class name of any canonical model class generated.
CANONICAL_MODEL_SUB_PACKAGE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.canonicalmodel.subpackage" optional property specifies a sub-package name that can be used to have the canonical model generator generate its classes in a sub-package of the package where the corresponding entity class is located.
CANONICAL_MODEL_SUB_PACKAGE_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Default sub-package name that is used to have the canonical model generator generate its classes in a sub-package of the package where the corresponding entity class is located.
CANONICAL_MODEL_SUFFIX - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.canonicalmodel.suffix" optional property specifies the suffix that will be added to the end of the class name of any canonical model class generated.
CANONICAL_MODEL_SUFFIX_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Default suffix that will be added to the end of the class name of any canonical model class generated.
CANONICAL_MODEL_USE_STATIC_FACTORY - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.canonicalmodel.use_static_factory" optional property can be used a performance enhancement between compile rounds within an IDE.
CANONICAL_MODEL_USE_STATIC_FACTORY_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Default value for the "eclipselink.canonicalmodel.use_static_factory" optional property.
canRollbackTransaction_impl(Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return true if the status indicates that a transaction can be rolled back.
canRollbackTransaction_impl(Object) - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Return true if the status indicates that a transaction can be rolled back.
CANT_HAVE_UNBOUND_IN_OUTPUT_ARGUMENTS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
canUnwrapOracleConnection() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Indicates whether this Oracle platform can unwrap Oracle connection.
capacity() - Method in class org.eclipse.persistence.indirection.IndirectList
 
capacity() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
cascade() - Method in annotation type org.eclipse.persistence.annotations.OptimisticLocking
(Optional) Specify where the optimistic locking policy should cascade lock.
cascade() - Method in annotation type org.eclipse.persistence.annotations.VariableOneToOne
(Optional) The operations that must be cascaded to the target of the association.
CASCADE_ALL_PARTS - Static variable in class org.eclipse.persistence.internal.sessions.MergeManager
 
CASCADE_ALL_PARTS - Static variable in class org.eclipse.persistence.sessions.CopyGroup
Depth level indicating that all relationships with mappings should be used when building the copied object graph
CASCADE_BY_MAPPING - Static variable in class org.eclipse.persistence.internal.sessions.MergeManager
 
CASCADE_PRIVATE_PARTS - Static variable in class org.eclipse.persistence.internal.sessions.MergeManager
 
CASCADE_PRIVATE_PARTS - Static variable in class org.eclipse.persistence.sessions.CopyGroup
Depth level indicating that only relationships with mapping indicated privately- owned should be copied
CASCADE_TREE - Static variable in class org.eclipse.persistence.sessions.CopyGroup
Depth level indicating that only the attributes found in the attribute group should be copied
CascadeAggregateDelete - Static variable in class org.eclipse.persistence.queries.DatabaseQuery
 
cascadeAllParts() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Cascade all parts, this is the default for the merge.
cascadeAllParts() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Cascade the query and its properties on the queries object(s) and all objects related to the queries object(s).
cascadeAllParts() - Method in class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: Set if the copy should cascade all relationships when copying the object(s).
CascadeAllParts - Static variable in class org.eclipse.persistence.config.CascadePolicy
 
CascadeAllParts - Static variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
CascadeAllParts - Static variable in class org.eclipse.persistence.queries.DatabaseQuery
 
cascadeByMapping() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Cascade the query and its properties on the queries object(s) and all related objects where the mapping has been set to cascade the merge.
CascadeByMapping - Static variable in class org.eclipse.persistence.config.CascadePolicy
 
CascadeByMapping - Static variable in class org.eclipse.persistence.queries.DatabaseQuery
 
cascadeCondition - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
CascadeCondition() - Constructor for class org.eclipse.persistence.internal.descriptors.DescriptorIterator.CascadeCondition
Default constructor.
cascadeDeleteObjects - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Set of objects that were deleted by database cascade delete constraints.
CascadeDependentParts - Static variable in class org.eclipse.persistence.queries.DatabaseQuery
 
cascadeDepth - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
cascadeDetach - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
 
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, boolean, Set) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Cascade discover and persist new objects during commit to the map key
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, boolean, Set) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Cascade discover and persist new objects during commit to the map key.
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, boolean, Set) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Cascade discover and persist new objects during commit to the map key
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, boolean, Set) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Cascade discover and persist new objects during commit.
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, Set) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Cascade discover and persist new objects during commit.
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, Set) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Cascade DiscoverAndPersistUnregisteredNewObjects to any mappings managed by the container policy.
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, Set) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Cascade discover and persist new objects during commit to the map key
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, Set) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Cascade discover and persist new objects during commit.
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, Set) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Cascade discover and persist new objects during commit.
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, Set) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Cascade discover and persist new objects during commit.
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, Set) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Cascade discover and persist new objects during commit.
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, Set) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Cascade discover and persist new objects during commit.
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, Set) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Cascade discover and persist new objects during commit.
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, Set) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: Cascade discover and persist new objects during commit.
cascadeDiscoverAndPersistUnregisteredNewObjects(Object, Map, Map, Map, UnitOfWorkImpl, Set) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Cascade discover and persist new objects during commit.
cascadedLockingInitialized - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: flag to indicate the initialization state of cascade locking for this descriptor
cascadeLockingPolicies - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
CascadeLockingPolicy - Class in org.eclipse.persistence.internal.descriptors
INTERNAL:
CascadeLockingPolicy(ClassDescriptor, ClassDescriptor) - Constructor for class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
INTERNAL:
cascadeMerge - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
 
cascadeOnDelete() - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
PUBLIC: Enables delete cascading on the database.
CascadeOnDelete - Annotation Type in org.eclipse.persistence.annotations
Define the foreign key defined by the relationship to cascade the delete on the database.
cascadeOnlyDependentParts() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Used by unit of work, only cascades constraint dependencies.
cascadePerformRemove(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: This method is used by the UnitOfWork to cascade registration of new objects.
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Cascade performRemove to any mappings managed by the container policy.
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Cascade registerNew to any mappings managed by the container policy.
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL: Cascade perform delete through mappings that require the cascade.
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Cascade perform delete through mappings that require the cascade.
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map, boolean) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map, boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Cascade perform delete through mappings that require the cascade.
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map, boolean) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Cascade perform delete through mappings that require the cascade
cascadePerformRemoveIfRequired(Object, UnitOfWorkImpl, Map, boolean) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Cascade remove through mappings that require the cascade.
cascadePerformRemovePrivateOwnedObjectFromChangeSet(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: This method is used to iterate over the specified object's mappings and cascade remove orphaned private owned objects from the UnitOfWorkChangeSet and IdentityMap.
cascadePerformRemovePrivateOwnedObjectFromChangeSetIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Cascade perform removal of orphaned private owned objects from the UnitOfWorkChangeSet
cascadePerformRemovePrivateOwnedObjectFromChangeSetIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Cascade perform removal of orphaned private owned objects from the UnitOfWorkChangeSet
cascadePerformRemovePrivateOwnedObjectFromChangeSetIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Cascade perform removal of orphaned private owned objects from the UnitOfWorkChangeSet
cascadePerformRemovePrivateOwnedObjectFromChangeSetIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Cascade removal of orphaned private owned objects from the UnitOfWorkChangeSet
cascadePerformRemovePrivateOwnedObjectFromChangeSetIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Cascade perform removal of orphaned private owned objects from the UnitOfWorkChangeSet
cascadePerformRemovePrivateOwnedObjectFromChangeSetIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Cascade removal of orphaned private owned objects from the UnitOfWorkChangeSet
cascadePersist - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Cascading flags used by the EntityManager
cascadePolicy - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
Policy that determines how the merge will cascade to its object's parts.
cascadePolicy - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Policy that determines how the query will cascade to its object's parts.
CascadePolicy - Class in org.eclipse.persistence.config
Cascade policy hint values.
CascadePolicy() - Constructor for class org.eclipse.persistence.config.CascadePolicy
 
cascadePrivateParts() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Cascade private parts, this can be used to merge clone when using RMI.
cascadePrivateParts() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Cascade the query and its properties on the queries object(s) and all privately owned objects related to the queries object(s).
cascadePrivateParts() - Method in class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: Set if the copy should cascade only those relationships that are configured as privately-owned.
CascadePrivateParts - Static variable in class org.eclipse.persistence.config.CascadePolicy
 
CascadePrivateParts - Static variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
CascadePrivateParts - Static variable in class org.eclipse.persistence.queries.DatabaseQuery
 
cascadeRefresh - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
 
cascadeRegisterNewForCreate(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: This method is used by the UnitOfWork to cascade registration of new objects.
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Cascade registerNew to any mappings managed by the container policy.
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Cascade registerNew to any mappings managed by the container policy.
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade.
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade.
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map, boolean) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map, boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade.
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map, boolean) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRegisterNewIfRequired(Object, UnitOfWorkImpl, Map, boolean) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Cascade registerNew for Create through mappings that require the cascade
cascadeRemove - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
 
cascadeTree() - Method in class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: Set if the copy should cascade only those attributes that are found in the group.
Case - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
CaseCondition - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
caseConditionOperator() - Method in class org.eclipse.persistence.platform.database.DB2Platform
DB2 does not allow untyped parameter binding for the THEN & ELSE 'result-expressions' of CASE expressions
caseConditionStatement() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Creates an ArgumentListFunctionExpression that is capable of creating a case statement of the form:
caseConditionStatement() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
caseConditionStatement(Map<Expression, Object>, Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function Convert values returned by the query to values given in the caseConditions Map.
caseOperator() - Method in class org.eclipse.persistence.platform.database.DB2Platform
DB2 does not allow untyped parameter binding for the THEN & ELSE 'result-expressions' of CASE expressions
caseStatement() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Creates an ArgumentListFunctionExpression that is capable of creating a case statement of the form:
caseStatement() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
caseStatement(Map, Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function Convert values returned by the query to values given in the caseItems Map.
cast() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
cast(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Cast the value to the database type.
Cast - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
CAST_MUST_USE_INHERITANCE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
castClass - Variable in class org.eclipse.persistence.internal.expressions.ObjectExpression
Allow an expression node to be cast to a subclass or implementation class.
castMustUseInheritance(Expression) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
castSizeForVarcharParameter - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
used for casting of input parameters in certain DBs
catalog() - Method in annotation type org.eclipse.persistence.annotations.CollectionTable
Deprecated.
(Optional) The catalog of the table.
catalog() - Method in annotation type org.eclipse.persistence.annotations.Index
The catalog of the INDEX
catchExceptions() - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: This method is used for catching all the Descriptor Exceptions
CATEGORY_LOGGING_LEVEL_ - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property prefix "eclipselink.logging.level." allows the category specific logging levels to be specified.
caughtExceptions - Variable in class org.eclipse.persistence.exceptions.IntegrityChecker
To add all the Descriptor exceptions
cciConnection - Variable in class org.eclipse.persistence.eis.EISAccessor
 
cdata(String) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
cdata(String) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
INTERNAL:
cdata(String) - Method in class org.eclipse.persistence.oxm.record.FormattedOutputStreamRecord
INTERNAL:
cdata(String) - Method in class org.eclipse.persistence.oxm.record.FormattedWriterRecord
INTERNAL:
cdata(String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
cdata(String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
cdata(String) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Receive notification of character data to be wrapped in a CDATA node.
cdata(String) - Method in class org.eclipse.persistence.oxm.record.NodeRecord
 
cdata(String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL:
cdata(String) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
cdata(String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL:
cdata(String) - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
cdata(String) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
CDATA - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
CDI_BEANMANAGER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.bean.manager" property is used to set CDI BeanManager when available
ceil() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
ceil(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Ceil - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
changed - Variable in class org.eclipse.persistence.expressions.ListExpressionOperator
 
CHANGED_COLUMNS - org.eclipse.persistence.annotations.OptimisticLockingType
Using this type of locking policy compares only the changed fields in the WHERE clause when doing an update.
changeDescriptor(AbstractSession) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: The reference class has been changed, need to reset the descriptor.
ChangedFieldsLockingPolicy - Class in org.eclipse.persistence.descriptors
Purpose: An implementation of the OptimisticLockingPolicy interface.
ChangedFieldsLockingPolicy() - Constructor for class org.eclipse.persistence.descriptors.ChangedFieldsLockingPolicy
PUBLIC: Create a new changed fields locking policy.
changedIndexes - Variable in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
Used only in case listOrderField != null in the mapping.
changedObject - Variable in class org.eclipse.persistence.internal.sessions.AggregateChangeRecord
 
changedValues - Variable in class org.eclipse.persistence.internal.sessions.AggregateCollectionChangeRecord
 
changeOrderTargetQuery - Variable in class org.eclipse.persistence.mappings.CollectionMapping
Query used when order of list members is changed.
changePolicy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
ChangeRecord - Class in org.eclipse.persistence.internal.sessions
Purpose: This class was designed as a superclass to all possible Change Record types.
ChangeRecord - Interface in org.eclipse.persistence.sessions.changesets
Purpose: Define the base Change Record API.
ChangeRecord() - Constructor for class org.eclipse.persistence.internal.sessions.ChangeRecord
 
changes - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
This is the collection of changes
Changes - Static variable in class org.eclipse.persistence.config.CommitOrderType
Updates are ordered by the object's changes, then by id.
CHANGES - org.eclipse.persistence.sessions.UnitOfWork.CommitOrderType
Updates are ordered by the object's changes, then by id.
CHANGES_INTO_DISTRIBUTED_CACHE - Static variable in class org.eclipse.persistence.internal.sessions.MergeManager
 
changeSet - Variable in class org.eclipse.persistence.descriptors.DescriptorEvent
For the post merge event it is possible that there has been a change set generated.
changeSet - Variable in class org.eclipse.persistence.sessions.coordination.MergeChangeSetCommand
The changes to be applied remotely
changeSetDeleteNullQuery - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
changeSetDeleteQuery - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
Used for deletion when ChangeSets are used
ChangeSetsNotProcessed - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
ChangeSetsProcessed - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
changeTrackedHardList - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
ChangeTracker - Interface in org.eclipse.persistence.descriptors.changetracking
Purpose: Define an interface for any object that wishes to use attribute change tracking.
ChangeTracker_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
ChangeTracking - Annotation Type in org.eclipse.persistence.annotations
The ChangeTracking annotation is used to specify the org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy which computes changes sets for EclipseLink's UnitOfWork commit process.
ChangeTrackingType - Enum in org.eclipse.persistence.annotations
An enum that is used within the ChangeTracking annotation.
changeType - Variable in class org.eclipse.persistence.descriptors.changetracking.CollectionChangeEvent
INTERNAL: Change type is either add or remove
CHANNEL_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
CHAR - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
CHAR_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
characterEscapeHandler - Variable in class org.eclipse.persistence.oxm.record.JsonRecord
 
characterEscapeHandler - Variable in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
CharacterEscapeHandler - Interface in org.eclipse.persistence.internal.oxm
Provide an interface to allow for custom character escaping behaviour.
CharacterEscapeHandler - Interface in org.eclipse.persistence.oxm
Provide an interface to allow for custom character escaping behaviour.
CharacterEscapeHandlerWrapper - Class in org.eclipse.persistence.internal.oxm.record
INTERNAL:
CharacterEscapeHandlerWrapper(Object) - Constructor for class org.eclipse.persistence.internal.oxm.record.CharacterEscapeHandlerWrapper
 
characters(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
characters(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
characters(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.record.BinaryDataUnmarshalRecord
 
characters(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
characters(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.record.UnmappedContentHandlerWrapper
 
characters(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
characters(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
characters(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
characters(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.unmapped.DefaultUnmappedContentHandler
 
characters(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryAttachmentHandler
 
characters(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.XMLInlineBinaryHandler
 
characters(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
characters(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
characters(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
characters(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
characters(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
characters(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.XMLRootRecord
 
characters(char[], int, int) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
characters(CharSequence) - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
characters(CharSequence) - Method in interface org.eclipse.persistence.internal.oxm.record.ExtendedContentHandler
 
characters(CharSequence) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
characters(CharSequence) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
characters(CharSequence) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
characters(CharSequence) - Method in class org.eclipse.persistence.internal.oxm.XMLInlineBinaryHandler
 
characters(CharSequence) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
characters(CharSequence) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
characters(CharSequence) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
characters(CharSequence) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
characters(CharSequence) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
characters(CharSequence) - Method in class org.eclipse.persistence.oxm.record.XMLRootRecord
 
characters(CharSequence) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
characters(String) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
characters(String) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
INTERNAL:
characters(String) - Method in class org.eclipse.persistence.oxm.record.FormattedOutputStreamRecord
INTERNAL:
characters(String) - Method in class org.eclipse.persistence.oxm.record.FormattedWriterRecord
INTERNAL:
characters(String) - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
INTERNAL:
characters(String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
characters(String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
characters(String) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Receive notification of character data.
characters(String) - Method in class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL:
characters(String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL:
characters(String) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
characters(String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL:
characters(String) - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
characters(String) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
characters(String, boolean, boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
characters(QName, Object, String, boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
characters(QName, Object, String, boolean) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
characters(QName, Object, String, boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
characters(QName, Object, String, boolean) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Convert the value if necessary and write out the converted value.
characters(QName, Object, String, boolean, boolean) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
characters(QName, Object, String, boolean, boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
characters(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.ChoiceUnmarshalContext
 
characters(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectUnmarshalContext
 
characters(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedUnmarshalContext
 
characters(UnmarshalRecord) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalContext
An event indicating that characters has been called on the unmarshalRecord.
charactersAllowed - Variable in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
charAt(int) - Method in class org.eclipse.persistence.internal.oxm.StrBuffer
 
charIndex() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
CharIndex - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
charLength() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
charLength() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Obtains the number of characters in the data string value expression.
Builds Symfoware equivalent to length(string_exp).
Symfoware: CHAR_LENGTH(string_exp)
CharLength - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
CHARSET - Static variable in class org.eclipse.persistence.internal.oxm.XPathFragment
 
CHECK_CACHE - org.eclipse.persistence.annotations.ExistenceType
Assume that if the objects primary key does not include null and it is in the cache, then it must exist.
CHECK_DATABASE - org.eclipse.persistence.annotations.ExistenceType
Perform does exist check on the database.
CHECK_EXISTENCE - Static variable in class org.eclipse.persistence.tools.schemaframework.TableCreator
Flag to disable table existence check before create.
CHECK_INVALIDATION_POLICY - Static variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
The following constants are used for the invalidationState variable
checkAndLockObject(Object, Map, Map, DatabaseMapping, AbstractSession) - Method in class org.eclipse.persistence.internal.helper.WriteLockManager
INTERNAL: Simply check that the object is not already locked then pass it on to the locking method
checkAndRefreshInvalidObject(Object, CacheKey, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Check if the object is invalid and refresh it.
checkAssignable(Class<?>) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
 
CheckCache - Static variable in class org.eclipse.persistence.queries.DoesExistQuery
 
checkCacheByExactPrimaryKey() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: The cache will be checked only if the query contains exactly the primary key.
CheckCacheByExactPrimaryKey - Static variable in class org.eclipse.persistence.config.CacheUsage
Configure the cache to be checked first if the query is by primary key (only).
CheckCacheByExactPrimaryKey - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
checkCacheByIndex(Expression, AbstractRecord, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Lookup the expression in the cache if it contains any indexes.
checkCacheByPrimaryKey() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: This is the default, the cache will be checked only if the query contains the primary key.
CheckCacheByPrimaryKey - Static variable in class org.eclipse.persistence.config.CacheUsage
Configure the cache to be checked first if the query contains the primary key.
CheckCacheByPrimaryKey - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
checkCacheFirst - Variable in class org.eclipse.persistence.queries.DoesExistQuery
Flag to determine if the cache should be check first in addition to another option.
checkCacheForBatchKey(AbstractRecord, Object, Map, ReadQuery, ObjectLevelReadQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Check if the target object is in the cache if possible based on the source row.
checkCacheForBatchKey(AbstractRecord, Object, Map, ReadQuery, ObjectLevelReadQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Check if the target object is in the cache if possible based on the target key value.
checkCacheForDoesExist() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Default behavior.
checkCacheForDoesExist() - Method in class org.eclipse.persistence.queries.DoesExistQuery
PUBLIC: Assume that if the objects primary key does not include null and it is in the cache, then is must exist.
checkCacheForDoesExist() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Switch all descriptors to check the cache for existence.
checkCacheForObject(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Perform a cache lookup for the query.
checkCacheForObject(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Perform a cache lookup for the query This is only called from read object query.
checkCacheOnly() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: The cache will checked completely, if the object is not found null will be returned or an error if the query is too complex.
CheckCacheOnly - Static variable in class org.eclipse.persistence.config.CacheUsage
Configure the cache to be searched for any matching objects.
CheckCacheOnly - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
checkCacheThenDatabase() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: The cache will be checked completely, then if the object is not found or the query too complex the database will be queried.
CheckCacheThenDatabase - Static variable in class org.eclipse.persistence.config.CacheUsage
Configure the cache to be searched for any matching object before accesing the database.
CheckCacheThenDatabase - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
checkCleanup() - Method in class org.eclipse.persistence.internal.identitymaps.WeakIdentityMap
Check if garbage collected cache keys need to be cleaned up.
checkCleanup() - Method in class org.eclipse.persistence.internal.identitymaps.WeakUnitOfWorkIdentityMap
Check if garbage collected cache keys need to be cleaned up.
checkConnections - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
checkCustomQueryFlag(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Check and return custom query flag.
checkCustomQueryFlag(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Check and return custom query flag.
checkCustomQueryFlag(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Check and return custom query flag.
checkDatabase() - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: This method is used to check the database tables.
checkDatabase(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
To check that tables and fields are present in database
CheckDatabase - Static variable in class org.eclipse.persistence.queries.DoesExistQuery
 
checkDatabaseForDoesExist() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Perform does exist check on the database
checkDatabaseForDoesExist() - Method in class org.eclipse.persistence.queries.DoesExistQuery
PUBLIC: Perform does exist check on the database through selecting the primary key.
checkDatabaseForDoesExist() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Switch all descriptors to check the database for existence.
checkDatabaseIfInvalid - Variable in class org.eclipse.persistence.queries.DoesExistQuery
Flag to determine cache invalidation policy support.
checkDeferredLock() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Check the lock state, if locked, acquire and release a deferred lock.
checkDeferredLock() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Check the deferred lock on the cache key object.
checkDeferredLock() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
checkDescriptor(Object, AbstractSession) - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Ensure that the descriptor has been set.
checkDescriptor(AbstractSession) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Ensure that the descriptor has been set.
checkDescriptor(AbstractSession) - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
INTERNAL: Ensure that the descriptor has been set.
checkDescriptor(AbstractSession) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Ensure that the descriptor has been set.
checkDescriptor(AbstractSession) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Ensure that the descriptor has been set.
checkDumpTime() - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
Log the results after a set amount of time has passed.
checkDumpTime() - Static method in class org.eclipse.persistence.tools.profiler.QueryMonitor
 
checkEarlyReturn(Object, Object, AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Check if existence can be determined without going to the database.
checkEarlyReturn(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Check to see if this query already knows the return value without performing any further work.
checkEarlyReturn(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Check if existence can be determined without going to the database.
checkEarlyReturn(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Check to see if this query already knows the return value without performing any further work.
checkEarlyReturnLocal(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Contains the body of the check early return call, implemented by subclasses.
checkEarlyReturnLocal(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: The cache check is done before the prepare as a hit will not require the work to be done.
checkEarlyReturnLocal(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: The cache check is done before the prepare as a hit will not require the work to be done.
checkEarlyReturnLocal(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: The cache check is done before the prepare as a hit will not require the work to be done.
checkEclipseLinkCache(DatabaseQuery, DataRecord, Session) - Static method in class org.eclipse.persistence.queries.QueryRedirectorHelper
This method will cause EclipseLink to check the EclipseLink cache for the object.
checkExistence(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Register the object and return the clone if it is existing otherwise return null if it is new.
checkForCustomQuery(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Check to see if a custom query should be used for this query.
checkForCustomQuery(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.DeleteObjectQuery
INTERNAL: Check to see if a custom query should be used for this query.
checkForCustomQuery(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.InsertObjectQuery
INTERNAL: Check to see if a custom query should be used for this query.
checkForCustomQuery(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Check to see if a custom query should be used for this query.
checkForCustomQuery(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Check to see if a custom query should be used for this query.
checkForCustomQuery(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.UpdateObjectQuery
INTERNAL: Check to see if a custom query should be used for this query.
checkForeignKeyJoinOptimization(Expression, Expression, ExpressionNormalizer) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
PERF: Optimize out unnecessary joins.
checkForInheritance(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
This method is used to resolve the inheritance issues arisen when conforming from the identity map 1.
checkForInheritance(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
This method is used to resolve the inheritance issues arise while trying to get object from identity map of parent session.
checkForUnregisteredExistingObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if the object is an existing object (but has not been registered), or a new object (that has not be persisted).
checkHierarchyForDescriptor(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
Check to see if the descriptor of a superclass can be used to describe this class
checkHierarchyForDescriptor(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
Check to see if the descriptor of a superclass can be used to describe this class By default, in JPA, classes must have specific descriptors to be considered entities In this implementation, we check whether the inheritance policy has been configured to allow superclass descriptors to describe subclasses that do not have a descriptor themselves
checkIfAlreadyRegistered(Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the value of the object if it already is registered, otherwise null.
checkIfExist(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.SequenceDefinition
INTERAL: Verify whether the sequence exists.
checkIfExist(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.SequenceObjectDefinition
INTERNAL: Check if the sequence object already exists, in which case dont create it.
checkIfExist(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
INTERAL: Execute the SQL required to insert the sequence row into the sequence table.
checkIfExist(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.UnaryTableSequenceDefinition
INTERAL: Verify whether the sequence exists.
checkInheritanceTreeAggregateSettings(AbstractSession, AggregateMapping) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Verify that an aggregate descriptor's inheritance tree is full of aggregate descriptors.
checkInstantiationPolicy() - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: This method is used to check the InstantiationPolicy.
checkIsCacheAccessPreCheckRequired() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
PERF: Used to micro optimize cache access.
checkJoinForSubSelectWithParent(ExpressionNormalizer, Expression, List<Expression>) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Check if new expression need to be created for sub queries and re-normalized.
checkNewObjectLockVersion(Object, Object, ClassDescriptor, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Check if the new object's version has been set, if so, then it was an existing object that was deleted.
checkPlatform() - Method in class org.eclipse.persistence.platform.server.glassfish.GlassfishPlatformDetector
 
checkPlatform() - Method in class org.eclipse.persistence.platform.server.NoServerPlatformDetector
 
checkPlatform() - Method in interface org.eclipse.persistence.platform.server.ServerPlatformDetector
 
checkPlatform() - Method in class org.eclipse.persistence.platform.server.was.WebSpherePlatformDetector
 
checkPlatform() - Method in class org.eclipse.persistence.platform.server.wls.WebLogicPlatformDetector
 
checkPrepare(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Check to see if this query needs to be prepare and prepare it.
checkPrepare(AbstractSession, AbstractRecord, boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Check to see if this query needs to be prepare and prepare it.
checkPrepare(AbstractSession, AbstractRecord, boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Check to see if this query needs to be prepare and prepare it.
checkPrePrepare(AbstractSession) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: ObjectLevelReadQueries now have an explicit pre-prepare stage, which is for checking for pessimistic locking, and computing any joined attributes declared on the descriptor.
checkReadLock() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Check the lock state, if locked, acquire and release a read lock.
checkReadLock() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Check the read lock on the cache key object.
checkReadLock() - Method in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
Avoid acquiring locks for unit of work.
checkReadLock() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
checkSet(String, Object) - Method in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
 
checkSet(String, Object) - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
Ensure the value being set is supported by the mapping.
checkTable(DatabaseTable, AbstractSession) - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
INTERNAL: This method checks that tables are present in the database.
checkTableExists(DatabaseSessionImpl, TableDefinition, boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Executes and evaluates query to check whether given table exists.
checkTableExists(DatabaseSessionImpl, TableDefinition, boolean) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Executes and evaluates query to check whether given table exists.
checkTableExists(DatabaseSessionImpl, TableDefinition, boolean) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Executes and evaluates query to check whether given table exists.
checkTableExists(TableDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Check if the table exists by issuing a query.
checkTableExists(TableDefinition, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Check if the table exists by issuing a query.
checkTransactionIsolation(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Check to see if the transaction isolation needs to be set for the newly created connection.
checkValues() - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
Reset the fields and values from the arrays.
checkValues() - Method in class org.eclipse.persistence.internal.sessions.ResultSetRecord
Reset the fields and values from the arrays.
checkWastedVersioning(AbstractRecord, DatabaseTable) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL: Checks for the case where an object has multiple tables but only some are part of a minimal update.
CHILD_DESCRIPTORS_DO_NOT_HAVE_IDENTITY_MAP - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CHILD_DOES_NOT_DEFINE_ABSTRACT_QUERY_KEY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
CHILD_TO_PARENT - org.eclipse.persistence.queries.ReadAllQuery.Direction
Hierarchy will be traversed from child to parent - PRIOR keyword is generated on the right side of the equation
childDescriptors - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
childDescriptors - Variable in class org.eclipse.persistence.descriptors.InterfacePolicy
 
childDescriptorsDoNotHaveIdentityMap() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
childDoesNotDefineAbstractQueryKeyOfParent(ClassDescriptor, ClassDescriptor, String) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
children - Variable in class org.eclipse.persistence.internal.codegen.HierarchyNode
 
children - Variable in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
childrenJoinExpression - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
childrenTables - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
childrenTablesJoinExpressions - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
Choice - Class in org.eclipse.persistence.internal.oxm.schema.model
Purpose: Class to represent a Choice in a Schema
Choice() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
ChoiceCollectionMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​CONVERTER extends CoreConverter,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​SESSION extends CoreSession,​UNMARSHALLER extends Unmarshaller,​XML_FIELD extends Field,​XML_MAPPING extends Mapping,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
ChoiceObjectMapping<ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​ABSTRACT_SESSION extends CoreAbstractSession,​CONTAINER_POLICY extends CoreContainerPolicy,​CONVERTER extends CoreConverter,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​SESSION extends CoreSession,​UNMARSHALLER extends Unmarshaller,​XML_FIELD extends Field,​XML_MAPPING extends Mapping,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
ChoiceUnmarshalContext - Class in org.eclipse.persistence.internal.oxm
Allow the unmarshal context to be wrapped.
ChoiceUnmarshalContext(UnmarshalContext, XMLConverterMapping) - Constructor for class org.eclipse.persistence.internal.oxm.ChoiceUnmarshalContext
 
chr() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
chr(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Chr - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
CIRCULAR_MAPPED_BY_REFERENCES - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
circularMappedByReferences(Object, String, Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
CLASS - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
CLASS_EXTRACTION_METHOD_MUST_BE_STATIC - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
CLASS_EXTRACTOR_CAN_NOT_BE_SPECIFIED_WITH_DISCRIMINATOR - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CLASS_FILE_TRANSFORMER_THROWS_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CLASS_INDICATOR_FIELD_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
CLASS_INSTANCE - Static variable in annotation type org.eclipse.persistence.annotations.Convert
Constant name for the reserved class instance converter.
CLASS_LIST_MUST_NOT_BE_NULL - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CLASS_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
CLASS_NOT_FOUND_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
CLASS_NOT_FOUND_FOR_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
CLASS_NOT_FOUND_WHILE_CONVERTING_CLASSNAMES - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CLASS_NOT_FOUND_WHILE_PROCESSING_ANNOTATIONS - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
CLASS_NOT_FOUND_WHILE_USING_QUERY_HINT - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CLASS_NOT_LISTED_IN_PERSISTENCE_UNIT - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CLASS_OR_CLASS_DESCRIPTOR_COULD_NOT_BE_FOUND - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
CLASS_PK_DOES_NOT_EXIST_IN_CACHE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CLASS_TYPE - Static variable in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
ClassConstants - Class in org.eclipse.persistence.internal.helper
INTERNAL:
ClassDefinition - Class in org.eclipse.persistence.internal.codegen
INTERNAL:
ClassDefinition() - Constructor for class org.eclipse.persistence.internal.codegen.ClassDefinition
 
ClassDescriptor - Class in org.eclipse.persistence.descriptors
Purpose: Abstract descriptor class for defining persistence information on a class.
ClassDescriptor() - Constructor for class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return a new descriptor.
classesToBeInvalidated - Variable in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
Contains classes that should be invalidated in the shared cache on commit.
classExtractionMethod - Variable in class org.eclipse.persistence.descriptors.MethodClassExtractor
 
classExtractionMethodMustBeStatic(String, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
classExtractionMethodName - Variable in class org.eclipse.persistence.descriptors.MethodClassExtractor
 
classExtractor - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
ClassExtractor - Class in org.eclipse.persistence.descriptors
Purpose: Abstract class to allow complex inheritance support.
ClassExtractor - Annotation Type in org.eclipse.persistence.annotations
A ClassExtractor allows for a user defined class indicator in place of providing a discriminator column.
ClassExtractor() - Constructor for class org.eclipse.persistence.descriptors.ClassExtractor
 
classExtractorCanNotBeSpecifiedWithDiscriminatorMetadata(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
classExtractorName - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
Allow for class extraction method to be specified.
classFileTransformerThrowsException(Object, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
classFromRow(ABSTRACT_RECORD, ABSTRACT_SESSION) - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL: This method is invoked only for the abstract descriptors.
classFromRow(UnmarshalRecord, ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
classFromRow(UnmarshalRecord, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
classFromRow(UnmarshalRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
classFromRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: This method is invoked only for the abstract descriptors.
classFromRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.QNameInheritancePolicy
INTERNAL: This method is invoked only for the abstract descriptors.
classFromValue(Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: This method is used to turn the a raw database field value classFieldValue into a Class object.
classImplementsInterface(Class<T>, Class<?>) - Static method in class org.eclipse.persistence.internal.helper.Helper
INTERNAL: Return whether a Class implements a specific interface, either directly or indirectly (through interface or implementation inheritance).
classIndicatorField - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
classIndicatorFieldNotFound(ClassDescriptor, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
classIndicatorMapping - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
ClassInstanceConverter - Class in org.eclipse.persistence.mappings.converters
Purpose: Allows a class name to be converted to and from a new instance of the class.
ClassInstanceConverter() - Constructor for class org.eclipse.persistence.mappings.converters.ClassInstanceConverter
PUBLIC: Default constructor.
classIsSubclass(Class<?>, Class<?>) - Static method in class org.eclipse.persistence.internal.helper.Helper
INTERNAL: Return whether a Class is a subclass of, or the same as, another Class.
classListMustNotBeNull() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
classLoader - Variable in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
Define the class loader that should be used to find the resource.
CLASSLOADER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.classloader" property specifies the classloader to use to create an EntityManagerFactory in the property map passed to Persistence.createEntityManagerFactory.
className - Variable in class org.eclipse.persistence.dynamic.DynamicEnumBuilder
 
className - Variable in class org.eclipse.persistence.internal.codegen.HierarchyNode
 
className - Variable in class org.eclipse.persistence.internal.oxm.XMLChoiceFieldToClassAssociation
 
className - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
className - Variable in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
className - Variable in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
 
ClassNameConversionRequired - Interface in org.eclipse.persistence.internal.descriptors
Tagging interface used to mark class as requiring class name conversion during deployment.
classNameIndicatorMapping - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
classNamesForWeaving - Variable in class org.eclipse.persistence.sessions.Project
used for Caching JPA projects
classNotFound(Exception, String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to load the instance class for a given type
classNotFoundException - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
classNotFoundException(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
classNotFoundException(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
classNotFoundForProperty(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
classNotFoundWhileConvertingClassNames(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
classNotFoundWhileProcessingAnnotations(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
classNotFoundWhileUsingQueryHint(DatabaseQuery, Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
classNotListedInPersistenceUnit(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
classPkDoesNotExistInCache(Class<?>, Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
ClassSummaryDetail - Class in org.eclipse.persistence.services.glassfish
The class is used internally by the Portable JMX Framework to convert model specific classes into Open Types so that the attributes of model class can be exposed by MBeans.
ClassSummaryDetail - Class in org.eclipse.persistence.services.jboss
The class is used internally by the Portable JMX Framework to convert model specific classes into Open Types so that the attributes of model class can be exposed by MBeans.
ClassSummaryDetail - Class in org.eclipse.persistence.services.weblogic
The class is used internally by the Portable JMX Framework to convert model specific classes into Open Types so that the attributes of model class can be exposed by MBeans.
ClassSummaryDetail - Class in org.eclipse.persistence.services.websphere
The class is used internally by the Portable JMX Framework to convert model specific classes into Open Types so that the attributes of model class can be exposed by MBeans.
ClassSummaryDetail(String, String, String, String, String) - Constructor for class org.eclipse.persistence.services.glassfish.ClassSummaryDetail
Construct a ClassSummaryDetail instance.
ClassSummaryDetail(String, String, String, String, String) - Constructor for class org.eclipse.persistence.services.jboss.ClassSummaryDetail
Construct a ClassSummaryDetail instance.
ClassSummaryDetail(String, String, String, String, String) - Constructor for class org.eclipse.persistence.services.weblogic.ClassSummaryDetail
Construct a ClassSummaryDetail instance.
ClassSummaryDetail(String, String, String, String, String) - Constructor for class org.eclipse.persistence.services.websphere.ClassSummaryDetail
Construct a ClassSummaryDetail instance.
ClassSummaryDetailBase - Class in org.eclipse.persistence.services
The class is used internally by the Portable JMX Framework to convert model specific classes into Open Types so that the attributes of model class can be exposed by MBeans.
ClassSummaryDetailBase(String, String, String, String, String) - Constructor for class org.eclipse.persistence.services.ClassSummaryDetailBase
Construct a ClassSummaryDetail instance.
classToConvertTo - Variable in exception org.eclipse.persistence.exceptions.ConversionException
 
classType - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
ClassTypeExpression - Class in org.eclipse.persistence.internal.expressions
 
ClassTypeExpression() - Constructor for class org.eclipse.persistence.internal.expressions.ClassTypeExpression
 
ClassTypeExpression(Expression) - Constructor for class org.eclipse.persistence.internal.expressions.ClassTypeExpression
 
classTypes - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Stores mapping of class types to database types for schema creation.
classWriters - Variable in class org.eclipse.persistence.dynamic.DynamicClassLoader
Map of DynamicClassWriter used to dynamically create a class in the DynamicClassLoader.findClass(String) call.
cleanup() - Method in class org.eclipse.persistence.tools.PackageRenamer
 
cleanUp() - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
 
cleanUp(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.cdi.DisabledInjectionManager
 
cleanUp(AbstractSession) - Method in interface org.eclipse.persistence.internal.sessions.cdi.InjectionManager
 
cleanUp(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.cdi.InjectionManagerImpl
 
CLEANUP_TEMP_TABLE - Static variable in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
cleanupCount - Variable in class org.eclipse.persistence.internal.identitymaps.WeakIdentityMap
Keep track of a counter to amortize cleanup of dead cache keys
cleanupCount - Variable in class org.eclipse.persistence.internal.identitymaps.WeakUnitOfWorkIdentityMap
Keep track of a counter to amortize cleanup of dead cache keys
cleanupDeadCacheKeys() - Method in class org.eclipse.persistence.internal.identitymaps.WeakIdentityMap
Search for any cache keys that have been garbage collected and remove them.
cleanupDeadCacheKeys() - Method in class org.eclipse.persistence.internal.identitymaps.WeakUnitOfWorkIdentityMap
Search for any cache keys that have been garbage collected and remove them.
cleanUpInjectionManager() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
allow the entity listener injection manager to clean itself up.
cleanupNamespaceResolvers(Element) - Method in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
Remove any temporary namespace resolvers created while processing a given element.
cleanupSize - Variable in class org.eclipse.persistence.internal.identitymaps.WeakIdentityMap
PERF: Keep track of a cleanup size to avoid cleanup bottleneck for large caches.
cleanupSize - Variable in class org.eclipse.persistence.internal.identitymaps.WeakUnitOfWorkIdentityMap
PERF: Keep track of a cleanup size to avoid cleanup bottleneck for large caches.
clear() - Method in class org.eclipse.persistence.eis.EISMappedRecord
Forward the request to the record.
clear() - Method in class org.eclipse.persistence.indirection.IndirectList
 
clear() - Method in class org.eclipse.persistence.indirection.IndirectMap
 
clear() - Method in class org.eclipse.persistence.indirection.IndirectSet
 
clear() - Method in class org.eclipse.persistence.internal.cache.AdvancedProcessor
 
clear() - Method in interface org.eclipse.persistence.internal.cache.Clearable
 
clear() - Method in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
INTERNAL: This method is used to clear the batched statements without the need to execute the statements first This is used in the case of rollback.
clear() - Method in class org.eclipse.persistence.internal.databaseaccess.ConnectionCustomizer
INTERNAL: Clears customization from connection.
clear() - Method in class org.eclipse.persistence.internal.databaseaccess.DynamicSQLBatchWritingMechanism
INTERNAL: This method is used to clear the batched statements without the need to execute the statements first This is used in the case of rollback.
clear() - Method in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
INTERNAL: This method is used to clear the batched statements without the need to execute the statements first This is used in the case of rollback.
clear() - Method in class org.eclipse.persistence.internal.helper.ConcurrentFixedCache
 
clear() - Method in class org.eclipse.persistence.internal.helper.IdentityHashSet
Removes all of the objects from this IdentityHashSet.
clear() - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Removes all of the mappings from this IdentityWeakHashMap.
clear() - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
Removes all of the contents from this list.
clear() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
clear() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
clear() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
clear() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Clear the joining state.
clear() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Clear the contents of the row.
clear() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.EntrySet
 
clear() - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
PUBLIC: Clear the contents of the row.
clear() - Method in class org.eclipse.persistence.internal.sessions.ResultSetRecord
PUBLIC: Clear the contents of the row.
clear() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
PUBLIC: Clear the sub-nodes of the DOM.
clear() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
clear() - Method in class org.eclipse.persistence.oxm.record.NodeRecord
 
clear() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
clear() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
clear() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
PUBLIC: Clear the sub-nodes of the DOM.
clear() - Method in class org.eclipse.persistence.queries.Cursor
PUBLIC: Release all objects read in so far.
clear() - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Release all objects read in so far.
clear() - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Clear the contents of the result.
clear() - Method in class org.eclipse.persistence.queries.ReportQueryResult.EntrySet
 
clear() - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
clear(boolean) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: This method will clear the changerecords from a changeSet
clear(boolean) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: This method will clear all registered objects from this UnitOfWork.
clear(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This method will clear all registered objects from this UnitOfWork.
clear(Object) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Remove all the elements from the specified container.
clear(Object) - Method in class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
INTERNAL: Remove all the elements from container.
clear(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Remove all the elements from the specified container.
clear(Object) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Remove all the elements from container.
CLEAR_QUERY_RESULTS_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
Clearable - Interface in org.eclipse.persistence.internal.cache
Behavioral interface saying that there is option to clear contents of the object.
clearAliases() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL:
clearAliases() - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL:
clearAliases() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL:
clearCacheIndexes() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Clear all index caches.
clearCacheQueryTimeout() - Method in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
INTERNAL: Clear the cached timeout after the statement has been executed.
clearChanges() - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Clears info about added / removed objects set by change tracker.
clearChanges() - Method in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
Clears info about added / removed objects set by change tracker.
clearChanges() - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
Clears info about added / removed objects set by change tracker.
clearChanges() - Method in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
Clears info about added / removed objects set by change tracker.
clearChanges(boolean) - Method in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
INTERNAL: Clear the changes in this listener
clearChanges(boolean) - Method in class org.eclipse.persistence.internal.descriptors.changetracking.ObjectChangeListener
INTERNAL: Clear a change flag used in this method.
clearChanges(Object, UnitOfWorkImpl, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: This is a place holder for reseting the listener on one of the subclasses
clearChanges(Object, UnitOfWorkImpl, ClassDescriptor, boolean) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: This is a place holder for reseting the listener on one of the subclasses
clearChanges(Object, UnitOfWorkImpl, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.descriptors.changetracking.ObjectChangeTrackingPolicy
INTERNAL: Clear the changes in the ObjectChangeListener
clearDataResults() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Clear the data-results for joined data for a 1-m join.
clearDeferredChanges() - Method in interface org.eclipse.persistence.indirection.IndirectCollection
INTERNAL: clear any changes that have been deferred to instantiation.
clearDeferredChanges() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: clear any changes that have been deferred to instantiation.
clearDeferredChanges() - Method in class org.eclipse.persistence.indirection.IndirectMap
INTERNAL: clear any changes that have been deferred to instantiation.
clearDeferredChanges() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: clear any changes that have been deferred to instantiation.
clearDescriptors() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Clear the the descriptors cache.
clearDriverClassAndDriver() - Method in class org.eclipse.persistence.sessions.DefaultConnector
INTERNAL: Discard the cached driver class and driver.
clearFlushClearCache() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Clears invalidation list.
clearForClose(boolean) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Call this method if the uow will no longer used for committing transactions: all the changes sets will be dereferenced, and (optionally) the cache cleared.
clearForClose(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Call this method if the uow will no longer be used for committing transactions: all the change sets will be dereferenced, and (optionally) the cache cleared.
clearInitialization() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
 
clearIntegrityChecker() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: clear the integrityChecker.
clearIntegrityChecker() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: clear the integrityChecker, the integrityChecker holds all the ClassDescriptor Exceptions.
clearIsResultSetOptimizedQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
ADVANCED: Clear the flag set by setIsResultSetOptimizedQuery method, allow to use default set on the session instead.
clearItems() - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Clear the ReportQueryItems
clearJustificationWhyMethodIsBuildingObjectCompleteReturnsFalse() - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
clearLastAccessedIdentityMap() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
INTERNAL: Clear the the lastAccessedIdentityMap and the lastAccessedIdentityMapClass
clearLastDescriptorAccessed() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Clear the the lastDescriptorAccessed cache.
clearMapThreadToObjectIdsWithChagenSet(Thread) - Static method in class org.eclipse.persistence.internal.helper.WriteLockManager
Remove the current thread from the map of object ids with change sets that are about to bec ommited
clearMapWriteLockManagerToCacheKeysThatCouldNotBeAcquired(Thread) - Static method in class org.eclipse.persistence.internal.helper.WriteLockManager
Before the problematic while loop starts we should always clear for this thread the set of cache keys it could not acquire.
clearNextAndPrevious() - Method in class org.eclipse.persistence.queries.ScrollableCursor
INTERNAL: Clear the cached next and previous object and row values.
clearNextAndPreviousObject() - Method in class org.eclipse.persistence.queries.ScrollableCursor
INTERNAL: Clear only the cached next and previous object values.
clearOracleConnectionCache(Connection) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Clears both implicit and explicit caches of OracleConnection on Oracle9Platform, noop here.
clearPrimaryKey(Object) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Clear any primary key cache data in the object.
clearProfile() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Clear the profiler, this will end the current profile operation.
clearProfile() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Clear the profiler, this will end the current profile operation.
clearQueryCache() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Clear all the query caches.
clearQueryCache() - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Clear all the query caches
clearQueryCache() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
ADVANCED: Clear all the query caches
clearQueryCache() - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Clear all the query caches
clearQueryCache(String) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Clear the query cache associated with the named query on the session
clearQueryCache(String) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
ADVANCED: Clear the query cache associated with the named query on the session
clearQueryCache(String) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Clear the query cache associated with the named query on the session.
clearQueryCache(String, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Clear the query cache associated with the named query on the descriptor for the given class
clearQueryCache(String, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
ADVANCED: Clear the query cache associated with the named query on the descriptor for the given class
clearQueryCache(String, Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Clear the query cache associated with the named query on the descriptor for the given class.
clearQueryCache(ReadQuery) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Remove the cache key related to a query.
clearQueryCache(ReadQuery) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Clear the query class associated with the passed-in read query
clearQueryCache(ReadQuery) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
ADVANCED: Clear the query class associated with the passed-in read query
clearQueryCache(ReadQuery) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Clear the query class associated with the passed-in read query.
clearQueryResults(AbstractSession) - Method in class org.eclipse.persistence.queries.ReadQuery
PUBLIC: Clears the current cached results, the next execution with read from the database.
clearQueryResultsNotSupported(ReadQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
clearReferencingClasses() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Cleans referencingClasses set.
clearSelectionId() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Clear the selection id and object.
clearSequencingListeners() - Method in interface org.eclipse.persistence.sessions.ExternalTransactionController
INTERNAL: Clears sequencing listeners.
clearSequencingListeners() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Clears sequencing listeners.
clearStatement() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
The statement is no longer require after prepare so can be released.
clearStatement() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
The statement is no longer require after prepare so can be released.
clearStatementCache() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Used to clear the statement cache.
clearStatementCache() - Method in class org.eclipse.persistence.services.RuntimeServices
Used to clear the statement cache.
clearStatementCache(Connection) - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: Clears statement cache of the wrapper connection.
clearStatementCache(Connection) - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: Clears statement cache of the wrapper connection.
clearStatementCache(Connection) - Method in class org.eclipse.persistence.platform.server.wls.WebLogicPlatform
INTERNAL: Clears statement cache of WebLogic connection using the WebLogic API reflectively.
clearStatementCache(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Flush the statement cache.
clearStatementCacheMethod - Variable in class org.eclipse.persistence.platform.server.wls.WebLogicPlatform
Cached WLConnection.clearStatementCache() Method used for clearing statement cache.
clearUsesResultSetAccessOptimization() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL:
CLIENT_SESSION_CANNOT_USE_EXCLUSIVE_CONNECTION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ClientSession - Class in org.eclipse.persistence.sessions.server
Purpose: Acts as a client to the server session.
ClientSession(Project) - Constructor for class org.eclipse.persistence.sessions.server.ClientSession
 
ClientSession(ServerSession, ConnectionPolicy) - Constructor for class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Create and return a new client session.
ClientSession(ServerSession, ConnectionPolicy, Map) - Constructor for class org.eclipse.persistence.sessions.server.ClientSession
 
clientSessionCanNotUseExclusiveConnection() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
ClientSessionCreated - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
ClientSessionIdentityMapAccessor - Class in org.eclipse.persistence.internal.sessions
INTERNAL: IdentityMapAccessor subclass for client sessions.
ClientSessionIdentityMapAccessor(ClientSession) - Constructor for class org.eclipse.persistence.internal.sessions.ClientSessionIdentityMapAccessor
INTERNAL: Create a ClientSessionIdentityMapAccessor Since the parent session's identity map manager is used, an IdentityMapManager does not need to be supplied to the constructor
ClientSessionReleased - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
CLINIT - Static variable in class org.eclipse.persistence.dynamic.DynamicClassWriter
 
CLOB - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
CLOB_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
clone() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
clone() - Method in class org.eclipse.persistence.descriptors.CacheIndex
 
clone() - Method in class org.eclipse.persistence.descriptors.CachePolicy
 
clone() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Clones the descriptor
clone() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: Clone the CMPPolicy
clone() - Method in class org.eclipse.persistence.descriptors.copying.AbstractCopyPolicy
INTERNAL: Clones the CopyPolicy
clone() - Method in interface org.eclipse.persistence.descriptors.copying.CopyPolicy
Clone the CopyPolicy.
clone() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: Clone the manager and its private parts.
clone() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Clone the query manager
clone() - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Clone the fetch group manager.
clone() - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Clone the policy
clone() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Clone the policy
clone() - Method in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
 
clone() - Method in class org.eclipse.persistence.descriptors.invalidation.DailyCacheInvalidationPolicy
 
clone() - Method in class org.eclipse.persistence.descriptors.invalidation.TimeToLiveCacheInvalidationPolicy
 
clone() - Method in class org.eclipse.persistence.descriptors.PessimisticLockingPolicy
INTERNAL: Clone the policy
clone() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL: Normally cloned when not yet initialized.
clone() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
INTERNAL:
clone() - Method in interface org.eclipse.persistence.descriptors.SerializedObjectPolicy
 
clone() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Clone the policy
clone() - Method in class org.eclipse.persistence.eis.EISConnectionSpec
INTERNAL: Clone the connector.
clone() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Clone the appropriate attributes.
clone() - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: This methods clones all the fields and ensures that each collection refers to the same clones.
clone() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Clone the expression maintaining clone identity in the inter-connected expression graph.
clone() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
 
clone() - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
 
clone() - Method in class org.eclipse.persistence.history.HistoryPolicy
PUBLIC: Performs a sufficiently deep clone.
clone() - Method in class org.eclipse.persistence.indirection.IndirectList
PUBLIC:
clone() - Method in class org.eclipse.persistence.indirection.IndirectMap
 
clone() - Method in class org.eclipse.persistence.indirection.IndirectSet
 
clone() - Method in class org.eclipse.persistence.indirection.ValueHolder
INTERNAL:
clone() - Method in interface org.eclipse.persistence.indirection.ValueHolderInterface
PUBLIC: Copy the value holder (but not its' reference, shallow).
clone() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return a clone of the accessor.
clone() - Method in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
INTERNAL: The mechanism will be cloned to be set into each accessor.
clone() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Clone the accessor.
clone() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Clone the accessor.
clone() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
clone() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
clone() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
clone() - Method in class org.eclipse.persistence.internal.descriptors.AbstractSerializedObjectPolicy
 
clone() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
INTERNAL: Clones the InstantiationPolicy
clone() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Returns a clone of itself.
clone() - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
 
clone() - Method in class org.eclipse.persistence.internal.descriptors.SerializedObjectPolicyWrapper
 
clone() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
clone() - Method in class org.eclipse.persistence.internal.expressions.ForUpdateClause
 
clone() - Method in class org.eclipse.persistence.internal.expressions.SQLStatement
Clone the Statement
clone() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
clone() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL:
clone() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
The table is not cloned because it is treated as an automatic value.
clone() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Return a shallow copy of the receiver.
clone() - Method in class org.eclipse.persistence.internal.helper.IdentityHashSet
Returns a shallow copy of this IdentityHashSet (the elements are not cloned).
clone() - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Returns a shallow copy of this IdentityWeakHashMap (the elements are not cloned).
clone() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
clone() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
clone() - Method in class org.eclipse.persistence.internal.helper.ReadLockManager
Create a new instance ReadLockManager that is in all regards equal to the current instance.
clone() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
clone() - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Clone the map and all of the CacheKeys.
clone() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
INTERNAL: Clones itself.
clone() - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
INTERNAL: Clones itself.
clone() - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Clone the map and all of the CacheKeys.
clone() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
INTERNAL: Clones itself, used for uow commit and resume on failure.
clone() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
 
clone() - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Clones itself.
clone() - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
INTERNAL:
clone() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
clone() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
clone() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Clone the mechanism
clone() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Clones the Joined Attribute Manager.
clone() - Method in class org.eclipse.persistence.internal.queries.JPQLCallQueryMechanism
 
clone() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: The mapping clones itself to create deep copy.
clone() - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
clone() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: Clone the row and its values.
clone() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Clones the descriptor
clone() - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
INTERNAL: Clone the row and its values.
clone() - Method in class org.eclipse.persistence.internal.sessions.EmptyRecord
Need to return a real record.
clone() - Method in class org.eclipse.persistence.logging.AbstractSessionLog
INTERNAL: Each session owns its own session log because session is stored in the session log
clone() - Method in class org.eclipse.persistence.logging.JavaLog
INTERNAL: Each session owns its own session log because session is stored in the session log
clone() - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Clone the log.
clone() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: The mapping clones itself to create deep copy.
clone() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Clone the aggregate to source field names.
clone() - Method in class org.eclipse.persistence.mappings.AttributeAccessor
INTERNAL: Clones itself.
clone() - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: The mapping clones itself to create deep copy.
clone() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Clones itself.
clone() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: The mapping clones itself to create deep copy.
clone() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: The mapping clones itself to create deep copy.
clone() - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL: The mapping clones itself to create deep copy.
clone() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: The mapping clones itself to create deep copy.
clone() - Method in interface org.eclipse.persistence.mappings.foundation.MapComponentMapping
INTERNAL Called when cloning the container policy.
clone() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: The mapping clones itself to create deep copy.
clone() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Clone the appropriate attributes.
clone() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: This methods clones all the fields and ensures that each collection refers to the same clones.
clone() - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
INTERNAL: Clones itself.
clone() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: The mapping clones itself to create deep copy.
clone() - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: The mapping clones itself to create deep copy
clone() - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: This methods clones all the fields and ensures that each collection refers to the same clones.
clone() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
clone() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
clone() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
clone() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Clone the row and its values.
clone() - Method in class org.eclipse.persistence.oxm.XMLMarshaller
 
clone() - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
 
clone() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
clone() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCollection
 
clone() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCursor
 
clone() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
clone() - Method in class org.eclipse.persistence.queries.AttributeGroup
 
clone() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
 
clone() - Method in interface org.eclipse.persistence.queries.Call
INTERNAL: Return a clone of the call.
clone() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Clone the query
clone() - Method in class org.eclipse.persistence.queries.DataReadQuery
INTERNAL: Clone the query.
clone() - Method in class org.eclipse.persistence.queries.FetchGroup
 
clone() - Method in class org.eclipse.persistence.queries.JPQLCall
 
clone() - Method in class org.eclipse.persistence.queries.LoadGroup
 
clone() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Clone the query
clone() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Creates and returns a copy of this query.
clone() - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
 
clone() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Creates and returns a copy of this query.
clone() - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Clone the query.
clone() - Method in class org.eclipse.persistence.sequencing.Sequence
 
clone() - Method in interface org.eclipse.persistence.sessions.Connector
INTERNAL: Must be cloneable.
clone() - Method in class org.eclipse.persistence.sessions.CopyGroup
 
clone() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Clone the login.
clone() - Method in class org.eclipse.persistence.sessions.DefaultConnector
INTERNAL: Clone the connector.
clone() - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Clone the map and all of the CacheKeys.
clone() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
clone() - Method in class org.eclipse.persistence.sessions.JNDIConnector
INTERNAL: Clone the connector.
clone() - Method in interface org.eclipse.persistence.sessions.Login
INTERNAL: Clone the login.
clone() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Clones the descriptor
clone() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
INTERNAL: Clone the query
clone() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Shallow clone the event manager.
clone() - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
clone() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
clone() - Method in class org.eclipse.persistence.tools.profiler.Profile
 
clone() - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
PUBLIC:
clone() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC:
clone() - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Performs a deep copy of this table definition.
clone(Serializable) - Static method in class org.eclipse.persistence.internal.helper.SerializationHelper
Deep clone a Serializable object using serialization.
clone(Map<ATTRIBUTE_GROUP, ATTRIBUTE_GROUP>, ATTRIBUTE_GROUP) - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
clone(Map<CoreAttributeGroup<ATTRIBUTE_ITEM, DESCRIPTOR>, CoreAttributeGroup<ATTRIBUTE_ITEM, DESCRIPTOR>>) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL: This method is used internally in the clone processing.
clone(ClassDescriptor) - Method in interface org.eclipse.persistence.descriptors.MultitenantPolicy
 
clone(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
clone(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL:
clone(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL: Multitenant policies are cloned per inheritance subclass.
clone(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.VPDMultitenantPolicy
INTERNAL:
clone(DatabaseQuery) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Clone the mechanism for the specified query clone.
clone(DatabaseQuery) - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Clone the DatasourceCall and Vector<DatasourceCall>.
clone(DatabaseQuery) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Clone the mechanism for the specified query clone.
clone(DatabaseQuery) - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Clone the mechanism for the specified query clone.
clone(ReadQuery) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
clone(ReadQuery) - Method in class org.eclipse.persistence.queries.CursorPolicy
INTERNAL:
clone(Session) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Clone the event manager for the new session.
CLONE_INTO_WORKING_COPY - Static variable in class org.eclipse.persistence.internal.sessions.MergeManager
 
CLONE_METHOD_INACCESSIBLE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CLONE_METHOD_REQUIRED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CLONE_METHOD_THORW_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
CLONE_WITH_REFS_INTO_WORKING_COPY - Static variable in class org.eclipse.persistence.internal.sessions.MergeManager
 
cloneAndRegisterNewObject(Object, boolean) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: To avoid putting the original object into the shared cache, and therefore, impede the 'detaching' of the original after commit, a clone of the original should be registered not the actual original object.
cloneAndRegisterNewObject(Object, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Register the new object with the unit of work.
cloneAndRegisterObject(Object, CacheKey, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Clone and register the object.
cloneAndRegisterObject(Object, CacheKey, CacheKey, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Clone and register the object.
cloneAttribute(Object, Object, CacheKey, Object, Integer, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return a clone of the attribute.
cloneAttribute(Object, Object, CacheKey, Object, Integer, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return a clone of the attribute.
cloneAttribute(Object, Object, CacheKey, Object, Integer, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return a clone of the attribute.
cloneAttribute(Object, Object, CacheKey, Object, Integer, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return a clone of the attribute.
cloneAttribute(Object, Object, CacheKey, Object, Integer, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Return a clone of the attribute.
cloneAttribute(Object, Object, CacheKey, Object, Integer, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
Return a clone of the attribute.
CloneCopyPolicy - Class in org.eclipse.persistence.descriptors.copying
Purpose: Allows a clone of an object to be created with a method that returns the cloned object.
CloneCopyPolicy - Annotation Type in org.eclipse.persistence.annotations
A CloneCopyPolicy is used to set an org.eclipse.persistence.descriptors.copying.CloneCopyPolicy on an Entity.
CloneCopyPolicy() - Constructor for class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
 
cloneDeferredLockManager(DeferredLockManager) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Clone an original DeferredLockManager so that our algorithms of state dump or dead lock search can safely work ina stable model state that is not constantly changing.
cloneDeferredLockManagerMap(Map<Thread, DeferredLockManager>) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
The exact same thing as the ConcurrencyUtil.cloneReadLockManagerMap(Map) but the map we are cloning here is the one of threads to deferred locks
cloneDelegate() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Clone the delegate.
cloneDepth - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Used during the cloning process to track the recursive depth in.
clonedExpressions - Variable in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
Used to maintain identity of cloned expressions.
clonedQueryExecutionComplete(DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL Used to give the subclasses opportunity to copy aspects of the cloned query to the original query.
clonedQueryExecutionComplete(DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.queries.ModifyAllQuery
INTERNAL Used to give the subclasses opportunity to copy aspects of the cloned query to the original query.
clonedQueryExecutionComplete(DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL Used to give the subclasses opportunity to copy aspects of the cloned query to the original query.
clonedQueryExecutionComplete(DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL Used to give the subclasses opportunity to copy aspects of the cloned query to the original query.
cloneFields(Vector) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Helper method to clone vector of fields (used in aggregate initialization cloning).
cloneFields(Vector) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Helper method to clone vector of fields (used in aggregate initialization cloning).
cloneFor(Object) - Method in class org.eclipse.persistence.internal.queries.ArrayListContainerPolicy
INTERNAL: Return a clone of the specified container.
cloneFor(Object) - Method in class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
INTERNAL: Return a clone of the specified container.
cloneFor(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return a clone of the specified container.
cloneFor(Object) - Method in class org.eclipse.persistence.internal.queries.IndirectListContainerPolicy
INTERNAL: Return a clone of the specified container.
cloneFor(Object) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Return a clone of the specified container.
cloneFor(Object) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return a clone of the specified container.
cloneFor(Object) - Method in class org.eclipse.persistence.internal.queries.VectorContainerPolicy
INTERNAL: Return a clone of the specified container.
cloneKeys() - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Allow for the CacheKey elements to be iterated.
cloneKeys() - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Allow for the CacheKeys to be iterated on using copy of keys enumeration.
cloneKeys() - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Return an empty enumerator.
cloneKeys() - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Allow for the CacheKey elements to be iterated.
cloneMap(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
This method is used internally to clone a map that holds the persistenceContexts.
cloneMapping - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Map of all the clones.
cloneMapThreadToMethodName(Map<Thread, String>) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Clone the map of the method names that tells us justification where threads acquire locks.
cloneMapThreadToObjectIdWithWriteLockManagerChanges(Map<Thread, Set<Object>>) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Clone the information about threads that are in the write lock manager trying to commit and the object ids they are holding with some arbitrary changes.
cloneMapThreadToWaitOnAcquire(Map<Thread, ConcurrencyManager>) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Clone the static map of the concurrency manager that tells us about threads waiting to acquire locks.
cloneMapThreadToWaitOnAcquireInsideWriteLockManagerOriginal(Map<Thread, Set<ConcurrencyManager>>) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Clone the static map of the concurrency manager that tells us about threads waiting to acquire locks.
cloneMethod - Variable in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
The method which will return a clone of an instance of the containerClass.
cloneMethodInaccessible() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cloneMethodRequired() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cloneMethodThrowException(Throwable) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
cloneObject - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
cloneOfObject - Variable in class org.eclipse.persistence.internal.indirection.UnitOfWorkTransformerValueHolder
 
cloneReadLockManagerMap(Map<Thread, ReadLockManager>) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
To facilitate algorithms that want to dump a snapshot of the current state of the concurrency manager or to start a hunt for dead locks this api faciliates the boostraping logic of such algorithms by giving the algorithm a stable clone of the map of read locks that we know will not change throughout the time the algorithm is running.
cloneSetThreadsThatAreCurrentlyWaitingToReleaseDeferredLocks(Set<Thread>) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
A set of threads that are at the end of object building and are waiting for the deferred locks to be resolved.
cloneToObjectChangeSet - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
 
cloneToOriginals - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
As well as used as lookup in merge algorithm for aggregates and others
cloneUsing(Expression) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: This expression is built on a different base than the one we want.
cloningMappings - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Cache mappings that require cloning.
close() - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: This method is called when connection in no longer used and it's resources should be freed.
close() - Method in class org.eclipse.persistence.internal.sessions.coordination.RemoteConnection
INTERNAL: cleanup whatever is necessary.
close() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteCursoredStream
Close the wrapped cursored stream This should be performed whenever the user has finished with the stream.
close() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
Close the wrapped cursored stream This should be performed whenever the user has finished with the stream.
close() - Method in class org.eclipse.persistence.queries.Cursor
PUBLIC: Closes the stream.
close(Closeable) - Static method in class org.eclipse.persistence.internal.helper.Helper
Close a closeable object, eating the exception
CLOSE_ATTRIBUTE_VALUE - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
CLOSE_CDATA - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
CLOSE_COMMENT - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
CLOSE_ELEMENT - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
CLOSE_PI - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
closeComplex() - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
 
closeComplex() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
closeConnection() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Close the accessor's connection.
closeConnection() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Close the accessor's connection.
closeConnection() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Close the accessor's connection.
closeCursor(ResultSet, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Close the result set of the cursored stream.
closeDatasourceConnection() - Method in class org.eclipse.persistence.eis.EISAccessor
Close the connection.
closeDatasourceConnection() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Close the connection.
closeDatasourceConnection() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Close the connection to the driver level datasource.
closeDatasourceConnection() - Method in class org.eclipse.persistence.internal.oxm.XMLAccessor
 
closeDDLWriter() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
PUBLIC: Close the schema writer.
closeDDLWriter(Writer) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
closeInternal() - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: This method is called by close method.
closeInternal() - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: This method is called by close method.
closeJTSConnection() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Called from beforeCompletion external transaction synchronization listener callback to close the external connection corresponding to the completing external transaction.
closeJTSConnection() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Called from beforeCompletion external transaction synchronization listener callback to close the external connection corresponding to the completing external transaction.
closeScrollableCursor(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Used for closing scrolable cursor across RMI.
closeStartElement() - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
closeStartElement() - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
INTERNAL:
closeStartElement() - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
closeStartElement() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
closeStartElement() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Receive notification that all of the attribute events have occurred for the most recent element that has been started.
closeStartElement() - Method in class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL:
closeStartElement() - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL:
closeStartElement() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
closeStartElement() - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL:
closeStartElement() - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
closeStartElement() - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
closeStartGroupingElements(XPathFragment) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
closeStartGroupingElements(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
closeStartGroupingElements(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
closeStatement(Statement, AbstractSession, DatabaseCall) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
INTERNAL: Closes a PreparedStatement (which is supposed to close it's current resultSet).
Cloudscape - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
CloudscapePlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides CloudScape DBMS specific behavior.
CloudscapePlatform() - Constructor for class org.eclipse.persistence.platform.database.CloudscapePlatform
Default constructor.
cls - Variable in class org.eclipse.persistence.internal.sessions.remote.SequencingFunctionCall.GetNextValue
 
cmpPolicy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
CMPPolicy - Class in org.eclipse.persistence.descriptors
Description: Place holder for CMP specific information.
CMPPolicy() - Constructor for class org.eclipse.persistence.descriptors.CMPPolicy
 
CMPPolicy.KeyElementAccessor - Interface in org.eclipse.persistence.descriptors
INTERNAL: This is the interface used to encapsulate the the type of key class element
CMPPolicy.KeyIsElementAccessor - Class in org.eclipse.persistence.descriptors
INTERNAL: This class will be used when the keyClass is a primitive
coalesce() - Method in class org.eclipse.persistence.expressions.Expression
 
coalesce() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
coalesce(Collection) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function Return null if all arguments are null and the first non-null argument otherwise The equivalent of the COALESCE SQL function
Coalesce - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
coalesceOperator() - Method in class org.eclipse.persistence.platform.database.DB2Platform
DB2 requires that at least one argument be a known type
CodeDefinition - Class in org.eclipse.persistence.internal.codegen
INTERNAL:
CodeDefinition() - Constructor for class org.eclipse.persistence.internal.codegen.CodeDefinition
 
CodeGenerator - Class in org.eclipse.persistence.internal.codegen
INTERNAL:
CodeGenerator() - Constructor for class org.eclipse.persistence.internal.codegen.CodeGenerator
 
CodeGenerator(boolean) - Constructor for class org.eclipse.persistence.internal.codegen.CodeGenerator
 
collapseStringValue(String) - Method in interface org.eclipse.persistence.internal.oxm.ConversionManager
Removes all leading and trailing whitespaces, and replaces any sequences of whitespaces that occur in the string with a single ' ' character.
collapseStringValue(String) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Removes all leading and trailing whitespaces, and replaces any sequences of whitespaces that occur in the string with a single ' ' character.
collectAndPrepareObjectsForNestedMerge() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Prepare for merge in nested uow.
collectDatabaseSchemasForDrop(DatabaseObjectDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
INTERNAL: Called when dropping tables.
collectFields() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
Return all the fields mapped by the mapping.
collectFields() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return the fields handled by the mapping.
collectFields() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
This method must be overwritten in the subclasses to return a vector of all the fields this mapping represents.
collectFields() - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
Returns the field this mapping represents.
collectFields() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
Return the fields handled by the mapping.
collectFields() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
Return the fields handled by the mapping.
collectFields() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
Return the fields mapped by the mapping.
collectFields() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Return all the fields with this mapping.
collectFields() - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Return all the fields populated by this mapping, these are foreign keys only.
collectFields() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return all the fields populated by this mapping, these are foreign keys only.
collectFields() - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
Returns all the aggregate fields.
collectFields() - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
Returns all the aggregate fields.
collectFields() - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Return all the fields populated by this mapping.
collectFields() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
collectFields() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
collectFields() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
collectFields() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
Collection_Class - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
COLLECTION_REMOVE_EVENT_WITH_NO_INDEX - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CollectionChangeEvent - Class in org.eclipse.persistence.descriptors.changetracking
Purpose: Define a change event for collection types.
CollectionChangeEvent(Object, String, Object, Object, int, boolean) - Constructor for class org.eclipse.persistence.descriptors.changetracking.CollectionChangeEvent
PUBLIC: Create a CollectionChangeEvent for an object based on the property name, old value, new value, change type (add or remove) and change applied.
CollectionChangeEvent(Object, String, Object, Object, int, Integer, boolean, boolean) - Constructor for class org.eclipse.persistence.descriptors.changetracking.CollectionChangeEvent
PUBLIC: Create a CollectionChangeEvent for an object based on the property name, old value, new value, change type (add or remove) and the index where the object is/was in the collection (list), flag indicating whether the change (addition or removal) is part of a single set operation on a list, flag indicating whether the object has already been added or removed from the collection.
CollectionChangeEvent_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
CollectionChangeRecord - Class in org.eclipse.persistence.internal.sessions
Purpose: This class holds the record of the changes made to a collection attribute of an object.
CollectionChangeRecord - Interface in org.eclipse.persistence.sessions.changesets
Purpose: This interface defines the API for the changeRecord that maintains the changes made to a collection attribute of an object.
CollectionChangeRecord() - Constructor for class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This default constructor.
CollectionChangeRecord(ObjectChangeSet) - Constructor for class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Constructor for the ChangeRecord representing a collection mapping
CollectionChangeTracker - Interface in org.eclipse.persistence.descriptors.changetracking
Purpose: Define an interface for any collection that wishes to use attribute change track.
CollectionContainerPolicy - Class in org.eclipse.persistence.internal.queries
Purpose: A CollectionContainerPolicy is ContainerPolicy whose container class implements the Collection interface.
CollectionContainerPolicy() - Constructor for class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
INTERNAL: Construct a new policy.
CollectionContainerPolicy(Class<?>) - Constructor for class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
INTERNAL: Construct a new policy for the specified class.
CollectionContainerPolicy(String) - Constructor for class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
INTERNAL: Construct a new policy for the specified class name.
CollectionExpression - Class in org.eclipse.persistence.internal.expressions
Used for wrapping collection of values or expressions.
CollectionExpression() - Constructor for class org.eclipse.persistence.internal.expressions.CollectionExpression
 
CollectionExpression(Object, Expression) - Constructor for class org.eclipse.persistence.internal.expressions.CollectionExpression
 
CollectionGroupingElementNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
CollectionGroupingElementNodeValue(ContainerValue) - Constructor for class org.eclipse.persistence.internal.oxm.CollectionGroupingElementNodeValue
 
CollectionMapping - Class in org.eclipse.persistence.mappings
Purpose: Abstract class for relationship mappings which store collection of objects
CollectionMapping() - Constructor for class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Default constructor.
CollectionReferenceMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​UNMARSHAL_RECORD extends UnmarshalRecord,​XML_FIELD extends Field,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
collectionRemoveEventWithNoIndex(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Attempt to call setListOrderField method on a mapping that doesn't support listOrderField.
CollectionTable - Annotation Type in org.eclipse.persistence.annotations
Deprecated. 
collectionTypeIsValid(Class<?>) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return whether the collection type is appropriate for the indirection policy.
collectLocks(HashMap) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Add all locked CacheKeys to the map grouped by thread.
collectLocks(HashMap) - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
INTERNAL: Used to print all the Locks in every identity map in this session.
collectLocks(HashMap) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Add all locked CacheKeys to the map grouped by thread.
collectLocks(HashMap) - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
NoIdentityMap has no locks.
collectLocks(HashMap) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Add all locked CacheKeys to the map grouped by thread.
collectNewObjects() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
This is done to maintain correspondence between local new objects and returned new objects from serialization.
collectObjectForNewCollection(Map, Map, Object, CollectionChangeRecord, AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Iterate over the list of new objects and create change sets for them This method is overridden by subclasses to handle map keys
collectQueryParameters(Set<DatabaseField>) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: This method is used to store the FK fields that can be cached that correspond to noncacheable mappings the FK field values will be used to re-issue the query when cloning the shared cache entity
collectQueryParameters(Set<DatabaseField>) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: This method is used to store the FK fields that can be cached that correspond to noncacheable mappings the FK field values will be used to re-issue the query when cloning the shared cache entity
collectQueryParameters(Set<DatabaseField>) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: This method is used to store the FK fields that can be cached that correspond to noncacheable mappings the FK field values will be used to re-issue the query when cloning the shared cache entity
collectQueryParameters(Set<DatabaseField>) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: This method is used to store the FK fields that can be cached that correspond to noncacheable mappings the FK field values will be used to re-issue the query when cloning the shared cache entity
collectQueryParameters(Set<DatabaseField>) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: This method is used to store the FK fields that can be cached that correspond to noncacheable mappings the FK field values will be used to re-issue the query when cloning the shared cache entity
collectQueryParameters(Set<DatabaseField>) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: This method is used to store the FK fields that can be cached that correspond to noncacheable mappings the FK field values will be used to re-issue the query when cloning the shared cache entity
collectQueryParameters(Set<DatabaseField>) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: This method is used to store the FK fields that can be cached that correspond to noncacheable mappings the FK field values will be used to re-issue the query when cloning the shared cache entity
collectQueryParameters(Set<DatabaseField>) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: This method is used to store the FK fields that can be cached that correspond to noncacheable mappings the FK field values will be used to re-issue the query when cloning the shared cache entity
collectQueryParameters(Set<DatabaseField>) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: This method is used to store the FK fields that can be cached that correspond to noncacheable mappings the FK field values will be used to re-issue the query when cloning the shared cache entity
collectQueryParameters(Set<DatabaseField>) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
 
collectQueryParameters(Set<DatabaseField>) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: This method is used to store the FK fields that can be cached that correspond to noncacheable mappings the FK field values will be used to re-issue the query when cloning the shared cache entity
collectUnregisteredNewObjects() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
This is done to maintain correspondence between local unregistered new objects and returned unregistered new objects from serialization.
COLON - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
COLON_W_SCHEMA_NIL_ATTRIBUTE - Static variable in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
 
COLON_W_SCHEMA_NIL_ATTRIBUTE - Static variable in class org.eclipse.persistence.oxm.record.MarshalRecord
 
column - Variable in class org.eclipse.persistence.queries.ColumnResult
Stores the Columns name from the result set
column - Variable in class org.eclipse.persistence.queries.FieldResult
Stores the Columns name from the result set that contains the attribute value
column() - Method in annotation type org.eclipse.persistence.annotations.SerializedObject
(Optional) The column that holds the serialized object.
column() - Method in annotation type org.eclipse.persistence.annotations.WriteTransformer
Specify here the column into which the value should be written.
COLUMN_RESULT_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
columnDefinition - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
 
columnDefinition() - Method in annotation type org.eclipse.persistence.annotations.TenantDiscriminatorColumn
(Optional) The SQL fragment that is used when generating the DDL for the discriminator column.
columnNames() - Method in annotation type org.eclipse.persistence.annotations.CacheIndex
Specify the set of columns to define the index on.
columnNames() - Method in annotation type org.eclipse.persistence.annotations.Index
Specify the set of columns to define the index on.
ColumnResult - Class in org.eclipse.persistence.queries
Purpose: Concrete class to represent the ColumnResult structure as defined by the EJB 3.0 Persistence specification.
ColumnResult(String) - Constructor for class org.eclipse.persistence.queries.ColumnResult
 
ColumnResult(DatabaseField) - Constructor for class org.eclipse.persistence.queries.ColumnResult
 
columnResultNotFound(DatabaseField) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
columnResults - Variable in class org.eclipse.persistence.queries.ConstructorResult
Stored the column results of this constructor result
columns() - Method in annotation type org.eclipse.persistence.annotations.PrimaryKey
(Optional) Used to specify the primary key columns directly.
comapreTo(JavaVersion) - Method in class org.eclipse.persistence.internal.helper.JavaVersion
Compares this JavaVersion object against another one.
command - Variable in class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
The command to send
Command - Class in org.eclipse.persistence.sessions.coordination
Purpose: Provide an extendable framework class for a Command object that can be remotely executed.
Command() - Constructor for class org.eclipse.persistence.sessions.coordination.Command
Default constructor.
commandBytes - Variable in class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
The command to send
commandConverter - Variable in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
Used for converting commands between EclipseLink Command and app command formats
CommandConverter - Interface in org.eclipse.persistence.sessions.coordination
Purpose: Define a pluggable conversion interface that can be supplied by the application
commandManager - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Used to connect this session to EclipseLink cluster for distributed command
commandManager - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
This is the Synchronization policy used to synchronize remote caches
CommandManager - Interface in org.eclipse.persistence.sessions.coordination
Purpose: Provide an interface that clients can use to invoke remote commands on other EclipseLink instances, or on other applications that may want to receive and process EclipseLink commands.
commandProcessor - Variable in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
Invoked to process a command when it is received from the cluster
CommandProcessor - Interface in org.eclipse.persistence.sessions.coordination
Purpose: Defines a pluggable interface for EclipseLink sessions and EclipseLink applications to be able to be on the receiving end of EclipseLink command objects.
CommandPropagator - Class in org.eclipse.persistence.internal.sessions.coordination
Purpose: Synchronous and asynchronous propagation of remote commands
CommandPropagator(RemoteCommandManager, Command, byte[]) - Constructor for class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
Constructor used to create the main propagator
CommandPropagator(RemoteCommandManager, Command, byte[], RemoteConnection) - Constructor for class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
Constructor used to create the async propagator threads
CommandsConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.rcm.command
INTERNAL:
CommandsConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.rcm.command.CommandsConfig
 
comment - Variable in class org.eclipse.persistence.internal.codegen.CodeDefinition
 
comment(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
comment(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
comment(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
comment(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.NodeRecord.NodeRecordContentHandler
 
comment(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
comment(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
comment(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
comment(char[], int, int) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
commit() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Commit the unit of work to its parent.
commit() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Commit the unit of work to its parent.
commitAddMap - Variable in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
Contains the number of objects that must be inserted to once the value is removed in the database as a delete where value = "value" will remove all instances of that value in the database not just one.
commitAfterWriteChanges() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Commits a UnitOfWork where the commit process has already been initiated by all call to writeChanges().
commitAllObjectsForClassWithChangeSet(UnitOfWorkChangeSet, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Commit all of the objects of the class type in the change set.
commitAllObjectsWithChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Commit all of the objects as a single transaction.
commitAndResume() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Commit the unit of work to its parent.
commitAndResume() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Commit the unit of work to its parent.
commitAndResumeAfterWriteChanges() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Commits and resumes a UnitOfWork where the commit process has already been initiated by all call to writeChanges().
commitAndResumeOnFailure() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Commit the unit of work to its parent.
commitAndResumeOnFailure() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Commit the unit of work to its parent.
commitAndResumeWithPreBuiltChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This method is used by the MappingWorkbench for their read-only file feature this method must not be exposed to or used by customers until it has been revised and the feature revisited to support OptimisticLocking and Serialization
commitChangedObjectsForClassWithChangeSet(UnitOfWorkChangeSet, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Commit changed of the objects of the class type in the change set.
commitDepth - Variable in class org.eclipse.persistence.internal.sessions.CommitManager
Counter used to keep track of commit depth for non-UOW writes.
commitExternalTransaction() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Attempts to commit the running internally started external transaction.
commitInternallyStartedExternalTransaction() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PROTECTED: Used in commit and commit-like methods to commit internally started external transaction
commitIntoRemoteUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
The remote unit of work returned after its commit on the server is merged with remote unit of work on the remote side.
commitManager - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Resolves referential integrity on commits.
CommitManager - Class in org.eclipse.persistence.internal.sessions
This class maintains a commit stack and resolves circular references.
CommitManager(AbstractSession) - Constructor for class org.eclipse.persistence.internal.sessions.CommitManager
Create the commit manager on the session.
commitNestedUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Commit the changes to any objects to the parent.
commitNewObjectsForClassWithChangeSet(UnitOfWorkChangeSet, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Commit all of the objects of the class type in the change set.
commitOrder - Variable in class org.eclipse.persistence.internal.sessions.CommitManager
Order based on mapping foreign key constraints on how to insert objects by class.
commitOrder - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Allow updates and deletes to be ordered by id or changes to avoid possible deadlocks.
CommitOrderCalculator - Class in org.eclipse.persistence.internal.sessions
This class calculates a commit order for a series of classes based on the dependencies between them.
CommitOrderCalculator(AbstractSession) - Constructor for class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
 
CommitOrderDependencyNode - Class in org.eclipse.persistence.internal.sessions
This wraps a descriptor with information required to compute an order for dependencies.
CommitOrderDependencyNode(CommitOrderCalculator, ClassDescriptor, AbstractSession) - Constructor for class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
CommitOrderType - Class in org.eclipse.persistence.config
Commit order type persistence property values.
CommitOrderType() - Constructor for class org.eclipse.persistence.config.CommitOrderType
 
CommitPending - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
commitRootUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
Starts committing the remote unit of work.
commitRootUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Commit the changes to any objects to the parent.
commitRootUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Commit the changes to any objects to the parent.
commitRootUnitOfWork(RemoteUnitOfWork) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Commit remote unit of work
commitRootUnitOfWork(RemoteUnitOfWork) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Commit root unit of work from the client side to the server side.
commitRootUnitOfWork(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Remote unit of work after serialization is commited locally.
commitRootUnitOfWork(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
To commit remote unit of work on the server side.
commitRootUnitOfWork(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Remote unit of work after serialization is committed locally.
commitRootUnitOfWorkOnClient() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
Merges remote unit of work to parent remote session.
commitRootUnitOfWorkWithPreBuiltChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This method is used by the MappingWorkbench read-only files feature It will commit a pre-built unitofwork change set to the database
commitState - Variable in class org.eclipse.persistence.internal.sessions.CommitManager
This tracks the commit state for the objects, PENDING, PRE, POST, COMPLETE.
commitToDatabase(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: CommitChanges To The Database from a calculated changeSet
commitToDatabaseWithChangeSet(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Commit the changes to any objects to the parent.
commitToDatabaseWithPreBuiltChangeSet(UnitOfWorkChangeSet, boolean, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Commit pre-built changeSet to the database changeSet to the database.
commitTransaction() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Commit the active database transaction.
commitTransaction() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Commit a transaction on the database.
commitTransaction() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Commit a transaction on the database.
commitTransaction() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: This is internal to the uow, transactions should not be used explicitly in a uow.
commitTransaction() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This is internal to the uow, transactions should not be used explicitly in a uow.
commitTransaction() - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Commit the active database transaction.
commitTransaction() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Commit a transaction on the server.
commitTransaction() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Commit a transaction on the database.
commitTransaction() - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Commit a transaction on the database.
commitTransaction() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Commit a transaction on the database.
commitTransaction(DatabaseAccessor) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for jdbc drivers which do not support autocommit to explicitly commit a transaction This method is a no-op for databases which implement autocommit as expected.
commitTransaction(AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Commit a transaction on the data store.
commitTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Commit a transaction on the database.
commitTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Commit a transaction on the database.
commitTransaction(AbstractSession) - Method in interface org.eclipse.persistence.sessions.ExternalTransactionController
INTERNAL: Commit a transaction externally.
commitTransaction(AbstractSession) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Commit the external transaction.
commitTransaction_impl() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Commit the external transaction.
commitTransaction_impl() - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Commit the external transaction.
commitTransactionAfterWriteChanges() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: After writeChanges() everything has been done except for committing the transaction.
CommitTransactionPending - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
CommunicationException - Exception in org.eclipse.persistence.exceptions
Purpose:This exception wraps all RMI or CORBA or IO exception that may occur.
CommunicationException(String) - Constructor for exception org.eclipse.persistence.exceptions.CommunicationException
 
CommunicationException(String, Exception) - Constructor for exception org.eclipse.persistence.exceptions.CommunicationException
PUBLIC: Creates a CommunicationException.
CommunicationExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for CommunicationException messages.
CommunicationExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.CommunicationExceptionResource
Default constructor.
communicationSocket - Variable in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
The multicast socket used for discovery
comparatorClass - Variable in class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
 
comparatorClassName - Variable in class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
 
compare(Object, Object) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet.ObjectChangeSetComparator
Determine if the receiver is greater or less than the change set.
compare(ClassDescriptor, ClassDescriptor) - Method in class org.eclipse.persistence.internal.helper.DescriptorCompare
 
compare(Schema, Schema) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SchemaCompareByNamespace
 
compare(DatabaseMapping, DatabaseMapping) - Method in class org.eclipse.persistence.internal.helper.MappingCompare
 
compareArrays(Object[], Object[]) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
compareAttributeValues(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Compare the attributes.
compareBigDecimals(BigDecimal, BigDecimal) - Static method in class org.eclipse.persistence.internal.helper.Helper
Compare two BigDecimals.
compareByteArrays(byte[], byte[]) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
compareCharArrays(char[], char[]) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
compareCollectionsForChange(Object, Object, ChangeRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: This method is used to calculate the differences between two collections.
compareCollectionsForChange(Object, Object, ChangeRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: This method is used to calculate the differences between two collections.
compareCollectionsForChange(Object, Object, ChangeRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: This method is used to calculate the differences between two collections.
compareCollectionsForChange(Object, Object, CollectionChangeRecord, AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: This method is used to calculate the differences between two collections.
compareCollectionsForChange(Object, Object, CollectionChangeRecord, AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: This method is used to calculate the differences between two collections.
compareContainers(Object, Object) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Return true if keys are the same.
compareElements(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Compare the non-null elements and return true if they are alike.
compareElements(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Compare the non-null elements and return true if they are alike.
compareElements(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Compare the non-null elements.
compareElements(Object, Object, AbstractSession) - Method in interface org.eclipse.persistence.mappings.structures.ArrayCollectionMapping
Compare the non-null elements and return true if they are alike.
compareElements(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ArrayCollectionMappingHelper
Convenience method.
compareElementsForChange(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Compare the non-null elements and return true if they are alike.
compareElementsForChange(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Compare the non-null elements and return true if they are alike.
compareElementsForChange(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Compare the non-null elements and return true if they are alike.
compareElementsForChange(Object, Object, AbstractSession) - Method in interface org.eclipse.persistence.mappings.structures.ArrayCollectionMapping
Compare the non-null elements and return true if they are alike.
compareElementsForChange(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ArrayCollectionMappingHelper
Convenience method.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Compare the changes between two collections.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMappingHelper
INTERNAL: Build and return the change record that results from comparing the two collection attributes.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: This method is used to create a change record from comparing two aggregate collections
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Compare the changes between two aggregates.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: This method is used to create a change record from comparing two collections.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: This method was created in VisualAge.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: This method compares the changes between two direct collections.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: This method compares the changes between two direct collections.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Build and return the change record that results from comparing the two direct collection attributes.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Build and return the change record that results from comparing the two direct collection attributes.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Compare the clone and backup clone values and return a change record if the value changed.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL: Compare the clone and backup clone values and return a change record if the value changed.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Return an ObjectReferenceChangeRecord describing the change, or null if no change.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ArrayCollectionMappingHelper
INTERNAL: Build and return the change record that results from comparing the two collection attributes.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL: This method is used to create a change record from comparing two collections
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL: This method was created in VisualAge.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL: This method was created in VisualAge.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
INTERNAL: This method was created in VisualAge.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL: This method was created in VisualAge.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
INTERNAL: This method was created in VisualAge.
compareForChange(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
compareForChange(Object, Object, UnitOfWorkChangeSet, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: This method creates a records change set for a particular object.
compareHashtables(Hashtable<?, ?>, Hashtable<?, ?>) - Static method in class org.eclipse.persistence.internal.helper.Helper
PUBLIC: Compare the elements in 2 hashtables to see if they are equal Added Nov 9, 2000 JED Patch 2.5.1.8
compareKeys(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return true if keys are the same in the source as the backup.
compareKeys(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return true if keys are the same in the source as the backup.
compareKeys(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Return true if keys are the same in the source as the backup.
compareLists(List, List) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
Compare two lists.
compareLists(List, List, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareLists(List, List, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.CollectionMapping
Compare two lists.
compareListsAndWrite(List, List, WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Old and new lists are compared and only the changes are written to the database.
compareListsAndWrite(List, List, WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Old and new lists are compared and only the changes are written to the database.
compareListsAndWrite_NonUpdatableListOrderField(List, List, WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Old and new lists are compared and only the changes are written to the database.
compareListsAndWrite_UpdatableListOrderField(List, List, WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Old and new lists are compared and only the changes are written to the database.
compareListsForChange(List, List, ChangeRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: This method is used to calculate the differences between two Lists.
compareMapCollectionForChange(Map, Map, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Determine if an AggregateCollection that is contained as a map has changed by comparing the values in the clone to the values in the backup.
compareObjects(Object, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return if the two object match completely.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMappingHelper
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Compares the two specified objects
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ArrayCollectionMappingHelper
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
INTERNAL: Compare the attributes belonging to this mapping for the objects.
compareObjects(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
compareObjectsAndWrite(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: The memory objects are compared and only the changes are written to the database.
compareObjectsDontMatch(Object, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
TESTING: Return true if the object do not match.
compareObjectsWithoutPrivateOwned(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
Compare two objects if their parts are not private owned
compareObjectsWithoutPrivateOwned(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Compare two objects if their parts are not private owned
compareObjectsWithoutPrivateOwned(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Compare the references of the two objects are the same, not the objects themselves.
compareObjectsWithoutPrivateOwned(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Compare the references of the two objects are the same, not the objects themselves.
compareObjectsWithPrivateOwned(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
Compare two objects if their parts are private owned
compareObjectsWithPrivateOwned(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Compare two objects if their parts are private owned
compareObjectsWithPrivateOwned(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Compare the references of the two objects are the same, and the objects themselves are the same.
compareObjectValues(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Compare the attribute values.
compareObjectValues(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.xdb.DirectToXMLTypeMapping
INTERNAL: Compare the attribute values.
comparePotentialArrays(Object, Object) - Static method in class org.eclipse.persistence.internal.helper.Helper
Compare two potential arrays and return true if they are the same.
compareTo(Object) - Method in class org.eclipse.persistence.internal.expressions.OuterJoinExpressionHolder
 
compareTo(IndexedObject) - Method in class org.eclipse.persistence.internal.helper.IndexedObject
 
compareTo(CacheId) - Method in class org.eclipse.persistence.internal.identitymaps.CacheId
Determine if the receiver is greater or less than the key.
compareTo(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Determine if the receiver is greater or less than the change set.
compareVersions(String, String) - Static method in class org.eclipse.persistence.internal.helper.Helper
INTERNAL: Compares two version in num.num.num.num.num*** format.
compareVersions(List<Integer>, List<Integer>) - Static method in class org.eclipse.persistence.internal.helper.Helper
INTERNAL: Compares two lists of Integers -1, 0, 1 means the first list is less than, equal, greater than the second list.
compareWriteLockValues(Object, Object) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: This method shouldn't be called if supportsWriteLockValuesComparison() returns false.
compareWriteLockValues(Object, Object) - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: This method compares two writeLockValues.
compareWriteLockValues(Object, Object) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: This method compares two writeLockValues.
compareWriteLockValues(Object, Object) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: This method shouldn't be called if supportsWriteLockValuesComparison() returns false.
ComparisonOperator - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
COMPAT_SHORT_PREFIX - Static variable in interface org.eclipse.persistence.internal.helper.DatabaseType
 
COMPAT_SUFFIX - Static variable in interface org.eclipse.persistence.internal.helper.DatabaseType
 
COMPATIBLE_TYPE_NOT_SET - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
compatibleType - Variable in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
compatibleType() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLRecord
(Required) The name of the database OBJECT TYPE that mirrors the record's structure.
compatibleType() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLTable
(Required) The name of the database VARRAY type that mirrors the table's structure.
compatibleTypeNotSet(DatabaseType) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
COMPLETE - Static variable in class org.eclipse.persistence.internal.sessions.CommitManager
The commit is complete for the object.
completeExpression(Expression, Object, Class<?>) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
INTERNAL: This method is used to determine which operation to use for comparison (equal, or a special operation).
completeExpressionForNull(Expression) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
INTERNAL: This method is used when the attribute value is null, but it has to be included at all times.
COMPLEX_TYPE - Static variable in interface org.eclipse.persistence.platform.xml.XMLSchemaReference
 
ComplexContent - Class in org.eclipse.persistence.internal.oxm.schema.model
 
ComplexContent() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.ComplexContent
 
ComplexDatabaseType - Class in org.eclipse.persistence.internal.helper
PUBLIC: Abstract class for Complex Database types (e.g.
ComplexDatabaseType() - Constructor for class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
ComplexPLSQLTypeWrapper - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: a helper class that holds DatabaseType's.
ComplexPLSQLTypeWrapper() - Constructor for class org.eclipse.persistence.internal.sessions.factories.ComplexPLSQLTypeWrapper
 
ComplexPLSQLTypeWrapper(DatabaseType) - Constructor for class org.eclipse.persistence.internal.sessions.factories.ComplexPLSQLTypeWrapper
 
ComplexQueryResult - Class in org.eclipse.persistence.queries
Purpose: Used to return multiple sets of information from a query.
ComplexQueryResult() - Constructor for class org.eclipse.persistence.queries.ComplexQueryResult
 
ComplexType - Class in org.eclipse.persistence.internal.oxm.schema.model
A Value Object class representing XML Schema's complexType.
ComplexType() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
COMPOSITE_INCOMPATIBLE_WITH_SESSIONS_XML - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
COMPOSITE_MEMBER_CANNOT_BE_USED_STANDALONE - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
COMPOSITE_NAME_LOOKUP - Static variable in class org.eclipse.persistence.sessions.JNDIConnector
 
COMPOSITE_TYPE_DESCRIPTION - Static variable in class org.eclipse.persistence.services.ClassSummaryDetailBase
Must override in subclass
COMPOSITE_TYPE_TYPENAME - Static variable in class org.eclipse.persistence.services.ClassSummaryDetailBase
Must override in subclass
COMPOSITE_UNIT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.composite-unit" property indicates if it's a composite persistence unit ("true").
COMPOSITE_UNIT_MEMBER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.composite-unit.member" property indicates if the persistence unit must be a member of a composite persistence unit ("true"), can't be used as an independent persistence unit.
COMPOSITE_UNIT_MEMBER - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.composite-unit.member"
COMPOSITE_UNIT_PROPERTIES - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
The property may be passed to createEntityManager method of a composite persistence unit to pass properties to member persistence units.
COMPOSITE_UNIT_PROPERTIES - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.composite-unit.properties" property may be passed to createEntityManagerFactory method of a composite persistence unit to pass properties to member persistence units.
CompositeCollectionMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​CONVERTER extends CoreConverter,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​SESSION extends CoreSession,​UNMARSHAL_KEEP_AS_ELEMENT_POLICY extends UnmarshalKeepAsElementPolicy,​UNMARSHALLER extends Unmarshaller,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
compositeIncompatibleWithSessionsXml(String) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
INTERNAL: Persistence unit tries to use sessions.xml and to be a composite.
CompositeMember - Annotation Type in org.eclipse.persistence.annotations
A CompositeMember annotation is ignored unless is in composite member persistence unit.
compositeMemberCannotBeUsedStandalone(String) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
INTERNAL: Persistence unit tries to use sessions.xml and to be a composite.
CompositeObjectMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​CONVERTER extends CoreConverter,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​SESSION extends CoreSession,​UNMARSHAL_KEEP_AS_ELEMENT_POLICY extends UnmarshalKeepAsElementPolicy,​UNMARSHALLER extends Unmarshaller,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
compositeObjectMarshal(AbstractMarshalRecord, Object, Field, CoreAbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
INTERNAL: When using the DOM Platform, this method is responsible for marshalling null values for the XML Composite Object Mapping.
compositeObjectMarshal(AbstractMarshalRecord, Object, Field, CoreAbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
INTERNAL
compositeObjectMarshal(XPathFragment, MarshalRecord, Object, CoreSession, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
INTERNAL: When using the SAX Platform, this method is responsible for marshalling null values for the XML Composite Object Mapping.
compositeObjectMarshal(XPathFragment, MarshalRecord, Object, CoreSession, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
INTERNAL
COMPOUND_NAME_LOOKUP - Static variable in class org.eclipse.persistence.sessions.JNDIConnector
 
CompoundExpression - Class in org.eclipse.persistence.internal.expressions
Abstract class for expression that have exactly two children, such as and/or and relations.
CompoundExpression() - Constructor for class org.eclipse.persistence.internal.expressions.CompoundExpression
 
ComputableTask<A,​V> - Interface in org.eclipse.persistence.internal.cache
Computable task.
compute(A) - Method in interface org.eclipse.persistence.internal.cache.ComputableTask
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
compute(ComputableTask<A, V>, A) - Method in class org.eclipse.persistence.internal.cache.AdvancedProcessor
 
compute(ComputableTask<A, V>, A) - Method in interface org.eclipse.persistence.internal.cache.LowLevelProcessor
Waits if necessary for the computation to complete, and then retrieves its result.
compute(ComputableTask<A, V>, A) - Method in class org.eclipse.persistence.internal.cache.Memoizer
 
compute(ComputableTask<A, V>, A) - Method in interface org.eclipse.persistence.internal.cache.Processor
Waits if necessary for the computation to complete, and then retrieves its result.
computeAndSetItemOffset(ReportQuery, List<ReportItem>, int) - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
calculate indexes for given items, given the current Offset
computeBatchReadAttributes() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Compute the cache batched attributes.
computeBatchReadMappingQueries() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Used to optimize joining by pre-computing the nested join queries for the mappings.
computeDescriptorMethodNames() - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
This figures out the best name for each descriptor, first using the local class name then the qualified one for duplicates.
computeDistinct() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: This is used by cursored stream to determine if an expression used distinct as the size must account for this.
computeHash(Object[]) - Method in class org.eclipse.persistence.internal.identitymaps.CacheId
Pre-compute the hash to optimize hash calls.
computeHashCode() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Compute a consistent hash-code for the expression.
computeHashCode() - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: Compute a consistent hash-code for the expression.
computeHashCode() - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: Compute a consistent hash-code for the expression.
computeHashCode() - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: Compute a consistent hash-code for the expression.
computeHashCode() - Method in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
INTERNAL: Compute a consistent hash-code for the expression.
computeHashCode() - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Compute a consistent hash-code for the expression.
computeHashCode() - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
INTERNAL: Compute a consistent hash-code for the expression.
computeHashCode() - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Compute a consistent hash-code for the expression.
computeHashCode() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Compute a consistent hash-code for the expression.
computeHashCode() - Method in class org.eclipse.persistence.internal.expressions.TableExpression
INTERNAL: Compute a consistent hash-code for the expression.
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
computeIndexesForJoinedExpressions(List, int, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
This method is used when computing the indexes for joined mappings.
computeInIndex(PLSQLargument, int) - Method in enum org.eclipse.persistence.internal.helper.DatabaseType.DatabaseTypeHelper
 
computeInIndex(PLSQLargument, int, ListIterator<PLSQLargument>) - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
computeInIndex(PLSQLargument, int, ListIterator<PLSQLargument>) - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
computeInIndex(PLSQLargument, int, ListIterator<PLSQLargument>) - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
computeInIndex(PLSQLargument, int, ListIterator<PLSQLargument>) - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
INTERNAL: Return the parameter index for the IN parameter.
computeInIndex(PLSQLargument, int, ListIterator<PLSQLargument>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCursor
 
computeInIndex(PLSQLargument, int, ListIterator<PLSQLargument>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
computeJoiningMappingIndexes(boolean, AbstractSession, int) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
For joining the resulting rows include the field/values for many objects.
computeJoiningMappingQueries(AbstractSession) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Used to optimize joining by pre-computing the nested join queries for the mappings.
computeMaxRowsForSQL(int, int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Use the JDBC maxResults and firstResultIndex setting to compute a value to use when limiting the results of a query in SQL.
computeMaxRowsForSQL(int, int) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL: Use the JDBC maxResults and firstResultIndex setting to compute a value to use when limiting the results of a query in SQL.
computeMaxRowsForSQL(int, int) - Method in class org.eclipse.persistence.platform.database.H2Platform
INTERNAL: Use the JDBC maxResults and firstResultIndex setting to compute a value to use when limiting the results of a query in SQL.
computeMaxRowsForSQL(int, int) - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
computeMaxRowsForSQL(int, int) - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
INTERNAL: Use the JDBC maxResults and firstResultIndex setting to compute a value to use when limiting the results of a query in SQL.
computeMaxRowsForSQL(int, int) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Use the JDBC maxResults and firstResultIndex setting to compute a value to use when limiting the results of a query in SQL.
computeMaxRowsForSQL(int, int) - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Use the JDBC maxResults and firstResultIndex setting to compute a value to use when limiting the results of a query in SQL.
computeMaxRowsForSQL(int, int) - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Use the JDBC maxResults and firstResultIndex setting to compute a value to use when limiting the results of a query in SQL.
computeNestedQueriesForBatchReadExpressions(List<Expression>) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: This method is used when computing the nested queries for batch read mappings.
computeNestedQueriesForJoinedExpressions(List, AbstractSession, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
This method is used when computing the nested queries for joined mappings.
computeOutIndex(PLSQLargument, int) - Method in enum org.eclipse.persistence.internal.helper.DatabaseType.DatabaseTypeHelper
 
computeOutIndex(PLSQLargument, int, ListIterator<PLSQLargument>) - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
computeOutIndex(PLSQLargument, int, ListIterator<PLSQLargument>) - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
computeOutIndex(PLSQLargument, int, ListIterator<PLSQLargument>) - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
computeOutIndex(PLSQLargument, int, ListIterator<PLSQLargument>) - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
INTERNAL: Return the parameter index for the OUT parameter.
computeOutIndex(PLSQLargument, int, ListIterator<PLSQLargument>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCursor
 
computeOutIndex(PLSQLargument, int, ListIterator<PLSQLargument>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
computeTables() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Computes all aliases which will appear in the FROM clause.
computeTablesFromTables() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
If there is no where clause, alias the tables from the tables list directly.
concat() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
concat(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the concatenation of the two string values.
Concat - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
concatenateContainers(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Build a new container, add the contents of each of the specified containers to it, and return it.
concatenateContainers(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Build a new container, add the contents of each of the specified containers to it, and return it.
concatenateMaps(Map<? extends K, ? extends V>, Map<? extends K, ? extends V>) - Static method in class org.eclipse.persistence.internal.helper.Helper
Merge the two Maps into a new HashMap.
concatenateUniqueLists(List<? extends E>, List<? extends E>) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return a new List with no duplicated values.
concatenateUniqueVectors(Vector<? extends E>, Vector<? extends E>) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return a new vector with no duplicated values.
concatenateVectors(Vector<? extends E>, Vector<? extends E>) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
concatOperator() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: The concat operator is of the form ....
concatOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
DB2 z/OS requires that at least one argument be a known type
concatOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
concreteSubclassCalls - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Allow concrete subclasses calls to be prepared and cached for inheritance queries.
concreteSubclassJoinedMappingIndexes - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Allow concrete subclasses joined mapping indexes to be prepared and cached for inheritance queries.
concreteSubclassQueries - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Allow concrete subclasses queries to be prepared and cached for inheritance queries.
CONCUR_READ_ONLY - Static variable in class org.eclipse.persistence.queries.ScrollableCursorPolicy
JDBC 2.0 The concurrency mode for a ResultSet object that may NOT be updated.
CONCUR_UPDATABLE - Static variable in class org.eclipse.persistence.queries.ScrollableCursorPolicy
JDBC 2.0 The concurrency mode for a ResultSet object that may be updated.
CONCURRENCY_MANAGER_ACQUIRE_WAIT_TIME - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This system property in milliseconds can control thread management in org.eclipse.persistence.internal.helper.ConcurrencyManager.
CONCURRENCY_MANAGER_ACQUIRE_WAIT_TIME - Static variable in class org.eclipse.persistence.config.SystemProperties
This system property in milliseconds can control thread management in org.eclipse.persistence.internal.helper.ConcurrencyManager.
CONCURRENCY_MANAGER_ALLOW_CONCURRENCY_EXCEPTION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This property control (enable/disable) if ConcurrencyException fired when dead-lock diagnostic is enabled.
CONCURRENCY_MANAGER_ALLOW_CONCURRENCY_EXCEPTION - Static variable in class org.eclipse.persistence.config.SystemProperties
This property control (enable/disable) if ConcurrencyException fired when dead-lock diagnostic is enabled.
CONCURRENCY_MANAGER_ALLOW_INTERRUPTED_EXCEPTION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This property control (enable/disable) if InterruptedException fired when dead-lock diagnostic is enabled.
CONCURRENCY_MANAGER_ALLOW_INTERRUPTED_EXCEPTION - Static variable in class org.eclipse.persistence.config.SystemProperties
This property control (enable/disable) if InterruptedException fired when dead-lock diagnostic is enabled.
CONCURRENCY_MANAGER_ALLOW_STACK_TRACE_READ_LOCK - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This property control (enable/disable) collection debug/trace information during ReadLock acquisition, when dead-lock diagnostic is enabled.
CONCURRENCY_MANAGER_ALLOW_STACK_TRACE_READ_LOCK - Static variable in class org.eclipse.persistence.config.SystemProperties
This property control (enable/disable) collection debug/trace information during ReadLock acquisition, when dead-lock diagnostic is enabled.
CONCURRENCY_MANAGER_BUILD_OBJECT_COMPLETE_WAIT_TIME - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This system property in milliseconds can control thread management in org.eclipse.persistence.internal.helper.ConcurrencyManager.
CONCURRENCY_MANAGER_BUILD_OBJECT_COMPLETE_WAIT_TIME - Static variable in class org.eclipse.persistence.config.SystemProperties
This system property in milliseconds can control thread management in org.eclipse.persistence.internal.helper.ConcurrencyManager.
CONCURRENCY_MANAGER_MAX_FREQUENCY_DUMP_MASSIVE_MESSAGE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This system property in milliseconds can control thread management in org.eclipse.persistence.internal.helper.ConcurrencyManager and org.eclipse.persistence.internal.helper.ConcurrencyUtil.
CONCURRENCY_MANAGER_MAX_FREQUENCY_DUMP_MASSIVE_MESSAGE - Static variable in class org.eclipse.persistence.config.SystemProperties
This system property in milliseconds can control thread management in org.eclipse.persistence.internal.helper.ConcurrencyManager and org.eclipse.persistence.internal.helper.ConcurrencyUtil.
CONCURRENCY_MANAGER_MAX_FREQUENCY_DUMP_TINY_MESSAGE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This system property in milliseconds can control thread management in org.eclipse.persistence.internal.helper.ConcurrencyManager and org.eclipse.persistence.internal.helper.ConcurrencyUtil.
CONCURRENCY_MANAGER_MAX_FREQUENCY_DUMP_TINY_MESSAGE - Static variable in class org.eclipse.persistence.config.SystemProperties
This system property in milliseconds can control thread management in org.eclipse.persistence.internal.helper.ConcurrencyManager and org.eclipse.persistence.internal.helper.ConcurrencyUtil.
CONCURRENCY_MANAGER_MAX_SLEEP_TIME - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This system property in milliseconds can control thread management in org.eclipse.persistence.internal.helper.ConcurrencyManager.
CONCURRENCY_MANAGER_MAX_SLEEP_TIME - Static variable in class org.eclipse.persistence.config.SystemProperties
This system property in milliseconds can control thread management in org.eclipse.persistence.internal.helper.ConcurrencyManager.
CONCURRENCY_MANAGER_OBJECT_BUILDING_NO_THREADS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This property control number of threads in semaphore in ObjectBuilder If "eclipselink.concurrency.manager.object.building.semaphore" property is true default value is 10.
CONCURRENCY_MANAGER_OBJECT_BUILDING_NO_THREADS - Static variable in class org.eclipse.persistence.config.SystemProperties
This property control number of threads in semaphore in ObjectBuilder If "eclipselink.concurrency.manager.object.building.semaphore" property is true default value is 10.
CONCURRENCY_MANAGER_USE_SEMAPHORE_TO_SLOW_DOWN_OBJECT_BUILDING - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This property control (enable/disable) semaphore in ObjectBuilder
CONCURRENCY_MANAGER_USE_SEMAPHORE_TO_SLOW_DOWN_OBJECT_BUILDING - Static variable in class org.eclipse.persistence.config.SystemProperties
This property control (enable/disable) semaphore in ObjectBuilder
CONCURRENCY_MANAGER_USE_SEMAPHORE_TO_SLOW_DOWN_WRITE_LOCK_MANAGER_ACQUIRE_REQUIRED_LOCKS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
CONCURRENCY_MANAGER_USE_SEMAPHORE_TO_SLOW_DOWN_WRITE_LOCK_MANAGER_ACQUIRE_REQUIRED_LOCKS - Static variable in class org.eclipse.persistence.config.SystemProperties
CONCURRENCY_MANAGER_WRITE_LOCK_MANAGER_ACQUIRE_REQUIRED_LOCKS_NO_THREADS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This property control number of threads in semaphore in WriteLockManager.acquireRequiredLocks(org.eclipse.persistence.internal.sessions.MergeManager, org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet) If "eclipselink.concurrency.manager.write.lock.manager.semaphore" property is true default value is 2.
CONCURRENCY_MANAGER_WRITE_LOCK_MANAGER_ACQUIRE_REQUIRED_LOCKS_NO_THREADS - Static variable in class org.eclipse.persistence.config.SystemProperties
This property control number of threads in semaphore in WriteLockManager.acquireRequiredLocks(org.eclipse.persistence.internal.sessions.MergeManager, org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet) If "eclipselink.concurrency.manager.write.lock.manager.semaphore" property is true default value is 2.
CONCURRENCY_SEMAPHORE_LOG_TIMEOUT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This property control timeout between log messages in ConcurrencySemaphore.acquireSemaphoreIfAppropriate(boolean) when method/thread tries to get permit for the execution.
CONCURRENCY_SEMAPHORE_LOG_TIMEOUT - Static variable in class org.eclipse.persistence.config.SystemProperties
This property control timeout between log messages in ConcurrencySemaphore.acquireSemaphoreIfAppropriate(boolean) when method/thread tries to get permit for the execution.
CONCURRENCY_SEMAPHORE_MAX_TIME_PERMIT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This property control semaphore the maximum time to wait for a permit in ConcurrencySemaphore.acquireSemaphoreIfAppropriate(boolean) It's passed to Semaphore.tryAcquire(long, TimeUnit) Default value is 2000 (unit is ms).
CONCURRENCY_SEMAPHORE_MAX_TIME_PERMIT - Static variable in class org.eclipse.persistence.config.SystemProperties
This property control semaphore the maximum time to wait for a permit in ConcurrencySemaphore.acquireSemaphoreIfAppropriate(boolean) It's passed to Semaphore.tryAcquire(long, TimeUnit) Default value is 2000 (unit is ms).
ConcurrencyException - Exception in org.eclipse.persistence.exceptions
Purpose: Concurrency deadlock or interupts will raise this exception.
ConcurrencyException(String) - Constructor for exception org.eclipse.persistence.exceptions.ConcurrencyException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
ConcurrencyException(String, Exception) - Constructor for exception org.eclipse.persistence.exceptions.ConcurrencyException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
ConcurrencyExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for ConcurrencyException messages.
ConcurrencyExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.ConcurrencyExceptionResource
Default constructor.
ConcurrencyManager - Class in org.eclipse.persistence.internal.helper
INTERNAL:
ConcurrencyManager() - Constructor for class org.eclipse.persistence.internal.helper.ConcurrencyManager
Initialize the newly allocated instance of this class.
ConcurrencyManagerState - Class in org.eclipse.persistence.internal.helper.type
 
ConcurrencyManagerState(Map<Thread, ReadLockManager>, Map<Thread, DeferredLockManager>, Map<Thread, Set<ConcurrencyManager>>, Map<Thread, String>, Map<Thread, ConcurrencyManager>, Map<Thread, String>, Set<Thread>, Map<Thread, String>, Map<ConcurrencyManager, CacheKeyToThreadRelationships>, Map<Thread, Set<Object>>) - Constructor for class org.eclipse.persistence.internal.helper.type.ConcurrencyManagerState
Create a new ConcurrencyManagerState.
ConcurrencySemaphore - Class in org.eclipse.persistence.internal.helper
 
ConcurrencySemaphore(ThreadLocal<Boolean>, int, Semaphore, Object, String) - Constructor for class org.eclipse.persistence.internal.helper.ConcurrencySemaphore
Constructor to create ConcurrencySemaphore
ConcurrencyUtil - Class in org.eclipse.persistence.internal.helper
 
CONCURRENT_READ_WRITE - Static variable in class org.eclipse.persistence.sessions.DatasourceLogin
Reads and unit of work merges can occur concurrently.
ConcurrentFixedCache - Class in org.eclipse.persistence.internal.helper
Provide a concurrent fixed size caching mechanism.
ConcurrentFixedCache() - Constructor for class org.eclipse.persistence.internal.helper.ConcurrentFixedCache
Create a new concurrent cache, with a fixed size of 100.
ConcurrentFixedCache(int) - Constructor for class org.eclipse.persistence.internal.helper.ConcurrentFixedCache
Create a new concurrent cache, with the max size.
config(String) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
config(String) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: This method is called when a config level message needs to be logged.
config(String, String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
CONFIG - org.eclipse.persistence.logging.LogLevel
Configuration information logging level.
CONFIG - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
CONFIG_FACTORY_NAME_PROPERTY_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CONFIG_FACTORY_NAME_PROPERTY_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CONFIG_LABEL - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
CONFIG_METHOD_NOT_DEFINED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CONFIG_PREFIX - Static variable in class org.eclipse.persistence.logging.AbstractSessionLog
Represents prefix to logged config
configFactoryNamePropertyNotFound(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
configFactoryNamePropertyNotSpecified(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
configMethodNotDefined(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
CONFIGURATION_ERROR_CLASS_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
CONFIGURATION_ERROR_NEW_INSTANCE_ILLEGAL_ACCESS_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
CONFIGURATION_ERROR_NEW_INSTANCE_INSTANTIATION_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
configurationErrorClassNotFound(String) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
configurationErrorNewInstanceIllegalAccessException(IllegalAccessException, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
configurationErrorNewInstanceInstantiationException(InstantiationException, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
configure(ClassDescriptor, String...) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Initialize a new or existing descriptor configuring the necessary policies as well as
configureConnectionSpec(ConnectionFactory) - Method in class org.eclipse.persistence.eis.EISLogin
PUBLIC: Configure the login to connect through a non-managed connection factory and the default getConnection().
configureConnectionSpec(ConnectionFactory, ConnectionSpec) - Method in class org.eclipse.persistence.eis.EISLogin
PUBLIC: Configure the login to connect through a non-managed connection factory and adapter connection spec.
configureConnectionSpec(String) - Method in class org.eclipse.persistence.eis.EISLogin
PUBLIC: Configure the login to connect through a JDNI managed connection factory and the default getConnection().
configureConnectionSpec(String, ConnectionSpec) - Method in class org.eclipse.persistence.eis.EISLogin
PUBLIC: Configure the login to connect through a JDNI managed connection factory and adapter connection spec.
configureDatabaseCall(DatabaseCall) - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Set the call level query options into the call.
configureNestedRow(AbstractRecord, AbstractRecord) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
configureProfiler(Session) - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: configureProfiler(): set default performance profiler used in this server.
configureSequencing(String, String) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Configure default sequencing.
configureSequencing(Sequence, String, String) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Configure sequencing specifying the sequence type to use.
CONFLICTING_ANNOTATIONS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CONFLICTING_NAMED_ANNOTATIONS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CONFLICTING_NAMED_XML_ELEMENTS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CONFLICTING_SEQUENCE_AND_TABLE_GENERATORS_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CONFLICTING_SEQUENCE_NAME_AND_TABLE_PK_COLUMN_VALUE_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CONFLICTING_XML_ELEMENTS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
conflictingAccessMethodsForEmbeddable(String, String, Object, String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
conflictingAccessTypeForEmbeddable(String, String, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
conflictingAnnotations(Object, Object, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
conflictingNamedAnnotations(String, Object, Object, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
conflictingNamedXMLElements(String, String, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
conflictingSequenceAndTableGeneratorsSpecified(String, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
conflictingSequenceNameAndTablePkColumnValueSpecified(String, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
conflictingXMLElements(String, Object, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
CONFLICTNG_ACCESS_METHODS_FOR_EMBEDDABLE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CONFLICTNG_ACCESS_TYPE_FOR_EMBEDDABLE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
Conform - Static variable in class org.eclipse.persistence.config.CacheUsageIndirectionPolicy
If conforming encounters an uninstantiated indirection/lazy object it is assumed to conform.
conformAllDescriptors() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set all this project's descriptors to conform all read queries within the context of the unit of work.
conformBetween(Object, Object) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Compare between in memory.
conformIndividualResult(Object, UnitOfWorkImpl, AbstractRecord, Expression, Map) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Conforms and registers an individual result.
conformLike(Object, Object) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Compare like in memory.
conformLike(Object, Object) - Static method in class org.eclipse.persistence.internal.helper.JavaPlatform
INTERNAL: An implementation of in memory queries with Like which uses the regular expression framework.
conformRegexp(Object, Object) - Static method in class org.eclipse.persistence.internal.helper.JavaPlatform
INTERNAL: An implementation of in memory queries with Regexp which uses the regular expression framework.
conformResult(Object, UnitOfWorkImpl, AbstractRecord, boolean) - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Conform the result if specified.
conformResult(Object, UnitOfWorkImpl, AbstractRecord, boolean) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Conform the result in the UnitOfWork.
conformResultsInUnitOfWork() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: The cache will checked completely, if the object is not found the database will be queried, and the database result will be verified with what is in the cache and/or unit of work including new objects.
ConformResultsInUnitOfWork - Static variable in class org.eclipse.persistence.config.CacheUsage
Configure the query results to be conformed with the current persistence context.
ConformResultsInUnitOfWork - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
connect() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Connect the session only.
connect() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Connect not required.
connect() - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Startup the server session, also startup all of the connection pools.
connect(Properties, Session) - Method in class org.eclipse.persistence.eis.EISConnectionSpec
INTERNAL: Required for interface, but never used, for JDBC.
connect(Properties, Session) - Method in interface org.eclipse.persistence.sessions.Connector
INTERNAL: Connect with the specified properties and return the Connection.
connect(Properties, Session) - Method in class org.eclipse.persistence.sessions.DefaultConnector
INTERNAL: Connect with the specified properties and session.
connect(Properties, Session) - Method in class org.eclipse.persistence.sessions.JNDIConnector
INTERNAL: Connect with the specified properties and return the Connection.
connect(Accessor) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Connect the session only (this must be the write connection as the read is shared).
connect(Login, AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Connect to the data store using the configuration information in the login.
connect(Login, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Connect to the datasource.
connectBackToRemote(RemoteConnection) - Method in class org.eclipse.persistence.sessions.coordination.broadcast.BroadcastTransportManager
INTERNAL: Prepare receiving messages by registering this connection as a listener to the Subscriber.
connectBackToRemote(RemoteConnection) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: This method is called by the remote command manager when this service should connect back ('handshake') to the service from which this remote connection came.
connectByExpression - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
connectByExpression - Variable in class org.eclipse.persistence.queries.ReadAllQuery
 
connectedTime - Variable in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: connectedTime indicates the exact time this session was logged in.
connectInternal(Login, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Connect to the database.
connectInternal(Login, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Connect to the database.
connectInternal(Login, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLAccessor
By default the SDK does not have a connection, so use an object as a placeholder.
connection - Variable in class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
Connection to send to
connection - Variable in class org.eclipse.persistence.logging.SessionLogEntry
 
CONNECTION - org.eclipse.persistence.logging.LogCategory
 
CONNECTION - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
CONNECTION_POLICY - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
ConnectionPolicy Allows to specify an entire ConnectionPolicy.
CONNECTION_POOL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Allow configuring a "eclipselink.connection-pool." properties.
CONNECTION_POOL_FAILOVER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "failover" property.
This can be append to a connection pool property, i.e.
CONNECTION_POOL_INITIAL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "initial" property.
This can be append to any connection pool property, i.e.
CONNECTION_POOL_INTERNALLY_POOL_DATASOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Tell EclipseLink to use it's internal connection pool to pool connections from a datasource.
CONNECTION_POOL_JTA_DATA_SOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jtaDataSource" property.
This can be append to a connection pool property, i.e.
CONNECTION_POOL_MAX - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "max" property.
This can be append to any connection pool property, i.e.
CONNECTION_POOL_MAX_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
CONNECTION_POOL_MIN - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "min" property.
This can be append to any connection pool property, i.e.
CONNECTION_POOL_MIN_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
CONNECTION_POOL_NON_JTA_DATA_SOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "nonJtaDataSource" property.
This can be append to a connection pool property, i.e.
CONNECTION_POOL_PASSWORD - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "password" property.
This can be append to a connection pool property, i.e.
CONNECTION_POOL_READ - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Allow configuring the "eclipselink.connection-pool.read." properties.
CONNECTION_POOL_SEQUENCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Allow configuring the "eclipselink.connection-pool.sequence." properties.
CONNECTION_POOL_SHARED - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "shared" property.
This can be append to the read connection pool, i.e.
CONNECTION_POOL_URL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "url" property.
This can be append to a connection pool property, i.e.
CONNECTION_POOL_USER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "user" property.
This can be append to a connection pool property, i.e.
CONNECTION_POOL_WAIT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "wait" property.
This can be append to any connection pool property, i.e.
CONNECTION_STRING - Static variable in class org.eclipse.persistence.logging.AbstractSessionLog
Connection string
ConnectionCustomizer - Class in org.eclipse.persistence.internal.databaseaccess
PUBLIC: The base class for connection customization.
ConnectionCustomizer(Accessor, Session) - Constructor for class org.eclipse.persistence.internal.databaseaccess.ConnectionCustomizer
INTERNAL: Constructor accepts the accessor to which the customizer will be applied and the session that used for customization.
connectionFactory - Variable in class org.eclipse.persistence.eis.EISConnectionSpec
 
connectionFactoryName - Variable in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
 
connectionHealthValidatedOnError - Variable in class org.eclipse.persistence.sessions.DatabaseLogin
On an SQL Exception EclipseLink will ping the database to determine if the connection used can continue to be used for queries.
ConnectionManagement - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
ConnectionPing - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
connectionPolicy - Variable in class org.eclipse.persistence.sessions.server.ClientSession
 
ConnectionPolicy - Class in org.eclipse.persistence.sessions.server
Purpose: Used to specify how a client session's should be allocated.
ConnectionPolicy() - Constructor for class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: A connection policy is used to define how the client session connection should be acquired.
ConnectionPolicy(String) - Constructor for class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: A connection policy is used to define how the client session connection should be acquired.
ConnectionPolicy(Login) - Constructor for class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: A connection policy is used to define how the client session connection should be acquired.
ConnectionPolicy.ExclusiveMode - Enum in org.eclipse.persistence.sessions.server
Default value Transactional causes creation of ClientSession, the other two values - ExclusiveIsolatedClientSession.
ConnectionPolicyConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.pool
INTERNAL:
ConnectionPolicyConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPolicyConfig
 
connectionPool - Variable in class org.eclipse.persistence.descriptors.partitioning.PinnedPartitioningPolicy
 
connectionPool - Variable in class org.eclipse.persistence.descriptors.partitioning.RangePartition
 
connectionPool() - Method in annotation type org.eclipse.persistence.annotations.PinnedPartitioning
The connection pool name to pin queries to.
connectionPool() - Method in annotation type org.eclipse.persistence.annotations.RangePartition
The connection pool to route queries to for this range.
connectionPool() - Method in annotation type org.eclipse.persistence.annotations.ValuePartition
The connection pool to route queries to for this value.
ConnectionPool - Class in org.eclipse.persistence.sessions.server
Purpose: Used to specify how connection should be pooled in a server session.
ConnectionPool() - Constructor for class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: A connection pool is used to specify how connection should be pooled in a server session.
ConnectionPool(String, Login, int, int, int, ServerSession) - Constructor for class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: A connection pool is used to specify how connection should be pooled in a server session.
ConnectionPool(String, Login, int, int, ServerSession) - Constructor for class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: A connection pool is used to specify how connection should be pooled in a server session.
ConnectionPool(String, Login, ServerSession) - Constructor for class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: A connection pool is used to specify how connection should be pooled in a server session.
ConnectionPoolConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.pool
INTERNAL:
ConnectionPoolConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPoolConfig
 
connectionPools - Variable in class org.eclipse.persistence.descriptors.partitioning.HashPartitioningPolicy
 
connectionPools - Variable in class org.eclipse.persistence.descriptors.partitioning.ReplicationPartitioningPolicy
 
connectionPools - Variable in class org.eclipse.persistence.sessions.server.ServerSession
 
connectionPools() - Method in annotation type org.eclipse.persistence.annotations.HashPartitioning
List of connection pool names to partition across.
connectionPools() - Method in annotation type org.eclipse.persistence.annotations.ReplicationPartitioning
List of connection pool names to load balance across.
connectionPools() - Method in annotation type org.eclipse.persistence.annotations.RoundRobinPartitioning
List of connection pool names to load balance across.
connectionPools() - Method in annotation type org.eclipse.persistence.annotations.UnionPartitioning
List of connection pool names to load balance across.
connectionProperties() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
INTERNAL: Get platform specific connection properties.
connectionProperties() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
 
connectionsAvailable - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
connectionSpec - Variable in class org.eclipse.persistence.eis.EISConnectionSpec
 
connectionsToExternalServices - Variable in class org.eclipse.persistence.sessions.coordination.TransportManager
Connections to other services
connectionsUsed - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
connector - Variable in class org.eclipse.persistence.sessions.DatasourceLogin
Provide a little flexibility for connecting to a database
Connector - Interface in org.eclipse.persistence.sessions
Purpose: Define an interface for supplying TopLink with a Connection to a JDBC database.
Connects - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
connectToDatasource(Accessor, Session) - Method in class org.eclipse.persistence.eis.EISLogin
Connect to the EIS adapter and return the Connection.
connectToDatasource(Accessor, Session) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Connect to the datasource, and return the driver level connection object.
connectToDatasource(Accessor, Session) - Method in interface org.eclipse.persistence.sessions.Login
INTERNAL: Connect to the datasource, and return the driver level connection object.
connectToDataSource(EISAccessor, Properties) - Method in class org.eclipse.persistence.eis.EISConnectionSpec
Connect with the specified properties and return the Connection.
ConnectToHostCommand - Class in org.eclipse.persistence.internal.sessions.coordination
Purpose: This class provides an implementation of an internal RCM Command.
ConnectToHostCommand() - Constructor for class org.eclipse.persistence.internal.sessions.coordination.ConnectToHostCommand
 
ConstantExpression - Class in org.eclipse.persistence.internal.expressions
Used for wrapping constant values.
ConstantExpression() - Constructor for class org.eclipse.persistence.internal.expressions.ConstantExpression
 
ConstantExpression(Object, Expression) - Constructor for class org.eclipse.persistence.internal.expressions.ConstantExpression
 
Constants - Class in org.eclipse.persistence.internal.oxm
 
Constants() - Constructor for class org.eclipse.persistence.internal.oxm.Constants
 
ConstantTransformer - Class in org.eclipse.persistence.mappings.transformers
Purpose: Allows a field to always be mapped to a constant value.
ConstantTransformer() - Constructor for class org.eclipse.persistence.mappings.transformers.ConstantTransformer
 
ConstantTransformer(Object) - Constructor for class org.eclipse.persistence.mappings.transformers.ConstantTransformer
PUBLIC: Return a constant transformer for the constant value.
constraint - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
CONSTRAINT_VIOLATION - Static variable in exception org.eclipse.persistence.exceptions.BeanValidationException
 
constraintDependencies - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
constraintViolation(Object[], Throwable) - Static method in exception org.eclipse.persistence.exceptions.BeanValidationException
 
constructor - Variable in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
constructor - Variable in class org.eclipse.persistence.queries.ConstructorReportItem
 
constructor - Variable in class org.eclipse.persistence.queries.ConstructorResult
 
constructorArgTypes - Variable in class org.eclipse.persistence.queries.ConstructorReportItem
 
constructorArgTypes - Variable in class org.eclipse.persistence.queries.ConstructorResult
 
constructorClassNotFound - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
constructorClassNotFound(String, int, int, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
constructorMappings - Variable in class org.eclipse.persistence.queries.ConstructorReportItem
 
ConstructorQueryMappings - Class in org.eclipse.persistence.internal.jpa.jpql
This object scans a DatabaseQuery and checks if it's a constructor query.
ConstructorReportItem - Class in org.eclipse.persistence.queries
Purpose: An item specifying a class constructor method to be used in a ReportQuery's returned results.
ConstructorReportItem() - Constructor for class org.eclipse.persistence.queries.ConstructorReportItem
Create a new constructor item.
ConstructorReportItem(String) - Constructor for class org.eclipse.persistence.queries.ConstructorReportItem
Create a new constructor item.
ConstructorResult - Class in org.eclipse.persistence.queries
Purpose: Concrete class to represent the ConstructorResult structure as defined by the JPA 2.1 Persistence specification.
ConstructorResult() - Constructor for class org.eclipse.persistence.queries.ConstructorResult
Default constructor is protected.
ConstructorResult(Class<?>) - Constructor for class org.eclipse.persistence.queries.ConstructorResult
Constructor accepting target class.
ConstructorResult(String) - Constructor for class org.eclipse.persistence.queries.ConstructorResult
Constructor accepting target class name.
CONTAINER_POLICY_DOES_NOT_USE_KEYS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
containerBeans - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
containerClass - Variable in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
The concrete container class.
containerClassName - Variable in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
 
ContainerIndirectionPolicy - Class in org.eclipse.persistence.internal.indirection
Purpose: Provide ability for developers to wrap ValueHolders (Basic Indirection)
ContainerIndirectionPolicy() - Constructor for class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Construct a new indirection policy.
containerInstance() - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Return an instance of the container class.
containerInstance() - Method in class org.eclipse.persistence.internal.queries.ArrayListContainerPolicy
INTERNAL: Return a new ArrayList.
containerInstance() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return an instance of the container class.
containerInstance() - Method in class org.eclipse.persistence.internal.queries.IndirectListContainerPolicy
INTERNAL: Return a new Vector.
containerInstance() - Method in class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
INTERNAL Override from ContainerPolicy.
containerInstance() - Method in class org.eclipse.persistence.internal.queries.VectorContainerPolicy
INTERNAL: Return a new Vector.
containerInstance(int) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Return an instance of the container class with the specified initial capacity.
containerInstance(int) - Method in class org.eclipse.persistence.internal.queries.ArrayListContainerPolicy
INTERNAL: Return a new ArrayList.
containerInstance(int) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return an instance of the container class with the specified initial capacity.
containerInstance(int) - Method in class org.eclipse.persistence.internal.queries.IndirectListContainerPolicy
INTERNAL: Return a new Vector.
containerInstance(int) - Method in class org.eclipse.persistence.internal.queries.VectorContainerPolicy
INTERNAL: Return a new Vector.
ContainerMapping - Interface in org.eclipse.persistence.mappings
Interface used by clients to interact with the assorted mappings that use ContainerPolicy.
containerPolicy - Variable in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
PERF: Cache the mappings container policy.
containerPolicy - Variable in class org.eclipse.persistence.mappings.CollectionMapping
 
containerPolicy - Variable in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
 
containerPolicy - Variable in class org.eclipse.persistence.queries.DataReadQuery
 
containerPolicy - Variable in class org.eclipse.persistence.queries.ReadAllQuery
Used for collection and stream support.
ContainerPolicy - Class in org.eclipse.persistence.internal.queries
Purpose: Used to support collections in read queries.
ContainerPolicy() - Constructor for class org.eclipse.persistence.internal.queries.ContainerPolicy
Default constructor.
containerPolicyDoesNotUseKeys(ContainerPolicy, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
containerPolicyIsValid() - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return whether the container policy is valid for the indirection policy.
containerUnitOfWork - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
This is only used for EJB entity beans to manage beans accessed in a transaction context.
ContainerValue - Interface in org.eclipse.persistence.internal.oxm
INTERNAL:
containingDescriptor - Variable in class org.eclipse.persistence.internal.expressions.FromAliasExpression
 
contains(Object) - Method in class org.eclipse.persistence.indirection.IndirectList
PUBLIC:
contains(Object) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
contains(Object) - Method in class org.eclipse.persistence.indirection.IndirectSet
 
contains(Object) - Method in class org.eclipse.persistence.internal.helper.IdentityHashSet
Returns true if this IdentityHashSet contains the given object.
contains(Object) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
Returns true if this list contains the specified contents.
contains(Object) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
contains(Object) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
If it does not contain the object must wait until it is complete.
contains(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Check if the value is contained in the row.
contains(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.EntrySet
 
contains(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.KeySet
 
contains(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.ValuesSet
 
contains(Object) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
PUBLIC: Check if the value is contained in the row.
contains(Object) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
PUBLIC: Check if the value is contained in the row.
contains(Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Check if the value is contained in the result.
contains(Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult.EntrySet
 
contains(Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult.KeySet
 
contains(Object, boolean) - Method in class org.eclipse.persistence.internal.oxm.record.MarshalRecord.CycleDetectionStack
 
contains(Object, Object) - Method in class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
INTERNAL: Return the true if element exists in container.
contains(Object, Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return whether element exists in container.
contains(Object, Object) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return the true if element exists in container.
contains(Object, Object, ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Check if the object is contained in the collection.
contains(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Check if the object is contained in the collection.
contains(String) - Method in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
 
containsAll(Collection) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
containsAll(Collection<?>) - Method in class org.eclipse.persistence.indirection.IndirectList
 
containsAll(Collection<?>) - Method in class org.eclipse.persistence.indirection.IndirectSet
 
containsAll(Collection<?>) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
containsAll(Collection<?>) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
If it does not contain the object must wait until it is complete.
containsAllKeyWords(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that performs a key word search.
containsAnyKeyWords(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that performs a key word search.
containsAttribute(String) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Return if the attribute is defined in the group.
containsAttributeInternal(String) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL: Return if the attribute is defined in the group.
containsChangesFromSynchronization() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Convenience method used to query this change set after it has been sent by cache synchronization.
containsIndex() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
containsKey(Object) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
containsKey(Object) - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Returns true if this IdentityWeakHashMap contains a mapping for the given key.
containsKey(Object) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
containsKey(Object) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Return true if an CacheKey with the primary key is in the map.
containsKey(Object) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Return true if an CacheKey with the primary key is in the map.
containsKey(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Check if the field is contained in the row.
containsKey(Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Check if the key is contained in the result.
containsKey(Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Return true if an CacheKey with the primary key is in the map.
containsKey(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Return true if an CacheKey with the primary key is in the map.
containsKey(String) - Method in class org.eclipse.persistence.eis.EISMappedRecord
Check if the field is contained in the row.
containsKey(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Check if the field is contained in the row.
containsKey(DatabaseField) - Method in class org.eclipse.persistence.eis.EISMappedRecord
Check if the field is contained in the row.
containsKey(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: Check if the field is contained in the row.
containsKey(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
INTERNAL: Check if the field is contained in the row.
containsKey(DatabaseField) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Check if the field is contained in the row.
containsMethod(MethodDefinition) - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
containsObject(Class<?>, String) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Check if the object is registered given its name.
containsObject(Object, String) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Check if the object is registered given its name.
containsObjectInIdentityMap(Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Return if their is an object for the primary key.
containsObjectInIdentityMap(Object) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Returns true if the identity map contains an Object with the same primary key and Class type of the given domainObject.
containsObjectInIdentityMap(Object, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Return if their is an object for the primary key.
containsObjectInIdentityMap(Object, Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Returns true if the identity map contains an Object with the same primary key and Class type as those specified.
containsObjectInIdentityMap(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Return if their is an object for the primary key.
containsObjectInIdentityMap(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
ADVANCED: Return if their is an object for the primary key.
containsObjectInIdentityMap(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
INTERNAL: Return if their is an object for the primary key.
containsObjectInIdentityMap(DataRecord, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Return if their is an object for the row containing primary key and the class.
containsObjectInIdentityMap(DataRecord, Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Returns true if the identity map contains an Object with the same primary key of the specified row (i.e.
containsProperty(String) - Method in interface org.eclipse.persistence.dynamic.DynamicType
 
containsProperty(String) - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
containsQuery(String) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Return true if the query is defined on the session
containsQuery(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return true if the pre-defined query is defined on the session.
containsQuery(String) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Return true if the pre-defined query is defined on the session.
containsQuery(String) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Was PUBLIC: customer will be redirected to Session.
containsQuery(String) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return true if the pre-defined query is defined on the session.
containsSubstring(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value contains the substring.
containsSubstring(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value contains the substring.
containsSubstringIgnoringCase(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value contains the substring, ignoring case.
containsSubstringIgnoringCase(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value contains the substring, ignoring case.
containsValue(Object) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
containsValue(Object) - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Returns true if this IdentityWeakHashMap contains the given object.
containsValue(Object) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
containsValue(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Check if the value is contained in the row.
containsValue(Object) - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
PUBLIC: Check if the value is contained in the row.
containsValue(Object) - Method in class org.eclipse.persistence.internal.sessions.ResultSetRecord
PUBLIC: Check if the value is contained in the row.
containsValue(Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Check if the value is contained in the result.
Content - Class in org.eclipse.persistence.internal.oxm.schema.model
 
Content() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Content
 
CONTENT_TYPE - Static variable in class org.eclipse.persistence.oxm.XMLConstants
 
contentHandler - Variable in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
ContentHandlerRecord - Class in org.eclipse.persistence.oxm.record
Use this type of MarshalRecord when the marshal target is a ContentHandler.
ContentHandlerRecord() - Constructor for class org.eclipse.persistence.oxm.record.ContentHandlerRecord
 
contents - Static variable in class org.eclipse.persistence.exceptions.i18n.JSONExceptionResource
 
context - Variable in class org.eclipse.persistence.eis.EISConnectionSpec
 
context - Variable in class org.eclipse.persistence.internal.oxm.Context.ContextState
 
context - Variable in class org.eclipse.persistence.internal.oxm.Marshaller
 
context - Variable in class org.eclipse.persistence.internal.oxm.Unmarshaller
 
context - Variable in class org.eclipse.persistence.sessions.JNDIConnector
 
Context<ABSTRACT_SESSION extends CoreAbstractSession,​DESCRIPTOR extends Descriptor<?,​?,​?,​?,​?,​NAMESPACE_RESOLVER,​?,​?,​?,​?>,​FIELD extends Field,​NAMESPACE_RESOLVER extends NamespaceResolver,​PROJECT extends CoreProject,​SESSION extends CoreSession,​SESSION_EVENT_LISTENER extends CoreSessionEventListener> - Class in org.eclipse.persistence.internal.oxm
 
Context() - Constructor for class org.eclipse.persistence.internal.oxm.Context
 
Context.ContextState<ABSTRACT_SESSION extends CoreAbstractSession,​DESCRIPTOR extends Descriptor,​PROJECT extends CoreProject,​SESSION extends CoreSession,​SESSION_EVENT_LISTENER extends CoreSessionEventListener> - Class in org.eclipse.persistence.internal.oxm
 
contextProperty - Variable in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
 
contextProperty() - Method in annotation type org.eclipse.persistence.annotations.TenantDiscriminatorColumn
(Optional) The name of the context property to apply to the tenant discriminator column.
contextProperty() - Method in annotation type org.eclipse.persistence.annotations.TenantTableDiscriminator
(Optional) The name of the context property to apply to as tenant table discriminator.
contextState - Variable in class org.eclipse.persistence.internal.oxm.Context
 
ContextState() - Constructor for class org.eclipse.persistence.internal.oxm.Context.ContextState
 
ContextState(Context, PROJECT, ClassLoader, Collection<SESSION_EVENT_LISTENER>) - Constructor for class org.eclipse.persistence.internal.oxm.Context.ContextState
 
contextTenant - Variable in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
 
controller - Variable in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Store the real controller.
controller - Variable in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
The external txn controller that is intimate with the transaction manager and knows how to do things like rolling back transactions, etc.
controllerClassName - Variable in class org.eclipse.persistence.sessions.remote.rmi.RMIServerSessionManagerDispatcher
 
CONVERSION_ERROR - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
CONVERSION_USE_DEFAULT_TIMEZONE - Static variable in class org.eclipse.persistence.config.SystemProperties
This system property can be set to restore ConversionManager behavior with converting LocalDateTime, OffsetDateTime, and OffsetTime types back to using the JVM's default time zone instead of UTC.
CONVERSION_USE_TIMEZONE - Static variable in class org.eclipse.persistence.config.SystemProperties
This system property can be set the specific time zone used by ConversionManager to convert LocalDateTime, OffsetDateTime, and OffsetTime types.
conversionError(Exception) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when trying to set a property to value that is an unsupported conversion
ConversionException - Exception in org.eclipse.persistence.exceptions
Purpose: Conversion exceptions such as method or class not defined will raise this exception.
ConversionException() - Constructor for exception org.eclipse.persistence.exceptions.ConversionException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
ConversionException(String, Object, Class<?>, Exception) - Constructor for exception org.eclipse.persistence.exceptions.ConversionException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
ConversionExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for ConversionException messages.
ConversionExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.ConversionExceptionResource
Default constructor.
conversionManager - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Allow for conversion to be customized in the platform.
ConversionManager - Class in org.eclipse.persistence.internal.helper
Purpose: Contains the conversion routines for some common classes in the system.
ConversionManager - Interface in org.eclipse.persistence.internal.oxm
 
ConversionManager() - Constructor for class org.eclipse.persistence.internal.helper.ConversionManager
 
ConversionManager_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
ConversionValue - Annotation Type in org.eclipse.persistence.annotations
A ConversionValue annotation is used within an ObjectTypeConverter.
conversionValues() - Method in annotation type org.eclipse.persistence.annotations.ObjectTypeConverter
(Required) Specify the conversion values to be used with the object converter.
conversionValueStrings - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
convert(Object, DatabaseField, AbstractSession, Connection) - Method in class org.eclipse.persistence.internal.databaseaccess.BindCallCustomParameter
INTERNAL: Converts the parameter object from a collection or java object into a JDBC type such as an Array or Struct object, based on the type information contained in the dbField object.
convert(String...) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Convert a provided name or path which could be a single attributeName, a single string with dot separated attribute names, or an array of attribute names defining the path.
convert(String...) - Static method in class org.eclipse.persistence.internal.core.queries.CoreAttributeConverter
INTERNAL: Splits given nameOrPath[0] argument around '.' character when nameOrPath.length is equal to 1.
convert(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLAccessor
Convert the specified row into something suitable for the calls.
Convert - Annotation Type in org.eclipse.persistence.annotations
The Convert annotation specifies that a named converter should be used with the corresponding mapped attribute.
convertArrayToString(Object[], QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL: Convert all the class-name-based settings in this Descriptor to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
INTERNAL: Convert all the class-name-based settings in this Descriptor to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.core.sessions.CoreProject
INTERNAL: Convert all the class-name-based settings in this project to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Convert all the class-name-based settings in this Descriptor to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Convert all the class-name-based settings in this Descriptor to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: Convert all the class-name-based settings in this object to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Convert all the class-name-based settings in this Query Manager to actual class-based settings This method is implemented by subclasses as necessary.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Convert all the class-name-based settings in this InheritancePolicy to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Convert all the class-name-based settings in this InheritancePolicy to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.descriptors.partitioning.CustomPartitioningPolicy
INTERNAL: Convert all the class-name-based settings to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.descriptors.partitioning.PartitioningPolicy
INTERNAL: Convert all the class-name-based settings to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartition
INTERNAL: Convert all the class-name-based settings to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartitioningPolicy
INTERNAL: Convert all the class-name-based settings to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
INTERNAL: Convert all the class-name-based settings to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in interface org.eclipse.persistence.internal.descriptors.ClassNameConversionRequired
INTERNAL: Convert all the class-name-based settings in this converter to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
INTERNAL: Convert all the class-name-based settings in this InstantiationPolicy to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
convertClassNamesToClasses(ClassLoader) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
 
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Convert all the class-name-based settings in this ContainerPolicy to actual class-based settings This method is implemented by subclasses as necessary.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Convert all the class-name-based settings in this ContainerPolicy to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Convert all the class-name-based settings in this ContainerPolicy to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Convert all the class-name-based settings in this ContainerPolicy to actual class-based settings
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
INTERNAL: Convert all the class-name-based settings in this SortedCollectionContainerPolicy to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Convert all the class-name-based settings in this mapping to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Convert all the class-name-based settings in this mapping to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Convert all the class-name-based settings in this mapping to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Convert all the class-name-based settings in this mapping to actual class-based settings This method is implemented by subclasses as necessary.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.converters.ConverterClass
INTERNAL: Convert all the class-name-based settings in this converter to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.converters.EnumTypeConverter
INTERNAL: Convert all the class-name-based settings in this converter to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Convert all the class-name-based settings in this converter to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
INTERNAL: Convert all the class-name-based settings in this converter to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
INTERNAL: Convert all the class-name-based settings in this converter to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Convert all the class-name-based settings in this mapping to actual class-based settings This method is implemented by subclasses as necessary.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Convert all the class-name-based settings in this mapping to actual class-based settings This method is implemented by subclasses as necessary.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
 
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Convert all the class-name-based settings in this mapping to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL: Convert all the class-name-based settings in this mapping to actual class-based settings This method is implemented by subclasses as necessary.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Convert all the class-name-based settings in this mapping to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
 
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Convert all the class-name-based settings in this mapping to actual class-based settings This method is implemented by subclasses as necessary.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Convert all the class-name-based settings in this mapping to actual class-based settings
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
INTERNAL: Convert all the class-name-based settings in this project to actual class-based settings
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
INTERNAL: Convert all the class-name-based settings in this QueryKey to actual class-based settings Will be overridded by subclasses
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDatabaseField
 
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Convert all the class-name-based settings in this mapping to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
convertClassNamesToClasses(ClassLoader) - Method in interface org.eclipse.persistence.oxm.mappings.XMLMapping
 
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Convert all the class-name-based settings in this Descriptor to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.queries.ColumnResult
INTERNAL: Convert all the class-name-based settings in this query to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.queries.ConstructorResult
INTERNAL: Convert all the class-name-based settings in this query to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Convert all the class-name-based settings in this query to actual class-based settings This method is implemented by subclasses as necessary.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.queries.EntityResult
INTERNAL: Convert all the class-name-based settings in this query to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Convert all the class-name-based settings in this query to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
INTERNAL: Convert all the class-name-based settings in this ResultSetMapping to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.queries.SQLResult
INTERNAL: Convert all the class-name-based settings in this SQLResult to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.queries.SQLResultSetMapping
INTERNAL: Convert all the class-name-based settings in this SQLResultSetMapping to actual class-based settings.
convertClassNamesToClasses(ClassLoader) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Convert all the class-name-based settings in this project to actual class-based settings.
convertClassNameToClass(String) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
PUBLIC: Resolve the given String className into a class using this ConversionManager's classloader.
convertClassNameToClass(String, ClassLoader) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Convert the given className to an actual class.
convertConverterClassNamesToClasses(Converter, ClassLoader) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
Convenience method to ensure converters have an opportunity to convert any class names to classes during project setup.
convertDataValueToObjectValue(Object, Session) - Method in class org.eclipse.persistence.internal.expressions.ExpressionOperatorConverter
INTERNAL: Returns the corresponding attribute value for the specified field value.
convertDataValueToObjectValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.ClassInstanceConverter
INTERNAL: Convert the class name to a class, then create an instance of the class.
convertDataValueToObjectValue(Object, Session) - Method in interface org.eclipse.persistence.mappings.converters.Converter
PUBLIC: Convert the databases' data representation of the value to the object's representation.
convertDataValueToObjectValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.ConverterClass
INTERNAL:
convertDataValueToObjectValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.EnumTypeConverter
INTERNAL: Returns the corresponding attribute value for the specified field value.
convertDataValueToObjectValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Returns the corresponding attribute value for the specified field value.
convertDataValueToObjectValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
INTERNAL: The fieldValue will be a byte array.
convertDataValueToObjectValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
INTERNAL: The field value must first be converted to the field type, then the attribute type.
convertDataValueToObjectValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.UUIDConverter
Converts String from JDBC VARCHAR parameter to UUID field value.
convertDataValueToObjectValue(Object, Session) - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLConverterAdapter
 
convertDataValueToObjectValue(Object, Session) - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLListConverter
 
convertDataValueToObjectValue(Object, Session) - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLRootConverter
 
convertDataValueToObjectValue(Object, Session, XMLUnmarshaller) - Method in interface org.eclipse.persistence.oxm.mappings.converters.XMLConverter
 
convertDataValueToObjectValue(Object, Session, XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLRootConverter
 
convertDataValueToObjectValue(Object, Session, XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL
convertDataValueToObjectValue(Object, Session, XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
INTERNAL
convertDataValueToObjectValue(Object, Session, XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL
convertDataValueToObjectValue(Object, Session, XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
INTERNAL
convertDataValueToObjectValue(Object, Session, XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
INTERNAL
convertDataValueToObjectValue(Object, Session, XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
INTERNAL
convertDataValueToObjectValue(Object, Session, XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
INTERNAL
convertDataValueToObjectValue(Object, Session, XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
INTERNAL
convertDataValueToObjectValue(Object, SESSION) - Method in interface org.eclipse.persistence.core.mappings.converters.CoreConverter
PUBLIC: Convert the databases' data representation of the value to the object's representation.
convertDataValueToObjectValue(Object, SESSION, UNMARSHALLER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.XMLConverterMapping
 
converter - Variable in class org.eclipse.persistence.internal.oxm.XMLChoiceFieldToClassAssociation
 
converter - Variable in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
Allows user defined conversion between the object attribute value and the database value.
converter - Variable in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
Allows user defined conversion between the object attribute value and the database value.
converter - Variable in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
Allows user defined conversion between the object attribute value and the database value.
converter() - Method in annotation type org.eclipse.persistence.annotations.StructConverter
(Required) The StructConverter class to be used.
Converter - Interface in org.eclipse.persistence.mappings.converters
Purpose: Conversion interface to allow conversion between object and data types.
Converter - Annotation Type in org.eclipse.persistence.annotations
A Converter is used to customize the values during the reading from the database into the object model as well as during the writing back of changes into the database.
CONVERTER_CLASS_MUST_IMPLEMENT_ATTRIBUTE_CONVERTER_INTERFACE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CONVERTER_CLASS_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CONVERTER_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
converterClass() - Method in annotation type org.eclipse.persistence.annotations.Converter
(Required) The converter class to be used.
ConverterClass<T extends jakarta.persistence.AttributeConverter<X,​Y>,​X,​Y> - Class in org.eclipse.persistence.mappings.converters
A JPA attribute converter class wrapped with an EclipseLink converter.
ConverterClass(String, boolean, String, boolean) - Constructor for class org.eclipse.persistence.mappings.converters.ConverterClass
INTERNAL: This method will be called when creating a converter for an embedded mapping attribute.
converterClassMustImplementAttributeConverterInterface(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
converterClassName - Variable in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
 
converterClassNotFound(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
converterFromAdapterRecord(Record) - Method in interface org.eclipse.persistence.eis.RecordConverter
 
converterName - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
converterNotFound(Object, String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
ConverterProvider - Interface in org.eclipse.persistence.mappings.converters.spi
Java Service loader interface for data converters.
converters - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
List of converters to apply at initialize time to their cloned aggregate mappings.
converters - Variable in class org.eclipse.persistence.mappings.AggregateObjectMapping
List of converters to apply at initialize time to their cloned aggregate mappings.
converters() - Method in interface org.eclipse.persistence.mappings.converters.spi.ConverterProvider
Returns converter suppliers mapping of specific provider.
Converters - Annotation Type in org.eclipse.persistence.annotations
A Converters annotation allows the definition of multiple Converter.
converterToAdapterRecord(Record) - Method in interface org.eclipse.persistence.eis.RecordConverter
 
convertHexBinaryListToByteArrayList(Object, CoreContainerPolicy, CoreAbstractSession) - Method in interface org.eclipse.persistence.internal.oxm.ConversionManager
 
convertHexBinaryListToByteArrayList(Object, CoreContainerPolicy, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertLikeToRegex(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Convert the SQL like pattern to a regex pattern.
convertListToString(Object, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertNodeToUseOuterJoin() - Method in class org.eclipse.persistence.expressions.Expression
 
convertNodeToUseOuterJoin() - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
INTERNAL: Modify this individual expression node to use outer joins wherever there are equality operations between two field nodes.
convertObject(Object, Class<?>, CoreAbstractSession, CoreContainerPolicy) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
convertObject(Object, Class<T>) - Method in interface org.eclipse.persistence.internal.core.databaseaccess.CorePlatform
Convert the object to the appropriate type by invoking the appropriate ConversionManager method
convertObject(Object, Class<T>) - Method in class org.eclipse.persistence.internal.core.helper.CoreConversionManager
Convert the object to the appropriate type by invoking the appropriate ConversionManager method
convertObject(Object, Class<T>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Convert the object to the appropriate type by invoking the appropriate ConversionManager method
convertObject(Object, Class<T>) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Convert the object to the appropriate type by invoking the appropriate ConversionManager method
convertObject(Object, Class<T>) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Convert the object to the appropriate type by invoking the appropriate ConversionManager method
convertObject(Object, Class<T>) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Convert the given object to the appropriate type by invoking the appropriate ConversionManager method.
convertObject(Object, Class<T>, QName) - Method in interface org.eclipse.persistence.internal.oxm.ConversionManager
Convert the given object to the appropriate type by invoking the appropriate ConversionManager method.
convertObject(Object, Class<T>, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Convert the given object to the appropriate type by invoking the appropriate ConversionManager method.
convertObjectToBigDecimal(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid instance of BigDecimal from the given sourceObject
convertObjectToBigDecimal(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Build a valid instance of BigDecimal from the given sourceObject
convertObjectToBigInteger(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid instance of BigInteger from the provided sourceObject.
convertObjectToBigInteger(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Build a valid instance of BigInteger from the provided sourceObject.
convertObjectToBoolean(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid instance of Boolean from the source object.
convertObjectToBoolean(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertObjectToByte(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid instance of Byte from the provided sourceObject
convertObjectToByte(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Build a valid instance of Byte from the provided sourceObject
convertObjectToByteArray(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid instance of a byte array from the given object.
convertObjectToByteObjectArray(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid instance of a Byte array from the given object.
convertObjectToCalendar(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid instance of java.util.Calendar from the given source object.
convertObjectToCalendar(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
INTERNAL: Converts given object to a Calendar object
convertObjectToChar(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid instance of Character from the provided sourceObject.
convertObjectToChar(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Build a valid instance of Character from the provided sourceObject.
convertObjectToChar(Object, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Build a valid instance of Character from the provided sourceObject.
convertObjectToCharacterArray(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid instance of a Character array from the given object.
convertObjectToCharArray(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid instance of a char array from the given object.
convertObjectToClass(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid Class from the string that is passed in
convertObjectToDataHandler(Object, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
convertObjectToDate(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Convert the object to an instance of java.sql.Date.
convertObjectToDate(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertObjectToDouble(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Convert the object to an instance of Double.
convertObjectToDouble(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Convert the object to an instance of Double.
convertObjectToDuration(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Build a valid instance of Duration from the provided sourceObject.
convertObjectToFloat(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid Float instance from a String or another Number instance.
convertObjectToFloat(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Build a valid Float instance from a String or another Number instance.
convertObjectToImage(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
convertObjectToInteger(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid Integer instance from a String or another Number instance.
convertObjectToInteger(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Build a valid Integer instance from a String or another Number instance.
convertObjectToLocalDate(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Build a valid instance of java.time.LocalDate from the given source object.
convertObjectToLocalDateTime(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Build a valid instance of java.time.LocalDateTime from the given source object.
convertObjectToLocalTime(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Build a valid instance of java.time.LocalTime from the given source object.
convertObjectToLong(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
Build a valid Long instance from a String or another Number instance.
convertObjectToLong(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Build a valid Long instance from a String or another Number instance.
convertObjectToMultipart(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
convertObjectToNumber(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Build a valid BigDecimal instance from a String or another Number instance.
convertObjectToNumber(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
INTERNAL: Build a valid BigDecimal instance from a String or another Number instance.
convertObjectToOffsetDateTime(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Build a valid instance of java.time.OffsetDateTime from the given source object.
convertObjectToOffsetTime(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Build a valid instance of java.time.OffsetTime from the given source object.
convertObjectToQName(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
INTERNAL: Converts given object to a QName object
convertObjectToShort(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Build a valid Short instance from a String or another Number instance.
convertObjectToShort(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
INTERNAL: Build a valid Short instance from a String or another Number instance.
convertObjectToSource(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
convertObjectToSQLDate(Object, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertObjectToSQLTime(Object, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertObjectToString(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Converts objects to their string representations.
convertObjectToString(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
INTERNAL: Converts objects to their string representations.
convertObjectToString(Object, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertObjectToTime(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Build a valid instance of java.sql.Time from the given source object.
convertObjectToTimestamp(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Build a valid instance of java.sql.Timestamp from the given source object.
convertObjectToTimestamp(Object, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertObjectToURI(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Convert a String to a URI.
convertObjectToUrl(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Build a valid instance of java.net.URL from the given source object.
convertObjectToUtilDate(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Build a valid instance of java.util.Date from the given source object.
convertObjectToUUID(Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Build a valid instance of java.util.UUID from the given source object.
convertObjectToXMLGregorianCalendar(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Build a valid instance of XMLGregorianCalendar from the provided sourceObject.
convertObjectToXMLGregorianCalendar(Object, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Build a valid instance of XMLGregorianCalendar from the provided sourceObject.
convertObjectValueToDataValue(Object, Session) - Method in class org.eclipse.persistence.internal.expressions.ExpressionOperatorConverter
INTERNAL: Convert to the data value.
convertObjectValueToDataValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.ClassInstanceConverter
INTERNAL: Convert to the field class.
convertObjectValueToDataValue(Object, Session) - Method in interface org.eclipse.persistence.mappings.converters.Converter
PUBLIC: Convert the object's representation of the value to the databases' data representation.
convertObjectValueToDataValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.ConverterClass
INTERNAL:
convertObjectValueToDataValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.EnumTypeConverter
INTERNAL: Convert Enum object to the data value.
convertObjectValueToDataValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Convert to the data value.
convertObjectValueToDataValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
INTERNAL: Convert the object to a byte array through serialize.
convertObjectValueToDataValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
INTERNAL: Convert to the field class.
convertObjectValueToDataValue(Object, Session) - Method in class org.eclipse.persistence.mappings.converters.UUIDConverter
Converts UUID field value to String.
convertObjectValueToDataValue(Object, Session) - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLConverterAdapter
 
convertObjectValueToDataValue(Object, Session) - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLListConverter
 
convertObjectValueToDataValue(Object, Session) - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLRootConverter
 
convertObjectValueToDataValue(Object, Session, XMLMarshaller) - Method in interface org.eclipse.persistence.oxm.mappings.converters.XMLConverter
 
convertObjectValueToDataValue(Object, Session, XMLMarshaller) - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLRootConverter
 
convertObjectValueToDataValue(Object, Session, XMLMarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL
convertObjectValueToDataValue(Object, Session, XMLMarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
INTERNAL
convertObjectValueToDataValue(Object, Session, XMLMarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL
convertObjectValueToDataValue(Object, Session, XMLMarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
INTERNAL
convertObjectValueToDataValue(Object, Session, XMLMarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
INTERNAL
convertObjectValueToDataValue(Object, Session, XMLMarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
INTERNAL
convertObjectValueToDataValue(Object, Session, XMLMarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
INTERNAL
convertObjectValueToDataValue(Object, Session, XMLMarshaller) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
INTERNAL
convertObjectValueToDataValue(Object, SESSION) - Method in interface org.eclipse.persistence.core.mappings.converters.CoreConverter
PUBLIC: Convert the object's representation of the value to the databases' data representation.
convertObjectValueToDataValue(Object, SESSION, MARSHALLER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.XMLConverterMapping
 
convertSchemaBase64ListToByteArrayList(Object, CoreContainerPolicy, CoreAbstractSession) - Method in interface org.eclipse.persistence.internal.oxm.ConversionManager
 
convertSchemaBase64ListToByteArrayList(Object, CoreContainerPolicy, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertSchemaBase64ToByteArray(Object) - Method in interface org.eclipse.persistence.internal.oxm.ConversionManager
INTERNAL: Converts a String which is in Base64 format to a Byte[]
convertSchemaBase64ToByteArray(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
INTERNAL: Converts a String which is in Base64 format to a Byte[]
convertSchemaBase64ToByteObjectArray(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertSingleObject(Object, Class<?>, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
convertStringToCalendar(String, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertStringToDate(String, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertStringToDuration(String) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Return a Duration created with a given date string.
convertStringToFile(String) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertStringToList(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertStringToList(Object, Class<T>, ContainerPolicy, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Convert the given sourceObject (String) to the appropriate collection type specified by the containerPolicy, using the elementType to properly convert each element of the list.
convertStringToTimestamp(String) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertStringToTimestamp(String, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertStringToXMLGregorianCalendar(String) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Return an XMLGregorianCalander created with a given date string
convertStringToXMLGregorianCalendar(String, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
convertToCastDescriptor(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL Return the descriptor which contains this query key, look in the inheritance hierarchy of rootDescriptor for the descriptor.
convertToCastDescriptor(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
INTERNAL - Return the descriptor which contains this query key, look in the inheritance hierarchy of rootDescriptor for the descriptor.
convertToChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: This method is used to convert the contents of an aggregateCollection into a changeRecord
convertToChangeRecord(Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
 
convertToChangeRecord(Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
 
convertToDatabaseType(Object) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL We support more primitive than JDBC does so we must do conversion before printing or binding.
convertToDatabaseType(Object) - Method in class org.eclipse.persistence.platform.database.DBasePlatform
INTERNAL We support more primitive than JDBC does so we must do conversion before printing or binding.
convertToDatabaseType(Object) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby error the data type, length or value of arguments 'TIMESTAMP' and 'DATE' is incompatible.
convertToEclipseLinkCommand(Object) - Method in interface org.eclipse.persistence.sessions.coordination.CommandConverter
PUBLIC: Convert a command from its application-specific format to a EclipseLink Command object.
convertToObject(Struct) - Method in interface org.eclipse.persistence.platform.database.converters.StructConverter
PUBLIC: This method will be invoked internally when reading a Struct from the database Implementers should put any custom conversion logic in this method
convertToStruct(Object, Connection) - Method in interface org.eclipse.persistence.platform.database.converters.StructConverter
PUBLIC: This method will be invoked internally when writing an Object to the database Implementers should put any custom conversion logic in this method
convertToUseOuterJoin() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Modify this expression to use outer joins wherever there are equality operations between two field nodes.
convertToUseOuterJoin() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
convertToUserCommand(Command) - Method in interface org.eclipse.persistence.sessions.coordination.CommandConverter
PUBLIC: Convert a EclipseLink Command object into its application-specific format to a
convertToXMLField(List<DatabaseField>) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
convertToXMLField(DatabaseField) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL: Convert a DatabaseField to an XMLField
convertValueBasedOnSchemaType(Object, CONVERSION_MANAGER, AbstractUnmarshalRecord) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
INTERNAL: Called from DOMRecord and XMLReader.
convertValueBasedOnSchemaType(Object, XMLConversionManager, AbstractUnmarshalRecord) - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL: Called from DOMRecord and XMLReader.
convertValueBasedOnSchemaType(Object, XMLConversionManager, AbstractUnmarshalRecord) - Method in class org.eclipse.persistence.oxm.XMLUnionField
INTERNAL:
convertValueBasedOnSchemaType(Field, Object, ConversionManager, AbstractUnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
INTERNAL:
COORDINATION_ASYNCH - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.propagate-asynchronously" property configures cache coordination for a clustered environment.
COORDINATION_CHANNEL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.channel" property configures cache coordination for a clustered environment.
COORDINATION_JGROUPS_CONFIG - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.jgroups.config" property configures cache coordination for a clustered environment.
COORDINATION_JMS_FACTORY - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.jms.factory" property configures cache coordination for a clustered environment.
COORDINATION_JMS_HOST - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.jms.host" property configures cache coordination for a clustered environment.
COORDINATION_JMS_REUSE_PUBLISHER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.jms.reuse-topic-publisher" property configures cache coordination for a clustered environment.
COORDINATION_JMS_TOPIC - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.jms.topic" property configures cache coordination for a clustered environment.
COORDINATION_JNDI_CONTEXT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.jndi.initial-context-factory" property configures cache coordination for a clustered environment.
COORDINATION_JNDI_PASSWORD - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.jndi.password" property configures cache coordination for a clustered environment.
COORDINATION_JNDI_USER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.jndi.user" property configures cache coordination for a clustered environment.
COORDINATION_NAMING_SERVICE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.naming-service" property configures cache coordination for a clustered environment.
COORDINATION_PROTOCOL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.protocol" property configures cache coordination for a clustered environment.
COORDINATION_REMOVE_CONNECTION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.remove-connection-on-error" property configures cache coordination for a clustered environment.
COORDINATION_RMI_ANNOUNCEMENT_DELAY - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.rmi.announcement-delay" property configures cache coordination for a clustered environment.
COORDINATION_RMI_MULTICAST_GROUP - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.rmi.multicast-group" property configures cache coordination for a clustered environment.
COORDINATION_RMI_MULTICAST_GROUP_PORT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.rmi.multicast-group.port" property configures cache coordination for a clustered environment.
COORDINATION_RMI_PACKET_TIME_TO_LIVE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.rmi.packet-time-to-live" property configures cache coordination for a clustered environment.
COORDINATION_RMI_URL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.rmi.url" property configures cache coordination for a clustered environment.
COORDINATION_SERIALIZER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.serializer" property configures how cache coordination serializes message sent between nodes.
COORDINATION_THREAD_POOL_SIZE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.coordination.thread.pool.size" property configures thread pool size for cache coordination threads.
coordinationType() - Method in annotation type org.eclipse.persistence.annotations.Cache
(Optional) The cache coordination mode.
copiedVersionFrom(Map) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
copies - Variable in class org.eclipse.persistence.sessions.CopyGroup
 
copy() - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
copy(int, int) - Method in class org.eclipse.persistence.queries.CursoredStream
INTERNAL: Answer a list of the elements of the receiver's collection from startIndex to endIndex.
copy(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return a complete copy of the object or of collection of objects.
copy(Object) - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
copy(Object) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return a complete copy of the object or of collection of objects.
copy(Object, Object) - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
copy(Object, AttributeGroup) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return a complete copy of the object or of collection of objects.
copy(Object, AttributeGroup) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return a complete copy of the object or collection of objects.
COPY_POLICY_MUST_SPECIFY_METHOD_OR_WORKING_COPY_METHOD - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
copyAggregateFetchGroupInto(Object, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Copy fetch group reference from the source object to the target
copyBooleanArray(boolean[]) - Static method in class org.eclipse.persistence.internal.helper.Helper
Copy an array of boolean to a new array
copyCollection(List<Expression>, Map) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
copyDerivedExpressions(Map) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
copyDescriptorNamedQueries(boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: This method will be used to copy all EclipseLink named queries defined in descriptors into the session.
copyDescriptorsFromProject() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Copies descriptors cached on the Project.
copyElement(Object, CopyGroup) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Copies member's value
copyElement(Object, CopyGroup) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Copies member's value
copyFetchGroupInto(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Copy fetch group reference from the source object to the target
copyFrom(JoinedAttributeManager) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Copies settings from another manager.
copyFromQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Copy all setting from the query.
copyFromQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Copy all setting from the query.
copyFromQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Copy all setting from the query.
copyFromQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Copy all setting from the query.
copyFromQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: Copy all setting from the query.
CopyGroup - Class in org.eclipse.persistence.sessions
Purpose: Define how an object is to be copied.
CopyGroup() - Constructor for class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: By default only copy the attributes found in the attribute group and don't null primary keys.
CopyGroup(String) - Constructor for class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: By default only copy the attributes found in the attribute group and don't null primary keys.
copyIntArray(int[]) - Static method in class org.eclipse.persistence.internal.helper.Helper
Copy an array of int to a new array
copyInternal(Object, CopyGroup) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL:
copyInto(Object[]) - Method in class org.eclipse.persistence.indirection.IndirectList
 
copyInto(Object[]) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
copyInto(Object[]) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
copyInto(Object, Object) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Copy each attribute from one object into the other.
copyInto(Object, Object, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Copy each attribute from one object into the other.
copyInto(Platform) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Copy the state into the new platform.
copyInto(Platform) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Copy the state into the new platform.
copyInto(Platform) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Copy the state into the new platform.
copyInto(Platform) - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
INTERNAL: Allow for conversion from the Oracle type to the Java type.
copyMainFrom(ReturningPolicy) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
 
copyMapDataToRow(Map, AbstractRecord) - Static method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: convenience method to copy the keys and values from a Map into an AbstractRecord
copyNamespaces(NamespaceResolver, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
copyObject(Object, CopyGroup) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return a copy of the object.
copyPolicy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
CopyPolicy - Interface in org.eclipse.persistence.descriptors.copying
Purpose: Allows customization of how an object is cloned.
CopyPolicy - Annotation Type in org.eclipse.persistence.annotations
A CopyPolicy is used to set an org.eclipse.persistence.descriptors.copying.CopyPolicy on an Entity.
copyPolicyClassName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
copyPolicyMustSpecifyEitherMethodOrWorkingCopyMethod(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Cause: An annotation or XML document specifies a CloneCopyPolicy, bug does not supply either a method or working copy method
copyQueryInfoToCacheKey(CacheKey, ObjectBuildingQuery, AbstractRecord, AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Initialize a cache key.
copyReadOnlyClasses() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Copy the read only classes from the unit of work Added Nov 8, 2000 JED for Patch 2.5.1.8 Ref: Prs 24502
copyReadOnlyClasses() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Copy the read only classes from the unit of work.
copyReportItems(Map) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Required for a very special case of bug 2612185: ReportItems from parallelExpressions, on a ReportQuery which is a subQuery, which is being batch read.
copySessionBroker() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Return a copy (not using clone) of a session broker.
copyStringArray(String[]) - Static method in class org.eclipse.persistence.internal.helper.Helper
Copy an array of strings to a new array
copyTo(ExpressionOperator) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
 
copyTo(ExpressionOperator) - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
 
copyVector(List<E>, int, int) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return a copy of the vector containing a subset starting at startIndex and ending at stopIndex.
CoreAbstractRecord - Class in org.eclipse.persistence.internal.core.sessions
 
CoreAbstractRecord() - Constructor for class org.eclipse.persistence.internal.core.sessions.CoreAbstractRecord
Default constructor.
CoreAbstractSession<DESCRIPTOR extends CoreDescriptor,​LOGIN extends CoreLogin,​PLATFORM extends CorePlatform,​PROJECT extends CoreProject,​SESSION_EVENT_MANAGER extends CoreSessionEventManager> - Class in org.eclipse.persistence.internal.core.sessions
 
CoreAbstractSession() - Constructor for class org.eclipse.persistence.internal.core.sessions.CoreAbstractSession
Default constructor.
CoreAttributeAccessor - Interface in org.eclipse.persistence.core.mappings
INTERNAL A abstraction of attribute accessor capturing behavior common to all persistence types.
CoreAttributeConverter - Class in org.eclipse.persistence.internal.core.queries
INTERNAL: AttributeGroup attribute names converter.
CoreAttributeGroup<ATTRIBUTE_ITEM extends CoreAttributeItem,​DESCRIPTOR extends CoreDescriptor> - Class in org.eclipse.persistence.core.queries
INTERNAL Purpose: A generic super class for AttributeGroup and other subclasses
CoreAttributeGroup() - Constructor for class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
CoreAttributeGroup(String) - Constructor for class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
CoreAttributeGroup(String, Class<?>, boolean) - Constructor for class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL: This constructer is to only be used by EclipseLink internally
CoreAttributeGroup(String, String, boolean) - Constructor for class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
CoreAttributeItem<ATTRIBUTE_GROUP extends CoreAttributeGroup> - Class in org.eclipse.persistence.core.queries
INTERNAL Purpose: Generic superclass for AttributeItem.
CoreAttributeItem() - Constructor for class org.eclipse.persistence.core.queries.CoreAttributeItem
 
CoreAttributeItem(ATTRIBUTE_GROUP, String) - Constructor for class org.eclipse.persistence.core.queries.CoreAttributeItem
 
CoreClassConstants - Class in org.eclipse.persistence.internal.core.helper
 
CoreClassConstants() - Constructor for class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
CoreContainerPolicy<ABSTRACT_SESSION extends CoreAbstractSession> - Interface in org.eclipse.persistence.internal.core.queries
 
CoreConversionManager - Class in org.eclipse.persistence.internal.core.helper
 
CoreConversionManager() - Constructor for class org.eclipse.persistence.internal.core.helper.CoreConversionManager
Default constructor.
CoreConverter<MAPPING extends CoreMapping,​SESSION extends CoreSession> - Interface in org.eclipse.persistence.core.mappings.converters
INTERNAL A abstraction of converter capturing behavior common to all persistence types.
CoreDescriptor<ATTRIBUTE_GROUP extends CoreAttributeGroup,​DESCRIPTOR_EVENT_MANAGER extends CoreDescriptorEventManager,​FIELD extends CoreField,​INHERITANCE_POLICY extends CoreInheritancePolicy,​INSTANTIATION_POLICY extends CoreInstantiationPolicy,​LIST extends List,​OBJECT_BUILDER extends CoreObjectBuilder> - Class in org.eclipse.persistence.core.descriptors
INTERNAL A abstraction of descriptor capturing behavior common to all persistence types.
CoreDescriptor() - Constructor for class org.eclipse.persistence.core.descriptors.CoreDescriptor
Default constructor.
CoreDescriptorEvent - Interface in org.eclipse.persistence.core.descriptors
INTERNAL A abstraction of descriptor event capturing behavior common to all persistence types.
CoreDescriptorEventManager<DESCRIPTOR_EVENT extends CoreDescriptorEvent> - Class in org.eclipse.persistence.core.descriptors
INTERNAL A abstraction of descriptor event manager capturing behavior common to all persistence types.
CoreDescriptorEventManager() - Constructor for class org.eclipse.persistence.core.descriptors.CoreDescriptorEventManager
Default constructor.
CoreField - Interface in org.eclipse.persistence.internal.core.helper
 
CoreFieldTransformer<SESSION extends CoreSession> - Interface in org.eclipse.persistence.core.mappings.transformers
This interface is used by the Transformation Mapping to build the value for a specific field.
CoreHelper - Class in org.eclipse.persistence.internal.core.helper
 
CoreHelper() - Constructor for class org.eclipse.persistence.internal.core.helper.CoreHelper
 
CoreInheritancePolicy<ABSTRACT_RECORD extends CoreAbstractRecord,​ABSTRACT_SESSION extends CoreAbstractSession,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField> - Class in org.eclipse.persistence.core.descriptors
INTERNAL A abstraction of inheritance policy capturing behavior common to all persistence types.
CoreInheritancePolicy() - Constructor for class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
Default constructor.
CoreInstantiationPolicy - Class in org.eclipse.persistence.internal.core.descriptors
 
CoreInstantiationPolicy() - Constructor for class org.eclipse.persistence.internal.core.descriptors.CoreInstantiationPolicy
Default constructor.
CoreLogin<PLATFORM extends CorePlatform> - Interface in org.eclipse.persistence.core.sessions
INTERNAL A abstraction of login capturing behavior common to all persistence types.
CoreMappedKeyMapContainerPolicy<ABSTRACT_SESSION extends CoreAbstractSession> - Interface in org.eclipse.persistence.internal.core.queries
 
CoreMapping<ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​ABSTRACT_SESSION extends CoreAbstractSession,​CONTAINER_POLICY extends CoreContainerPolicy,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField> - Class in org.eclipse.persistence.core.mappings
INTERNAL A abstraction of mapping capturing behavior common to all persistence types.
CoreMapping() - Constructor for class org.eclipse.persistence.core.mappings.CoreMapping
Default constructor.
CoreObjectBuilder<ABSTRACT_RECORD extends CoreAbstractRecord,​ABSTRACT_SESSION extends CoreAbstractSession,​FIELD extends CoreField,​MAPPING extends CoreMapping> - Class in org.eclipse.persistence.internal.core.descriptors
 
CoreObjectBuilder() - Constructor for class org.eclipse.persistence.internal.core.descriptors.CoreObjectBuilder
Default constructor.
CorePlatform<CONVERSION_MANAGER extends CoreConversionManager> - Interface in org.eclipse.persistence.internal.core.databaseaccess
 
CoreProject<DESCRIPTOR extends CoreDescriptor,​LOGIN extends CoreLogin,​SESSION extends CoreSession> - Class in org.eclipse.persistence.core.sessions
INTERNAL A abstraction of project capturing behavior common to all persistence types.
CoreProject() - Constructor for class org.eclipse.persistence.core.sessions.CoreProject
Default constructor.
CoreSession<DESCRIPTOR extends CoreDescriptor,​LOGIN extends CoreLogin,​PLATFORM extends CorePlatform,​PROJECT extends CoreProject,​SESSION_EVENT_MANAGER extends CoreSessionEventManager> - Interface in org.eclipse.persistence.core.sessions
INTERNAL A abstraction of session capturing behavior common to all persistence types.
CoreSessionEventListener - Interface in org.eclipse.persistence.core.sessions
INTERNAL A abstraction of session event listener capturing behavior common to all persistence types.
CoreSessionEventManager<SESSION_EVENT_LISTENER extends CoreSessionEventListener> - Class in org.eclipse.persistence.core.sessions
INTERNAL A abstraction of sessuin event manager capturing behavior common to all persistence types.
CoreSessionEventManager() - Constructor for class org.eclipse.persistence.core.sessions.CoreSessionEventManager
Default constructor.
CoreTable - Interface in org.eclipse.persistence.internal.core.helper
 
correctOrderList(List<IndexedObject>) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
PUBLIC: Correct object's order in the list.
cos() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
cos(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Cos - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
cosh() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
cosh(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Cosh - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
cot() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
cot(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Cot - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
COULD_NOT_BE_CONVERTED - Static variable in exception org.eclipse.persistence.exceptions.ConversionException
 
COULD_NOT_BE_CONVERTED_EXTENDED - Static variable in exception org.eclipse.persistence.exceptions.ConversionException
 
COULD_NOT_BE_CONVERTED_TO_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ConversionException
 
COULD_NOT_BIND_JNDI - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
COULD_NOT_CONVERT_OBJECT_TYPE - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
COULD_NOT_CONVERT_TO_BYTE_ARRAY - Static variable in exception org.eclipse.persistence.exceptions.ConversionException
 
COULD_NOT_CREATE_CONTEXT_FOR_XML_MODEL - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
COULD_NOT_CREATE_CUSTOMIZER_INSTANCE - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
COULD_NOT_DELETE_FILE - Static variable in exception org.eclipse.persistence.eis.EISException
 
COULD_NOT_FIND_CAST_DESCRIPTOR - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
COULD_NOT_FIND_DRIVER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
COULD_NOT_FIND_MAP_KEY - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
COULD_NOT_FIND_MATCHED_DATABASE_FIELD_FOR_SPECIFIED_OPTOMISTICLOCKING_FIELDS - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
COULD_NOT_FIND_PERSISTENCE_UNIT_BUNDLE - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
COULD_NOT_FIND_PROJECT_XML - Static variable in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
COULD_NOT_GET_CLASS_NAMES_FROM_URL - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
COULD_NOT_GET_PERSISTENCE_UNIT_INFO_FROM_URL - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
COULD_NOT_INITIALIZE_DOM_HANDLER_CONVERTER - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
COULD_NOT_INSTANTIATE_CONTAINER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
COULD_NOT_INSTANTIATE_INDIRECT_CONTAINER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
COULD_NOT_LOAD_CLASS_FROM_METADATA - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
COULD_NOT_LOCATE_DESCRIPTOR - Static variable in exception org.eclipse.persistence.exceptions.DBWSException
 
COULD_NOT_LOCATE_FILE - Static variable in exception org.eclipse.persistence.exceptions.DBWSException
 
COULD_NOT_LOCATE_OR_SESSION_FOR_SERVICE - Static variable in exception org.eclipse.persistence.exceptions.DBWSException
 
COULD_NOT_LOCATE_OX_SESSION_FOR_SERVICE - Static variable in exception org.eclipse.persistence.exceptions.DBWSException
 
COULD_NOT_LOCATE_QUERY_FOR_DESCRIPTOR - Static variable in exception org.eclipse.persistence.exceptions.DBWSException
 
COULD_NOT_LOCATE_QUERY_FOR_SESSION - Static variable in exception org.eclipse.persistence.exceptions.DBWSException
 
COULD_NOT_PARSE_DBWS_FILE - Static variable in exception org.eclipse.persistence.exceptions.DBWSException
 
COULD_NOT_UNMARSHAL_METADATA - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
couldNotBeConverted(Object, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.ConversionException
 
couldNotBeConverted(Object, Class<?>, Exception) - Static method in exception org.eclipse.persistence.exceptions.ConversionException
 
couldNotBeConverted(Object, Object, ConversionException) - Static method in exception org.eclipse.persistence.exceptions.ConversionException
 
couldNotBeConvertedToClass(Object, Class<?>, Exception) - Static method in exception org.eclipse.persistence.exceptions.ConversionException
 
couldNotBindJndi(String, Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
couldNotBuildPersistenceUntiName(Exception, String, String) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
couldNotConvertObjectType(int) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
couldNotConvertToByteArray(Object) - Static method in exception org.eclipse.persistence.exceptions.ConversionException
 
couldNotCreateContextForXmlModel() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception would typically be used by JAXBContextFactory during externalized metadata processing (i.e.
couldNotCreateContextForXmlModel(Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception would typically be used by JAXBContextFactory during externalized metadata processing (i.e.
couldNotCreateCustomizerInstance(Exception, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception should be used when a descriptor customizer instance cannot be created.
couldNotDeleteFile(Object[]) - Static method in exception org.eclipse.persistence.eis.EISException
 
couldNotFindCastDescriptor(Class<?>, Expression) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
couldNotFindDriverClass(Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
couldNotFindMapKey(String, Object, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
couldNotFindPersistenceUnitBundle(String) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
INTERNAL: An OSGi application is trying to instantiate a persistence unit for which a bundle does not exist
couldNotFindProjectXml(String) - Static method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
couldNotGetClassNamesFromUrl(URL) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
couldNotGetUnitInfoFromUrl(URL) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
couldNotInitializeDomHandlerConverter(Exception, String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception should be used when DomHandlerConverter initialization fails.
couldNotInstantiateContainerClass(Class<?>, Exception) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
couldNotInstantiateIndirectContainerClass(Class<?>, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
couldNotLoadClassFromMetadata(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception would typically be used by JAXBContextFactory during externalized metadata processing (i.e.
couldNotLocateDescriptorForOperation(String, String) - Static method in exception org.eclipse.persistence.exceptions.DBWSException
INTERNAL: Exception when processing DBWS metadata and the descriptor cannot be located for the operation
couldNotLocateFile(String) - Static method in exception org.eclipse.persistence.exceptions.DBWSException
INTERNAL: Exception when reading DBWS metadata and the given file cannot be located
couldNotLocateORSessionForService(String) - Static method in exception org.eclipse.persistence.exceptions.DBWSException
INTERNAL: Exception when reading DBWS metadata and the given file cannot be located
couldNotLocateOXSessionForService(String) - Static method in exception org.eclipse.persistence.exceptions.DBWSException
INTERNAL: Exception when reading DBWS metadata and the given file cannot be located
couldNotLocateQueryForDescriptor(String, String) - Static method in exception org.eclipse.persistence.exceptions.DBWSException
INTERNAL: Exception when processing DBWS metadata and the descriptor cannot be located for the operation
couldNotLocateQueryForSession(String, String) - Static method in exception org.eclipse.persistence.exceptions.DBWSException
INTERNAL: Exception when processing DBWS metadata and the descriptor cannot be located for the operation
couldNotParseDBWSFile() - Static method in exception org.eclipse.persistence.exceptions.DBWSException
 
couldNotTranslatePropertiesIntoObject(Object, String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ConversionException
 
couldNotUnmarshalMetadata(Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception would typically be used by JAXBContextFactory during externalized metadata processing (i.e.
count - Variable in class org.eclipse.persistence.internal.helper.IdentityHashSet
 
count - Variable in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
 
count() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This represents the aggregate function Average.
count() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the COUNT operator.
count() - Method in class org.eclipse.persistence.platform.database.DB2Platform
Disable binding support.
Count - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
Aggregate operators
COUNTER - Static variable in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
counterFieldName - Variable in class org.eclipse.persistence.sequencing.TableSequence
Hold the name of the column in the sequence table which specifies the sequence numeric value
counterFieldName - Variable in class org.eclipse.persistence.sequencing.UnaryTableSequence
Hold the name of the only column in multiple single-column tables
countOccurrencesOf(Object, List<?>) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return an integer representing the number of occurrences (using equals()) of the specified object in the specified list.
cr() - Static method in exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL: Convenience method - return a platform-specific line-feed.
cr() - Method in class org.eclipse.persistence.internal.codegen.CodeGenerator
 
cr() - Static method in class org.eclipse.persistence.internal.core.helper.CoreHelper
Return a string containing the platform-appropriate characters for carriage return.
cr() - Static method in class org.eclipse.persistence.internal.helper.Helper
Return a string containing the platform-appropriate characters for carriage return.
cr() - Static method in class org.eclipse.persistence.internal.oxm.Constants
Return a string containing the platform-appropriate characters for carriage return.
CR - Static variable in exception org.eclipse.persistence.exceptions.EclipseLinkException
 
CR - Static variable in class org.eclipse.persistence.internal.core.helper.CoreHelper
Store CR string, for some reason \n is not platform independent.
CR - Static variable in class org.eclipse.persistence.internal.helper.Helper
Store CR string, for some reason \n is not platform independent.
CR - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
Carriage return
create(List<Field>, Node, List<XMLEntry>, Field, DocumentPreservationPolicy, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XPathEngine
 
create(Expression, Object, ExpressionOperator) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
create(Expression, Object, ExpressionOperator) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL:
create(Expression, Object, ExpressionOperator) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL:
create(Expression, List, ExpressionOperator) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
create(Expression, List, ExpressionOperator) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL:
create(Expression, List, ExpressionOperator) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL:
create(Field, Node, Object, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XPathEngine
 
create(Field, Node, Object, Field, DocumentPreservationPolicy, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XPathEngine
Create the node path specified by xpathString under element and initialize the leaf node with value.
create(Field, Node, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XPathEngine
Create the node path specified by xpathString under element.
CREATE_CONTAINER_EMF_NOT_SUPPORTED_IN_OSGI - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
CREATE_JDBC_DDL_FILE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The property "eclipselink.create-ddl-jdbc-file-name" specifies the name of the DDL file which is used to create database tables.
CREATE_ONLY - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "create-tables" specifies that database tables should be created.
CREATE_OR_EXTEND - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "create-or-extend-tables" specifies that database tables should be created and if existing, missing columns will be added.
CREATE_PLATFORM_DEFAULT_SEQUENCE_UNDEFINED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CREATE_TEMP_TABLE - Static variable in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
createAggregateTargetTable(AggregateCollectionMapping) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Add the foreign key to the aggregate collection mapping target table.
createArguments(DatabaseQuery, String, Number) - Method in class org.eclipse.persistence.sequencing.QuerySequence
INTERNAL:
createArray(String, Object[], Connection) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Platforms that support java.sql.Array may override this method.
createArray(String, Object[], AbstractSession, Connection) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: This method builds an Array using the unwrapped connection within the session
createBeanUsingKey(Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: Use the key to create a bean and initialize its primary key fields.
createBinder() - Method in class org.eclipse.persistence.oxm.XMLContext
Create a new XMLBinder
createBinder(XMLMarshaller, XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.XMLContext
Create a new XMLBinder with supplied marshaller and unmarshaller instances.
createByQualifiedName(String, String, boolean) - Method in class org.eclipse.persistence.oxm.XMLContext
Create a new object instance for a given XML namespace and name.
createByXPath(Object, String, NAMESPACE_RESOLVER, Class<T>) - Method in class org.eclipse.persistence.internal.oxm.Context
Create a new object instance for a given XPath, relative to the parentObject.
createByXPath(Object, String, NamespaceResolver, Class<T>) - Method in class org.eclipse.persistence.oxm.XMLContext
Create a new object instance for a given XPath, relative to the parentObject.
createCacheKey(Object, Object, Object, long) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Create the correct type of CacheKey for this map.
createCacheKey(Object, Object, Object, long) - Method in class org.eclipse.persistence.internal.identitymaps.CacheIdentityMap
 
createCacheKey(Object, Object, Object, long) - Method in class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap
Use a ReferenceCacheKey that also stores the linked list node to manage the LRU sub-cache of references.
createCacheKey(Object, Object, Object, long) - Method in class org.eclipse.persistence.internal.identitymaps.SoftIdentityMap
 
createCacheKey(Object, Object, Object, long) - Method in class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
 
createCacheKey(Object, Object, Object, long) - Method in class org.eclipse.persistence.internal.identitymaps.WeakIdentityMap
 
createCacheKey(Object, Object, Object, long) - Method in class org.eclipse.persistence.internal.identitymaps.WeakUnitOfWorkIdentityMap
 
createCacheKeyInterceptor(CacheKey) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
 
createChangeEvent(Object, String, Object, Object, int, Integer, boolean) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Creates a CollectionChangeEvent for the container
createChangeEvent(Object, String, Object, Object, int, Integer, boolean) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Creates a CollectionChangeEvent for the container
createChangeEvent(Object, String, Object, Object, int, Integer, boolean) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Creates a CollectionChangeEvent for the container
createChangeEvent(Object, String, Object, Object, int, Integer, boolean) - Method in class org.eclipse.persistence.queries.CursorPolicy
INTERNAL: Creates a CollectionChangeEvent for the container
createChangeSetForKeys(Map, CollectionChangeRecord, AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Create change sets that contain map keys.
createChangeSetForKeys(Map, CollectionChangeRecord, AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Create change sets that contain map keys.
createCloneQueryValueHolder(ValueHolderInterface<T>, Object, AbstractRecord, ForeignReferenceMapping) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
 
createCloneQueryValueHolder(ValueHolderInterface<T>, Object, AbstractRecord, ForeignReferenceMapping) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
createCloneTransformationValueHolder(ValueHolderInterface<T>, Object, Object, AbstractTransformationMapping) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
 
createCloneTransformationValueHolder(ValueHolderInterface<T>, Object, Object, AbstractTransformationMapping) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
createCloneValueHolder(ValueHolderInterface<T>, Object, Object, AbstractRecord, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Builder the unit of work value holder.
createCloneValueHolder(ValueHolderInterface<T>, Object, Object, AbstractRecord, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Builder the unit of work value holder.
createCloneValueHolder(ValueHolderInterface<T>, Object, Object, AbstractRecord, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Builder the unit of work value holder.
createCloneValueHolder(ValueHolderInterface<T>, Object, Object, AbstractRecord, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Builder the unit of work value holder.
createCollection() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
createCommunicationSocket() - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
INTERNAL: Create the multicast socket and join the multicast group.
createConcatOperator() - Static method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
createConcurrencyManagerState(Map<Thread, DeferredLockManager>, Map<Thread, ReadLockManager>, Map<Thread, ConcurrencyManager>, Map<Thread, String>, Map<Thread, Set<ConcurrencyManager>>, Map<Thread, ConcurrencyManager>, Map<Thread, String>, Set<Thread>, Map<Thread, String>, Map<Thread, Set<Object>>) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
create a DTO that tries to represent the current snapshot of the concurrency manager and write lock manager cache state
createConnection(boolean) - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
INTERNAL: This method creates JMSTopicRemoteConnection to be used by this TransportManager.
createConnection(ServiceId) - Method in class org.eclipse.persistence.sessions.coordination.broadcast.BroadcastTransportManager
INTERNAL: No-op implementation of super abstract method since there is only one connection to a known topic.
createConnection(ServiceId) - Method in class org.eclipse.persistence.sessions.coordination.rmi.RMITransportManager
INTERNAL: Create and return an RMI remote connection to the specified service
createConnection(ServiceId) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Return a remote connection to the specified service
createConnectionCustomizer(Accessor, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL:
createConnectionFromJNDI(String, String) - Method in class org.eclipse.persistence.sessions.coordination.rmi.RMITransportManager
INTERNAL: Look the specified remote object up in JNDI and return a Connection to it.
createConnectionFromRegistry(String, String) - Method in class org.eclipse.persistence.sessions.coordination.rmi.RMITransportManager
INTERNAL: Look the specified remote object up in the RMIRegistry and return a Connection to it.
createConnections() - Method in class org.eclipse.persistence.sessions.coordination.broadcast.BroadcastTransportManager
INTERNAL: BroadcastTransportManager doesn't use DiscoveryManager (createDiscoveryManager method returns null) therefore this method called during RCM initialization to create all the necessary connections.
createConnections() - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
INTERNAL: JMSTopicTransportManager doesn't use DiscoveryManager, therefore this method is called during RCM initialization to create all the necessary connections.
createConnections() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Does nothing by default.
createConstraints(List<TableDefinition>, DatabaseSession, SchemaManager, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Create constraints.
createConstraints(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Execute the SQL alter table constraint creation string.
createConstraints(DatabaseSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Create constraints.
createConstraints(DatabaseSession, SchemaManager) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Create constraints.
createConstraints(DatabaseSession, SchemaManager, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Create constraints.
createConstraints(TableDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Use the table definition to add the constraints to the database, this is normally done in two steps to avoid dependencies.
createConstraintsOnDatabase(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Execute the SQL alter table constraint creation string.
createContainerEntityManagerFactoryNotSupportedInOSGi() - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
INTERNAL: Our OSGI persistence provider does not support a JavaEE-type deployment
createCopy(Class<?>) - Method in class org.eclipse.persistence.dynamic.DynamicClassWriter
Create a copy of this DynamicClassWriter but with a different parent class.
createCopyPolicy(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Create a copy policy of the type passed in as a string.
createCurrentDateOperator() - Static method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
createCurrentTimeOperator() - Static method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
createCustomizer(AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Attempts to create ConnectionCustomizer.
createCustomizer(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Attempts to create ConnectionCustomizer.
createDatabaseRowFromDOMRecord(Record, EISInteraction, EISAccessor) - Method in class org.eclipse.persistence.eis.EISPlatform
INTERNAL: Allow the platform to handle the creation of the Record for the DOM record.
createDatabaseSchema(AbstractSession, Writer, Set<String>) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Execute the DDL to create the database schema for this object.
createDatabaseSchema(AbstractSession, Writer, Set<String>) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Execute the DDL to create the database schema for this object.
createDatabaseSchemaOnDatabase(AbstractSession, Set<String>) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Execute the DDL to create the database schema for this object.
createDatabaseSchemaOnDatabase(AbstractSession, Set<String>) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Execute the DDL to create the database schema for this object.
createDatabaseSchemas - Variable in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Flag to determine if database schemas should be created during DDL generation
createDatabaseSession() - Method in class org.eclipse.persistence.core.sessions.CoreProject
INTERNAL: Factory method to create session.
createDatabaseSession() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Factory method to create session.
createdDatabaseSchemas - Variable in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
createdDatabaseSchemasOnDatabase - Variable in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
createDefaultFetchGroup() - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
PUBLIC: Returns clone of the default fetch group.
createDefaultTables(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Create the default table schema for the project this session associated with.
createDestinationDirectory(File) - Method in class org.eclipse.persistence.tools.PackageRenamer
This method creates an output directory for post-rename file(s).
createDiscoveryManager() - Method in class org.eclipse.persistence.sessions.coordination.broadcast.BroadcastTransportManager
ADVANCED: BroadcastTransportManager doesn't use DiscoveryManager - instead RemoteCommandManager calls createConnections method during initialization.
createDiscoveryManager() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
ADVANCED: Factory of new DiscoveryManager for different transports.
createDisplayString() - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL:
createDisplayString() - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: Used for debug logging
createDocument() - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
Creates a new document.
createDocumentBuilderFactory(boolean) - Static method in class org.eclipse.persistence.internal.helper.XMLHelper
Returns properly configured (e.g.
createDocumentWithPublicIdentifier(String, String, String) - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
Creates a new document with the specified public and system identifiers in the DOCTYPE, and adds a root element with the specified name.
createDocumentWithSystemIdentifier(String, String) - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
Creates a new document with the specified system identifier in the DOCTYPE, and adds a root element with the specified name.
createDOMRecord(String, EISAccessor) - Method in class org.eclipse.persistence.eis.EISPlatform
Allow the platform to handle the creation of the DOM record.
createDynamicAdapter(String) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
Create an adapter for given className
createDynamicClass(String) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
Create a new dynamic entity type for the specified name assuming the use of the default writer and its default parent class.
createDynamicClass(String, Class<?>) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
Create a new dynamic entity type for the specified name with the specified parent class.
createDynamicClass(String, DynamicClassWriter) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
Create a dynamic class registering a writer and then forcing the provided class name to be loaded.
createDynamicCollectionAdapter(String) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
Create a collection adapter for given className
createDynamicReferenceAdapter(String) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
Create a reference for given className
createEmptyCustomizer(Session) - Static method in class org.eclipse.persistence.internal.databaseaccess.ConnectionCustomizer
 
createEnum(DynamicClassLoader.EnumInfo) - Method in class org.eclipse.persistence.dynamic.DynamicClassWriter
 
createException(Exception) - Static method in exception org.eclipse.persistence.eis.EISException
 
createException(Object[], int) - Static method in exception org.eclipse.persistence.eis.EISException
 
createExpressionFor(DatabaseField, Expression, String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Override this method if the platform needs to use a custom function based on the DatabaseField
createExpressionFor(DatabaseField, Expression, String) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
 
createExternalConnection() - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
INTERNAL: JMSPublishingTransportManager has maximum one external connection.
createField(String) - Method in class org.eclipse.persistence.eis.interactions.XMLInteraction
INTERNAL:
createField(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: Create a new Database Field This method can be overridden by subclasses to return other field types
createField(String) - Method in class org.eclipse.persistence.internal.oxm.Context
 
createField(String) - Method in class org.eclipse.persistence.oxm.XMLContext
 
createField(String, Class<?>) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
createFullFetchGroup() - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
PUBLIC: Returns clone of the full fetch group - contains all the attributes, no nesting.
createIndexes(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL:
Write the SQL create index string to create index if passed a writer, else delegate to a method that executes the string on the database.
createIndexList(Map<DatabaseTable, OuterJoinExpressionHolder>, Map<DatabaseTable, Integer>) - Method in class org.eclipse.persistence.internal.expressions.OuterJoinExpressionHolder
 
createIndirectList() - Static method in class org.eclipse.persistence.indirection.IndirectCollectionsFactory
Construct an empty IndirectList with the default initial capacity (10) and default capacity increment (0).
createIndirectList(int) - Static method in class org.eclipse.persistence.indirection.IndirectCollectionsFactory
Construct an empty IndirectList with the specified initial capacity and default capacity increment (0).
createIndirectList(int, int) - Method in interface org.eclipse.persistence.indirection.IndirectCollectionsFactory.IndirectCollectionsProvider
Construct an empty IndirectList with the specified initial capacity and capacity increment.
createIndirectList(Collection<? extends E>) - Static method in class org.eclipse.persistence.indirection.IndirectCollectionsFactory
Construct an IndirectList containing the elements of the specified collection, in the order they are returned by the collection's iterator.
createIndirectList(Collection<? extends E>) - Method in interface org.eclipse.persistence.indirection.IndirectCollectionsFactory.IndirectCollectionsProvider
Constructs an IndirectList containing the elements of the specified collection, in the order they are returned by the collection's iterator.
createIndirectMap() - Static method in class org.eclipse.persistence.indirection.IndirectCollectionsFactory
Construct a new, empty IndirectMap with the default initial capacity (11) and the default load factor (0.75).
createIndirectMap(int) - Static method in class org.eclipse.persistence.indirection.IndirectCollectionsFactory
Construct a new, empty IndirectMap with the specified initial capacity and the default load factor (0.75).
createIndirectMap(int, float) - Method in interface org.eclipse.persistence.indirection.IndirectCollectionsFactory.IndirectCollectionsProvider
Construct a new, empty IndirectMap with the specified initial capacity and the specified load factor.
createIndirectMap(Map<? extends K, ? extends V>) - Static method in class org.eclipse.persistence.indirection.IndirectCollectionsFactory
Construct a new IndirectMap with the same mappings as the given Map.
createIndirectMap(Map<? extends K, ? extends V>) - Method in interface org.eclipse.persistence.indirection.IndirectCollectionsFactory.IndirectCollectionsProvider
Construct a new IndirectMap with the same mappings as the given Map.
createIndirectSet() - Static method in class org.eclipse.persistence.indirection.IndirectCollectionsFactory
Construct an empty IndirectSet with the default initial capacity (10) and the default load factor (0.75).
createIndirectSet(int) - Static method in class org.eclipse.persistence.indirection.IndirectCollectionsFactory
Construct an empty IndirectSet with the specified initial capacity and the default load factor (0.75).
createIndirectSet(int, float) - Method in interface org.eclipse.persistence.indirection.IndirectCollectionsFactory.IndirectCollectionsProvider
Construct an empty IndirectSet with the specified initial capacity and the specified load factor.
createIndirectSet(Collection<? extends E>) - Static method in class org.eclipse.persistence.indirection.IndirectCollectionsFactory
Constructs an IndirectSet containing the elements of the specified collection.
createIndirectSet(Collection<? extends E>) - Method in interface org.eclipse.persistence.indirection.IndirectCollectionsFactory.IndirectCollectionsProvider
Constructs an IndirectSet containing the elements of the specified collection.
createInformationAboutAllResourcesAcquiredAndDeferredByAllThreads(ConcurrencyManagerState) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Log information about all threads tracked in the concurrency manager.
createInformationAboutAllResourcesAcquiredAndDeferredByThread(ReadLockManager, DeferredLockManager, Set<ConcurrencyManager>, ConcurrencyManager, boolean, Thread, int, int, Set<Object>, String) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Build a string that tries to describe in as much detail as possible the resources associated to the current thread.
createInformationAboutAllThreadsWaitingToAcquireReadCacheKeys(Map<Thread, ConcurrencyManager>, Map<Thread, String>) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
In this page of log dumping information we want to give a summary to the user of threads that appear to be stuck doing an acquire of the cache key.
createInformationAboutAllThreadsWaitingToReleaseDeferredLocks(Set<Thread>) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Log information about threads not moving forward because they are waiting for the isBuildObjectOnThreadComplete to return true.
createInjectionManager(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
 
createInOutParameter(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Returns INOUT parameter.
createInOutParameter(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: Returns INOUT parameter.
createInputDOM(EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.XMLInteraction
Create a DOM for this interaction.
createInputDOM(EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.XQueryInteraction
Create a DOM for this interaction.
createInputRecord(EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
Create the appropriate input record for this interaction.
createInputRecord(EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.IndexedInteraction
Create an indexed input record for this interaction.
createInputRecord(EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.MappedInteraction
Create a mapped input record for this interaction.
createInputRecord(EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.XMLInteraction
Create a DOM input record for this interaction.
createInputRecord(EISInteraction, EISAccessor) - Method in class org.eclipse.persistence.eis.EISPlatform
Allow the platform to create the appropriate type of record for the interaction.
createInstantiationPolicy(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Create a instantiation policy of the type passed in as a string.
createListExplainingDeadLock(DeadLockComponent) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
When the last (repeating thread) of a dead lock is discovered and we start the unwinding of the recursion, the first DTO we create is flagged with DeadLockComponent.isFirstRepeatingThreadThatExplainsDeadLock() but it lacks all additional metadata.
createLocalConnection() - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
INTERNAL: JMSPublishingTransportManager has only two connections: one local and one external.
createLocalConnection() - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSTopicTransportManager
INTERNAL: JMSTopicTransportManager may have only two connections: one local and one external.
createLocalConnection() - Method in class org.eclipse.persistence.sessions.coordination.rmi.RMITransportManager
INTERNAL: Create the local command connection for this transport in a naming service and return it.
createLocalConnection() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Put the remote connection to local host in naming service and return the of the created remote connection
createLocalConnectionInJNDI() - Method in class org.eclipse.persistence.sessions.coordination.rmi.RMITransportManager
INTERNAL: Put the local command connection of this transport in JNDI and return it
createLocalConnectionInRegistry() - Method in class org.eclipse.persistence.sessions.coordination.rmi.RMITransportManager
INTERNAL: Put the local command connection of this transport in the Registry and return it
createLocate2Operator() - Static method in class org.eclipse.persistence.platform.database.HANAPlatform
INTERNAL: Build locate operator with 3 params i.e.
createLocate2Operator() - Static method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
createLocateOperator() - Static method in class org.eclipse.persistence.platform.database.HANAPlatform
INTERNAL: Build locate operator i.e.
createLocateOperator() - Static method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
createManagedBeanAndInjectDependencies(Class<T>) - Method in class org.eclipse.persistence.internal.sessions.cdi.DisabledInjectionManager
 
createManagedBeanAndInjectDependencies(Class<T>) - Method in interface org.eclipse.persistence.internal.sessions.cdi.InjectionManager
 
createManagedBeanAndInjectDependencies(Class<T>) - Method in class org.eclipse.persistence.internal.sessions.cdi.InjectionManagerImpl
Creates an instance of the CDI managed bean.
createMap() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
This method is used internally to create a map to hold the persistenceContexts.
createMap(int) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
This method is used internally to create a map to hold the persistenceContexts.
createMapComponentFromJoinedRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection and a join query is executed.
createMapComponentFromJoinedRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection and a join query is executed.
createMapComponentFromJoinedRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection and a join query is used.
createMapComponentFromJoinedRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection.
createMapComponentFromRow(AbstractRecord, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection.
createMapComponentFromRow(AbstractRecord, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection.
createMapComponentFromRow(AbstractRecord, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection.
createMapComponentFromRow(AbstractRecord, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection.
createMapComponentFromRow(AbstractRecord, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection.
createMapComponentFromRow(AbstractRecord, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection.
createMapComponentFromRow(AbstractRecord, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in interface org.eclipse.persistence.mappings.foundation.MapComponentMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection.
createMapComponentFromRow(AbstractRecord, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection.
createMapComponentFromRow(AbstractRecord, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection.
createMapComponentFromRow(AbstractRecord, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL Called when a DatabaseMapping is used to map the key in a collection.
createMapComponentsFromSerializableKeyInfo(Object[], AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Create an instance of the Key object from the key information extracted from the map.
createMapComponentsFromSerializableKeyInfo(Object[], AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Create an instance of the Key object from the key information extracted from the map.
createMapComponentsFromSerializableKeyInfo(Object[], AbstractSession) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Create an instance of the Key object from the key information extracted from the map.
createMapComponentsFromSerializableKeyInfo(Object[], AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Create an instance of the Key object from the key information extracted from the map.
createMarshaller() - Method in class org.eclipse.persistence.internal.oxm.Context
 
createMarshaller() - Method in class org.eclipse.persistence.oxm.XMLContext
Create a new XMLMarshaller
createMinimalFetchGroup() - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
PUBLIC: Returns clone of the minimal fetch group.
createModifyRowForAddTargetQuery() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL:
createModifyRowForAddTargetQuery() - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL:
createMultipleTableInsertOrder() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Create multiple table insert order.
createMultipleTableInsertOrderFromComparison(int[][], int) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: This helper method creates multipleTableInsertOrderFromComparison using comparison matrix created by createTableComparison(getTables()) method call.
createNewDocument(String) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Creates a new Document and returns the root element of that document
createNewDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Creates a new Document and returns the root element of that document
createNewLevel(boolean, JsonBuilderRecord.Level, boolean) - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord
 
createNewLevel(boolean, T, boolean) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
createNode() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Instantiate an instance of the operator's node class.
createObject(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Either drop from the database directly or write the statement to a file.
createObject(DatabaseObjectDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Use the definition object to create the schema entity on the database.
createObjectChangeSet(Object, Object, UnitOfWorkChangeSet, boolean, AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.changetracking.AttributeChangeTrackingPolicy
INTERNAL: Create ObjectChangeSet
createObjectChangeSet(Object, Object, UnitOfWorkChangeSet, boolean, AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: Create ObjectChangeSet
createObjectChangeSet(Object, UnitOfWorkChangeSet, boolean, boolean, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Used by the ObjectBuilder to create an ObjectChangeSet for the specified clone object.
createObjectChangeSet(Object, UnitOfWorkChangeSet, boolean, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Used by the ObjectBuilder to create an ObjectChangeSet for the specified clone object.
createObjectChangeSet(Object, UnitOfWorkChangeSet, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Used by the ObjectBuilder to create an ObjectChangeSet for the specified clone object.
createObjectChangeSetThroughComparison(Object, Object, UnitOfWorkChangeSet, boolean, AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: Create ObjectChangeSet
createObjectChangeSetThroughComparison(Object, Object, UnitOfWorkChangeSet, boolean, AbstractSession, ClassDescriptor) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: Create ObjectChangeSet through comparison.
createOnDatabase(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Execute the DDL to create this object.
createOnDatabase(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.SequenceDefinition
INTERNAL: Creates this sequence definition on the database.
createOrReplaceSequences(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Common implementor for createSequence and replaceSequence
createOrReplaceSequences(boolean, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Common implementor for createSequence and replaceSequence, distinguishes between sequence tables and sequence objects
createOutput(String, String) - Method in interface org.eclipse.persistence.internal.oxm.schema.SchemaModelOutputResolver
Determines the location where a given schema file (of the given namespace URI) will be generated, and return it as a Result object.
createOutputRecord(EISInteraction, AbstractRecord, EISAccessor) - Method in class org.eclipse.persistence.eis.EISPlatform
Allow the platform to create the appropriate type of record for the interaction.
createParserFactory(boolean) - Static method in class org.eclipse.persistence.internal.helper.XMLHelper
Returns properly configured (e.g.
createPlatform(Class<? extends DatabasePlatform>) - Method in class org.eclipse.persistence.internal.databaseaccess.JsonPlatformManager
Creates DatabaseJsonPlatform implementation instance registered for provided database platform.
createPlatformDefaultSequence() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Create platform-default Sequence
createPlatformDefaultSequence() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Create platform-default Sequence
createPlatformDefaultSequenceUndefined(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
createPrimaryKeyExpression(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Creates and stores primary key expression.
createPrimaryKeyFromId(Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: Use the key to create a EclipseLink primary key.
createPrimaryKeyInstance(Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: Create an instance of the Id class or value from the object.
createPrimaryKeyInstanceFromId(Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: Create an instance of the composite primary key class for the key object.
createPrimaryKeyInstanceFromPrimaryKeyValues(AbstractSession, int[], Object...) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: Create an instance of the composite primary key class for the key object.
createProtectedInstanceFromCachedData(Object, Integer, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: This method is similar to getAndCloneCacheKeyFromParent.
createQueryKeyForMapKey() - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Create a query key that links to the map key InterfaceContainerPolicy does not support maps, so this method will return null subclasses will extend this method.
createQueryKeyForMapKey() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Create a query key that links to the map key.
createQueryKeyForMapKey() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Create a query key that links to the map key.
createQueryKeyForMapKey() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Create a query key that links to the map key
createQueryKeyForMapKey() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Create a query key that links to the map key.
createQueryKeyForMapKey() - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Create a query key that links to the map key
createQueryKeyForMapKey() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Create a query key that links to the map key
createReader(Unmarshaller) - Method in class org.eclipse.persistence.internal.oxm.record.ExtendedSource
 
createReader(Unmarshaller) - Method in class org.eclipse.persistence.oxm.json.JsonParserSource
 
createReader(Unmarshaller) - Method in class org.eclipse.persistence.oxm.json.JsonStructureSource
 
createReader(Unmarshaller, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.ExtendedSource
 
createReader(Unmarshaller, Class<?>) - Method in class org.eclipse.persistence.oxm.json.JsonParserSource
 
createReader(Unmarshaller, Class<?>) - Method in class org.eclipse.persistence.oxm.json.JsonStructureSource
 
createReadLockAcquisitionMetadata(ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
The concurrency managers about to acquire a cache key.
createRecord() - Method in class org.eclipse.persistence.internal.oxm.record.ExtendedResult
 
createRecord() - Method in class org.eclipse.persistence.oxm.json.JsonArrayBuilderResult
 
createRecord() - Method in class org.eclipse.persistence.oxm.json.JsonGeneratorResult
 
createRecord() - Method in class org.eclipse.persistence.oxm.json.JsonObjectBuilderResult
 
createRecord(int, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Create a new row/record for the object builder.
createRecord(int, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
Create a new row/record for the object builder.
createRecord(int, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
Create a new row/record for the object builder.
createRecord(ABSTRACT_SESSION) - Method in class org.eclipse.persistence.internal.core.descriptors.CoreObjectBuilder
Create a new row/record for the object builder.
createRecord(ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
createRecord(String, String, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
Create a new row/record for the object builder with the given name and namespace resolver instead of the namespace resolver from the descriptor.
createRecord(String, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
Create a new row/record for the object builder with the given name.
createRecord(String, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
Create a new row/record for the object builder with the given name.
createRecord(String, Node, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
Create a new row/record for the object builder with the given name.
createRecord(String, Node, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
Create a new row/record for the object builder with the given name.
createRecord(CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
Create a new row/record for the object builder.
createRecord(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Create a new row/record for the object builder.
createRecord(AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
Create a new row/record for the object builder.
createRecord(AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
Create a new row/record for the object builder.
createRecordElement(String, Object, EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
Create the appropriate record element for the data value.
createRecordFor(Object, Field, XMLRecord, Mapping) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
createRecordFor(Object, DocumentPreservationPolicy) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
createRecordFor(Object, DocumentPreservationPolicy, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
createRecordForPKExtraction(int, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Create a new row/record for the object builder.
createRecordForPKExtraction(int, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
Create a new row/record for the object builder.
createRecordFromXMLContext(XMLContext) - Method in class org.eclipse.persistence.internal.core.descriptors.CoreObjectBuilder
Create a new row/record from XMLContext.
createRecordFromXMLContext(XMLContext) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
createRecordFromXMLContext(XMLContext) - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
createRemoteSession() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Returns remote client session.
createRemoteSession() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
PUBLIC: Returns a remote session.
createRemoteSessionController() - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIServerSessionManager
 
createRemoteSessionController() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIServerSessionManagerDispatcher
 
createResourceException(Object[], int) - Static method in exception org.eclipse.persistence.eis.EISException
 
createRoot() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
createRoot() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
INTERNAL:
createRoot() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
INTERNAL
createRoot() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
INTERNAL
createRoot() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
createRoot() - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
INTERNAL
createRootUnmarshalRecord(Class<?>) - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
INTERNAL
createRootUnmarshalRecord(Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
INTERNAL
createSchemaFactory(String, boolean) - Static method in class org.eclipse.persistence.internal.helper.XMLHelper
Returns properly configured (e.g.
createSchemaWriter - Variable in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
createSequences() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Create all the receiver's sequences on the database for all of the loaded descriptors.
createSequencing(AbstractSession) - Static method in class org.eclipse.persistence.internal.sequencing.SequencingFactory
INTERNAL: Takes a potential owner - a Session, returns Sequencing object.
createSequencingCallback() - Method in interface org.eclipse.persistence.internal.sequencing.SequencingCallbackFactory
INTERNAL: Create SequencingCallback.
createSequencingHome(DatabaseSessionImpl) - Static method in class org.eclipse.persistence.internal.sequencing.SequencingFactory
INTERNAL: Takes a potential owner - a DatabaseSession, returns SequencingHome object.
createSerializableMapKeyInfo(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Creates the Array of simple types used to recreate this map.
createSerializableMapKeyInfo(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Creates the Array of simple types used to recreate this map.
createSerializableMapKeyInfo(Object, AbstractSession) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Creates the Array of simple types used to recreate this map.
createSerializableMapKeyInfo(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Creates the Array of simple types used to recreate this map.
createServerPlatform(DatabaseSession, String, ClassLoader) - Static method in class org.eclipse.persistence.platform.server.ServerPlatformUtils
Create an instance of ServerPlatform from parameters passed in.
createServerSession() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Factory method to create a server session.
createServerSession(int, int) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Factory method to create a server session.
createServerSession(int, int, int) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Factory method to create a server session.
createServerSession(ConnectionPolicy) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Factory method to create a server session.
createSession(DatabaseSessionConfig, Login) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Return a DatabaseSession object from it's config object using either the project classes or project XML files.
createSessionLog() - Method in class org.eclipse.persistence.platform.server.was.WebSphere_7_Platform
 
createSlots(DynamicEntityImpl) - Method in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
 
createSQLFiles - Variable in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
createSQLSelectStatementForAssignedExpressionForUpdateAll(Expression) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
createSQLSelectStatementForModifyAll(Expression) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
createSQLSelectStatementForModifyAll(Expression, Expression, ClassDescriptor, boolean, boolean) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Customary inheritance expression is required for DeleteAllQuery and UpdateAllQuery preparation.
createSQLSelectStatementForModifyAllForTempTable(HashMap) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
createSQLSelectStatementForUpdateAllForOracleAnonymousBlock(HashMap) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
createStruct(String, Object[], Connection) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Platforms that support java.sql.Struct may override this method.
createStruct(String, Object[], AbstractRecord, Vector<DatabaseField>, AbstractSession, Connection) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: This method builds a Struct using the unwrapped connection within the session
createStruct(String, Object[], AbstractSession, Connection) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: This method builds a Struct using the unwrapped connection within the session
createStubbedMapComponentFromSerializableKeyInfo(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Create an instance of the Key object from the key information extracted from the map.
createStubbedMapComponentFromSerializableKeyInfo(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Create an instance of the Key object from the key information extracted from the map.
createStubbedMapComponentFromSerializableKeyInfo(Object, AbstractSession) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Create an instance of the Key object from the key information extracted from the map.
createStubbedMapComponentFromSerializableKeyInfo(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Create an instance of the Key object from the key information extracted from the map.
createSubSelectExpressionForCount(Expression, Expression, String, Class<?>) - Static method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
INTERNAL: This factory method is used to build a subselect that will do a count.
createTableComparison(List<DatabaseTable>, int) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: This helper method creates a matrix that contains insertion order comparison for the tables.
createTableOrder(int, int, int[], int[][]) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: This helper method recursively puts indexes from 0 to nTables-1 into tableOrder according to tableComparison 2 dim array.
createTables(boolean, Collection<DynamicType>) - Method in class org.eclipse.persistence.tools.schemaframework.DynamicSchemaManager
 
createTables(boolean, DynamicType...) - Method in class org.eclipse.persistence.tools.schemaframework.DynamicSchemaManager
 
createTables(DynamicType...) - Method in class org.eclipse.persistence.tools.schemaframework.DynamicSchemaManager
Create the database tables for one or more entityTypes.
createTables(DatabaseSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
This creates the tables on the database.
createTables(DatabaseSession, SchemaManager) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
This creates the tables on the database.
createTables(DatabaseSession, SchemaManager, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
This creates the tables on the database.
createTables(DatabaseSession, SchemaManager, boolean, boolean, boolean, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
This creates the tables on the database.
createToStringExplainingOwnedCacheKey(ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
createTransformerFactory(boolean) - Static method in class org.eclipse.persistence.internal.helper.XMLHelper
Returns properly configured (e.g.
createTranslationRecord(AbstractRecord, EISAccessor) - Method in class org.eclipse.persistence.eis.interactions.MappedInteraction
Create a mapped input record for this interaction.
createUnmarshaller() - Method in class org.eclipse.persistence.internal.oxm.Context
 
createUnmarshaller() - Method in class org.eclipse.persistence.oxm.XMLContext
Create a new XMLUnmarshaller
createUnmarshaller(Map<String, Boolean>) - Method in class org.eclipse.persistence.oxm.XMLContext
Create a new XMLUnmarshaller
createUnmarshalRecord(DESCRIPTOR, ABSTRACT_SESSION) - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
INTERNAL
createUnmarshalRecord(DESCRIPTOR, ABSTRACT_SESSION) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
INTERNAL
createUnmarshalRecord(XMLDescriptor, AbstractSession) - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
INTERNAL
createUnownedElement(Node, Field) - Method in class org.eclipse.persistence.internal.oxm.XPathEngine
 
createValidator() - Method in class org.eclipse.persistence.oxm.XMLContext
Create a new XMLValidator
createVector(Number, String, int) - Method in class org.eclipse.persistence.sequencing.StandardSequence
INTERNAL: given sequence = 10, size = 5 will create Vector (6,7,8,9,10)
createVectorAtNextVal(Number, String, int) - Method in class org.eclipse.persistence.sequencing.StandardSequence
INTERNAL: given sequence = 10, size = 5 will create Vector (10,11,12,13,14)
createWhereClauseForDeleteNullQuery(ExpressionBuilder) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
createWhereClauseForDeleteQuery(ExpressionBuilder) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
createWithBaseLast(Expression, Object, ExpressionOperator) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
createWithBaseLast(Expression, Object, ExpressionOperator) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: added for Trim support.
createWrappedObjectFromExistingWrappedObject(Object, Object, ClassDescriptor, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: This method will actually potentially wrap an object in two ways.
createWrappedObjectFromExistingWrappedObject(Object, Object, ClassDescriptor, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: This method will actually potentially wrap an object in two ways.
createWrappedObjectFromExistingWrappedObject(Object, Object, ClassDescriptor, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: This method will actually potentially wrap an object in two ways.
createXMLRecord(String) - Method in class org.eclipse.persistence.eis.interactions.XMLInteraction
INTERNAL: Use the createRecord method on ObjectBuilder in case the root element is namespace qualified
createXPathFactory(boolean) - Static method in class org.eclipse.persistence.internal.helper.XMLHelper
Returns properly configured (e.g.
CREATION_THREAD_HASHCODE - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
CREATION_THREAD_HASHCODE - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
CREATION_THREAD_ID - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
CREATION_THREAD_ID - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
CREATION_THREAD_NAME - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
CREATION_THREAD_NAME - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
creationalContext - Variable in class org.eclipse.persistence.internal.sessions.cdi.InjectionManagerImpl
 
creationPrefix - Variable in class org.eclipse.persistence.tools.schemaframework.TableDefinition
 
creationSuffix - Variable in class org.eclipse.persistence.internal.helper.DatabaseTable
 
creationSuffix - Variable in class org.eclipse.persistence.tools.schemaframework.TableDefinition
 
criteriaBase - Variable in class org.eclipse.persistence.internal.expressions.SubSelectExpression
 
cType_ - Static variable in class org.eclipse.persistence.services.ClassSummaryDetailBase
 
cumulativeUOWChangeSet - Variable in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
Used to store the final UnitOfWorkChangeSet for merge into the shared cache
CURRENT - Static variable in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Current Java SE platform.
CURRENT_LOADER_NOT_VALID - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
CURRENT_WORKING_DIRECTORY - Static variable in class org.eclipse.persistence.internal.helper.Helper
Prime the platform-dependent current working directory
currentAlias - Variable in class org.eclipse.persistence.expressions.Expression
 
currentAlias - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
currentAliasNumber - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
currentClass - Variable in class org.eclipse.persistence.internal.codegen.CodeGenerator
 
currentDate() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This gives access to the current date on the database through expression.
currentDate() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
CurrentDate - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
Function to obtain the current date on the database with date components only but without time components.
currentDateDate() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This gives access to the current date only on the database through expression.
currentDateOperator() - Method in class org.eclipse.persistence.platform.database.Informix11Platform
currentDateOperator() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Create the current date operator for this platform.
currentDescriptor - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
currentGroup - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
currentIndex - Variable in class org.eclipse.persistence.descriptors.partitioning.RoundRobinPartitioningPolicy
 
currentIndex() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
Retrieves the current row index number
currentIndex() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Retrieves the current row index number
currentItem - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
currentLoaderNotValid(ClassLoader) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
currentlyProcessedListeners - Variable in class org.eclipse.persistence.transaction.AbstractTransactionController
Non-null only in case sequencing callbacks are used: numSessionsRequiringSequencingCallback > 0
currentMapping - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
currentObject - Variable in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
currentObject - Variable in class org.eclipse.persistence.oxm.record.XMLRecord
 
currentSession - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Used only in externalConnectionPooling case.
currentThreadIsKnownToBeWaitingForAnyResource(ConcurrencyManagerState, Thread) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
This a helper sanity check.
currentThreadIsStuckForSomeTimeProduceTinyLogMessage(long, ConcurrencyManager, DeferredLockManager, ReadLockManager) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
We have a thread that is not evolving for quite some while.
currentTime - Variable in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
 
currentTime() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This gives access to the current time only on the database through expression.
currentTime() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
currentTime() - Static method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL specific currentTime operator.
CurrentTime - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
Function to obtain the current time on the database with time components only but without date components.
currentTimeOperator() - Method in class org.eclipse.persistence.platform.database.Informix11Platform
currentTimeStamp() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This gives access to the current timestamp on the database through expression.
currentTimeStamp() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
currentTimeStamp() - Static method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL specific currentTimeStamp operator.
currentWorkingDirectory() - Static method in class org.eclipse.persistence.internal.helper.Helper
Return the name of the "current working directory".
Cursor - Class in org.eclipse.persistence.queries
Purpose: Abstract class for CursoredStream and ScrolableCursor
Cursor() - Constructor for class org.eclipse.persistence.queries.Cursor
INTERNAL: Default constructor.
Cursor(DatabaseCall, CursorPolicy) - Constructor for class org.eclipse.persistence.queries.Cursor
INTERNAL:
CURSOR - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.cursor"
CURSOR_INITIAL_SIZE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.cursor.initial-size"
CURSOR_PAGE_SIZE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.cursor.page-size"
CURSOR_SIZE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.cursor.size-sql"
cursorCode - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allow for the code that is used for preparing cursored outs for a storedprocedure to be settable.
CursoredStream - Class in org.eclipse.persistence.queries
Purpose: Stream class which is used to deal with large collections returned from TOPLink queries more efficiently.
CursoredStream() - Constructor for class org.eclipse.persistence.queries.CursoredStream
INTERNAL: Initialize the state of the stream
CursoredStream(DatabaseCall, CursoredStreamPolicy) - Constructor for class org.eclipse.persistence.queries.CursoredStream
INTERNAL: Initialize the state of the stream
CursoredStream_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
cursoredStreamClose(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Used for closing cursored streams across RMI.
cursoredStreamClose(ObjID) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Used for closing cursored streams across RMI.
cursoredStreamClose(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Used for closing cursored streams across RMI.
cursoredStreamClose(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Used for closing cursored streams across RMI.
cursoredStreamClose(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Used for closing cursored streams across RMI.
cursoredStreamNextpage(Transporter, int) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Retrieve next page of objects from the remote cursored stream once, avoid page size round trips from the server to the client
cursoredStreamNextPage(RemoteCursoredStream, ReadQuery, DistributedSession, int) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Retrieve next page size of objects from the remote cursored stream
cursoredStreamNextPage(RemoteCursoredStream, ReadQuery, DistributedSession, int) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Retrieve next page size of objects from the remote cursored stream
cursoredStreamNextPage(Transporter, int) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Retrieve next page size of objects from the remote cursored stream
cursoredStreamNextPage(Transporter, int) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Retrieve next page size of objects from the remote cursored stream
CursoredStreamPolicy - Class in org.eclipse.persistence.queries
Purpose: Used to support cursored streams in a read query.
CursoredStreamPolicy() - Constructor for class org.eclipse.persistence.queries.CursoredStreamPolicy
default constructor
CursoredStreamPolicy(ReadQuery, int) - Constructor for class org.eclipse.persistence.queries.CursoredStreamPolicy
set the initial read size to match the page size
CursoredStreamPolicy(ReadQuery, int, int) - Constructor for class org.eclipse.persistence.queries.CursoredStreamPolicy
 
CursoredStreamPolicy(ReadQuery, int, int, ValueReadQuery) - Constructor for class org.eclipse.persistence.queries.CursoredStreamPolicy
 
cursoredStreamSize(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Return the cursored stream size
cursoredStreamSize(ObjID) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Return the cursored stream size
cursoredStreamSize(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Return the wrapped cursored stream from the server
cursoredStreamSize(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
INTERNAL: Return the cursored stream size
cursoredStreamSize(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Return the cursored stream size
cursorOutput - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
CursorPolicy - Class in org.eclipse.persistence.queries
Purpose: Abstract class for all Cursor-related policy objects
CursorPolicy() - Constructor for class org.eclipse.persistence.queries.CursorPolicy
INTERNAL: default constructor
CursorPolicy(ReadQuery, int) - Constructor for class org.eclipse.persistence.queries.CursorPolicy
INTERNAL:
cursorRetrieveNextRow(Vector<DatabaseField>, ResultSet, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Advance the result set and return a Record populated with values from the next valid row in the result set.
cursorRetrievePreviousRow(Vector<DatabaseField>, ResultSet, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Advance the result set and return a DatabaseRow populated with values from the next valid row in the result set.
cursorSelectAllRows() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Read all rows from the database using a cursored stream.
cursorSelectAllRows() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Read all rows from the database using a cursored stream.
cursorSelectObjects(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Returns a remote cursor stub in a transporter
cursorSelectObjects(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
To get remote cursor stub in a transporter
cursorSelectObjects(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Returns a remote cursor stub in a transporter
cursorSelectObjects(CursoredStreamPolicy) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Return remote cursor stream.
cursorSelectObjects(CursoredStreamPolicy, DistributedSession) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Get remote cursor stream.
cursorSelectObjects(CursoredStreamPolicy, DistributedSession) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Returns remote cursor stream
cursorSelectObjects(ScrollableCursorPolicy) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Return remote scrollable cursor
cursorSelectObjects(ScrollableCursorPolicy, DistributedSession) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Get remote cursor stream.
cursorSelectObjects(ScrollableCursorPolicy, DistributedSession) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Returns remote cursor stream
CUSTOM_MODIFY - org.eclipse.persistence.internal.databaseaccess.DatasourceCall.ParameterType
 
CUSTOM_QUERY_AND_RETURNING_POLICY_CONFLICT - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
CUSTOM_SERVER_PLATFORM_CLASS_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
customize() - Method in class org.eclipse.persistence.internal.databaseaccess.ConnectionCustomizer
INTERNAL: Applies customization to connection.
customize(ClassDescriptor) - Method in interface org.eclipse.persistence.config.DescriptorCustomizer
Customize the provided descriptor.
customize(Session) - Method in interface org.eclipse.persistence.config.SessionCustomizer
 
customize(Session) - Method in class org.eclipse.persistence.dynamic.DynamicHelper.SessionCustomizer
 
customizer - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Allows session-specific connection customization.
Customizer - Annotation Type in org.eclipse.persistence.annotations
The Customizer annotation is used to specify a class that implements the org.eclipse.persistence.config.DescriptorCustomizer interface and is to run against an entity's class descriptor after all metadata processing has been completed.
CustomObjectInputStream - Class in org.eclipse.persistence.internal.helper
INTERNAL: Defines a custom ObjectInputStream that is used with SerializedObjectConverter to ensure the correct class loader is used.
CustomObjectInputStream(InputStream, Session) - Constructor for class org.eclipse.persistence.internal.helper.CustomObjectInputStream
 
customParameterMarker() - Method in interface org.eclipse.persistence.internal.databaseaccess.DatabaseJsonPlatform
JSON parameter marker in SQL expression of PreparedStatement.
CustomPartitioningPolicy - Class in org.eclipse.persistence.descriptors.partitioning
PUBLIC: Defines a user defined partitioning policy.
CustomPartitioningPolicy() - Constructor for class org.eclipse.persistence.descriptors.partitioning.CustomPartitioningPolicy
 
customQueryAndReturningPolicyFieldConflict(String, String, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
CustomServerPlatform - Class in org.eclipse.persistence.platform.server
INTERNAL: This is the concrete subclass responsible for handling backward compatibility for 9.0.4.
CustomServerPlatform(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.CustomServerPlatform
INTERNAL: Default Constructor: JTA is disabled until a transaction controller class is set.
CustomServerPlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
CustomServerPlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.CustomServerPlatformConfig
 
CYCLE_RECOVERABLE - Static variable in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
CYCLE_RECOVERABLE_CONTEXT - Static variable in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
CycleDetectionStack() - Constructor for class org.eclipse.persistence.internal.oxm.record.MarshalRecord.CycleDetectionStack
 
CycleRecoverableContextProxy - Class in org.eclipse.persistence.internal.oxm
Allows for the reflective creation of an implementation of Sun's org.glassfish.jaxb.runtime.CycleRecoverable$Context interface.

D

DailyCacheInvalidationPolicy - Class in org.eclipse.persistence.descriptors.invalidation
PUBLIC: A CacheInvalidationPolicy that allows objects to expire every day at a specific time.
DailyCacheInvalidationPolicy() - Constructor for class org.eclipse.persistence.descriptors.invalidation.DailyCacheInvalidationPolicy
INTERNAL: Default constructor for Project XML if setters are not called to set expiry times, expiry time will be the time of day at which this object is instantiated.
DailyCacheInvalidationPolicy(int, int, int, int) - Constructor for class org.eclipse.persistence.descriptors.invalidation.DailyCacheInvalidationPolicy
PUBLIC: Construct a daily policy that will allow objects to expire at a specific time of day.
data - Variable in class org.eclipse.persistence.queries.ComplexQueryResult
 
DATA_HANDLER - Variable in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
Database - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
DATABASE_ACCESSOR_CONNECTION_IS_NULL - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
DATABASE_ACCESSOR_NOT_CONNECTED - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
DATABASE_EVENT_LISTENER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.cache.database-event-listener" property allows integration with a database event notification service.
DATABASE_MAPPING_COULD_NOT_BE_FOUND_FOR_ENTITY_ATTRIBUTE - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
databaseAccessor - Variable in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
This member variable stores the reference to the DatabaseAccessor that is using this Mechanism to handle the batch writing
DatabaseAccessor - Class in org.eclipse.persistence.internal.databaseaccess
INTERNAL: DatabaseAccessor is private to EclipseLink.
DatabaseAccessor() - Constructor for class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
 
DatabaseAccessor(Object) - Constructor for class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Create a database accessor with the given connection.
databaseAccessorConnectionIsNull(DatabaseAccessor, AbstractSession) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
databaseAccessorNotConnected() - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
databaseAccessorNotConnected(DatabaseAccessor) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
DatabaseCall - Class in org.eclipse.persistence.internal.databaseaccess
INTERNAL: Purpose: Used as an abstraction of a database invocation.
DatabaseCall() - Constructor for class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
databaseChangeNotificationType - Variable in class org.eclipse.persistence.descriptors.CachePolicy
Allows configuration of database change event notification.
databaseChangeNotificationType() - Method in annotation type org.eclipse.persistence.annotations.Cache
(Optional) The database change notification mode.
DatabaseChangeNotificationType - Enum in org.eclipse.persistence.annotations
Configures what type of database change notification an entity/descriptor should use.
databaseEventListener - Variable in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
Database event listener, this allows database events to invalidate the cache.
DatabaseEventListener - Interface in org.eclipse.persistence.platform.database.events
PUBLIC: Defines the API for integration with a database event notification service.
DatabaseException - Exception in org.eclipse.persistence.exceptions
Purpose: Wrapper for any database exception that occurred through EclipseLink.
DatabaseException() - Constructor for exception org.eclipse.persistence.exceptions.DatabaseException
INTERNAL: EclipseLink exceptions should only be thrown by the EclipseLink code.
DatabaseException(String) - Constructor for exception org.eclipse.persistence.exceptions.DatabaseException
INTERNAL: EclipseLink exceptions should only be thrown by the EclipseLink code.
DatabaseException(SQLException) - Constructor for exception org.eclipse.persistence.exceptions.DatabaseException
INTERNAL: EclipseLink exceptions should only be thrown by the EclipseLink code.
DatabaseExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for DatabaseException messages.
DatabaseExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.DatabaseExceptionResource
Default constructor.
databaseField - Variable in class org.eclipse.persistence.descriptors.CMPPolicy.KeyIsElementAccessor
 
DatabaseField - Class in org.eclipse.persistence.internal.helper
INTERNAL:
DatabaseField() - Constructor for class org.eclipse.persistence.internal.helper.DatabaseField
 
DatabaseField(String) - Constructor for class org.eclipse.persistence.internal.helper.DatabaseField
 
DatabaseField(String, String) - Constructor for class org.eclipse.persistence.internal.helper.DatabaseField
 
DatabaseField(String, String, String) - Constructor for class org.eclipse.persistence.internal.helper.DatabaseField
 
DatabaseField(String, DatabaseTable) - Constructor for class org.eclipse.persistence.internal.helper.DatabaseField
 
DatabaseField(String, DatabaseTable, String, String) - Constructor for class org.eclipse.persistence.internal.helper.DatabaseField
 
databaseFields - Variable in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
DatabaseField pool (synchronized with above 'fieldMap')
databaseFieldsToTableAliases - Variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
DatabaseJsonPlatform - Interface in org.eclipse.persistence.internal.databaseaccess
Database platform JSON extension.
DatabaseLogin - Class in org.eclipse.persistence.sessions
Purpose: Hold the configuration information necessary to connect to a JDBC driver.
DatabaseLogin() - Constructor for class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Create a new login.
DatabaseLogin(DatabasePlatform) - Constructor for class org.eclipse.persistence.sessions.DatabaseLogin
ADVANCED: Create a new login for the given platform.
DatabaseLoginConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.login
INTERNAL:
DatabaseLoginConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
DatabaseMapping - Class in org.eclipse.persistence.mappings
Purpose: Defines how an attribute of an object maps to and from the database
DatabaseMapping() - Constructor for class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: Default constructor.
DatabaseMapping.WriteType - Enum in org.eclipse.persistence.mappings
 
DatabaseObjectDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Define a database object for the purpose of creation and deletion.
DatabaseObjectDefinition() - Constructor for class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
 
databasePlatform - Variable in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
the target database platform.
DatabasePlatform - Class in org.eclipse.persistence.internal.databaseaccess
DatabasePlatform is private to EclipseLink.
DatabasePlatform - Class in org.eclipse.persistence.platform.database
DatabasePlatform is private to EclipseLink.
DatabasePlatform() - Constructor for class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Creates an instance of default database platform.
DatabasePlatform() - Constructor for class org.eclipse.persistence.platform.database.DatabasePlatform
Creates an instance of default database platform.
DatabaseQuery - Class in org.eclipse.persistence.queries
Purpose: Abstract class for all database query objects.
DatabaseQuery() - Constructor for class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Initialize the state of the query
DatabaseQuery_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
DatabaseQuery.ParameterType - Enum in org.eclipse.persistence.queries
Used for parameter retreival in JPQL
DatabaseQueryMechanism - Class in org.eclipse.persistence.internal.queries
Purpose: Abstract class for all database query mechanism objects.
DatabaseQueryMechanism() - Constructor for class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Initialize the state of the query.
DatabaseQueryMechanism(DatabaseQuery) - Constructor for class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Initialize the state of the query
DatabaseRecord - Class in org.eclipse.persistence.sessions
Purpose: Define a representation of a database row as field=>value pairs.
DatabaseRecord() - Constructor for class org.eclipse.persistence.sessions.DatabaseRecord
INTERNAL: Returns a record (of default size).
DatabaseRecord(int) - Constructor for class org.eclipse.persistence.sessions.DatabaseRecord
INTERNAL: Returns a record of the given initial capacity.
DatabaseRecord(Vector, Vector) - Constructor for class org.eclipse.persistence.sessions.DatabaseRecord
INTERNAL: Builds row from database result fields and values.
DatabaseRecord(Vector, Vector, int) - Constructor for class org.eclipse.persistence.sessions.DatabaseRecord
INTERNAL: Builds row from database result fields and values.
DatabaseRow_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
DatabaseSession - Interface in org.eclipse.persistence.sessions
Purpose: Add login and configuration API to that of Session.
DatabaseSessionConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.session
INTERNAL:
DatabaseSessionConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.session.DatabaseSessionConfig
 
DatabaseSessionImpl - Class in org.eclipse.persistence.internal.sessions
Implementation of org.eclipse.persistence.sessions.DatabaseSession The public interface should be used.
DatabaseSessionImpl() - Constructor for class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Create and return a new default database session.
DatabaseSessionImpl(Login) - Constructor for class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Create and return a new session.
DatabaseSessionImpl(Project) - Constructor for class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Create and return a new session.
DatabaseTable - Class in org.eclipse.persistence.internal.helper
INTERNAL:
DatabaseTable() - Constructor for class org.eclipse.persistence.internal.helper.DatabaseTable
Initialize the newly allocated instance of this class.
DatabaseTable(String) - Constructor for class org.eclipse.persistence.internal.helper.DatabaseTable
 
DatabaseTable(String, String) - Constructor for class org.eclipse.persistence.internal.helper.DatabaseTable
 
DatabaseTable(String, String, boolean, String, String) - Constructor for class org.eclipse.persistence.internal.helper.DatabaseTable
 
DatabaseTable(String, String, String) - Constructor for class org.eclipse.persistence.internal.helper.DatabaseTable
 
databaseType - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
databaseType() - Method in annotation type org.eclipse.persistence.annotations.Array
(Required) The database name of the database array structure type.
databaseType() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLParameter
(Optional) The database data-type for the paramter.
DatabaseType - Interface in org.eclipse.persistence.internal.helper
PUBLIC: Interface used to categorize arguments to Stored Procedures as either 'simple' (use subclass SimpleDatabaseType) or 'complex' (use subclass ComplexDatabaseType)
DatabaseType.DatabaseTypeHelper - Enum in org.eclipse.persistence.internal.helper
 
databaseTypeHelper - org.eclipse.persistence.internal.helper.DatabaseType.DatabaseTypeHelper
 
DatabaseTypeWrapper - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: a helper class that holds DatabaseType's.
DatabaseTypeWrapper() - Constructor for class org.eclipse.persistence.internal.sessions.factories.DatabaseTypeWrapper
 
DatabaseTypeWrapper(DatabaseType) - Constructor for class org.eclipse.persistence.internal.sessions.factories.DatabaseTypeWrapper
 
databaseURL - Variable in class org.eclipse.persistence.sessions.DefaultConnector
 
DatabaseValueHolder<T> - Class in org.eclipse.persistence.internal.indirection
DatabaseValueHolder wraps a database-stored object and implements behavior to access it.
DatabaseValueHolder() - Constructor for class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Default constructor.
dataClass - Variable in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
Field type
dataClassName - Variable in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
 
DataExpression - Class in org.eclipse.persistence.internal.expressions
Superclass for all expression that have a context.
DataExpression() - Constructor for class org.eclipse.persistence.internal.expressions.DataExpression
DataExpression constructor comment.
dataFormat - Variable in class org.eclipse.persistence.eis.EISDescriptor
Define the type of data the descriptor maps to.
DATALINK_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
dataModifications - Variable in class org.eclipse.persistence.internal.sessions.CommitManager
Map of modification events used to defer insertion into m-m, dc, join tables.
DataModify - Static variable in class org.eclipse.persistence.config.QueryType
 
DataModifyQuery - Class in org.eclipse.persistence.queries
Purpose: Concrete class used for executing non selecting SQL strings.
DataModifyQuery() - Constructor for class org.eclipse.persistence.queries.DataModifyQuery
 
DataModifyQuery(String) - Constructor for class org.eclipse.persistence.queries.DataModifyQuery
Warning: Allowing an unverified SQL string to be passed into this method makes your application vulnerable to SQL injection attacks.
DataModifyQuery(Call) - Constructor for class org.eclipse.persistence.queries.DataModifyQuery
 
DATAOBJECT_FROM_DIFFERENT_HELPERCONTEXT - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
dataObjectNotFromHelperContext() - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to marshal a dataobject from a different HelperContext
DataPartitioningCallback - Interface in org.eclipse.persistence.platform.database.partitioning
PUBLIC: Defines the API for the integration with an external DataSources data partitioning support.
DataRead - Static variable in class org.eclipse.persistence.config.QueryType
 
DataReadQuery - Class in org.eclipse.persistence.queries
Purpose: Concrete class to perform read using raw SQL.
DataReadQuery() - Constructor for class org.eclipse.persistence.queries.DataReadQuery
PUBLIC: Initialize the state of the query.
DataReadQuery(String) - Constructor for class org.eclipse.persistence.queries.DataReadQuery
PUBLIC: Initialize the query to use the specified SQL string.
DataReadQuery(Call) - Constructor for class org.eclipse.persistence.queries.DataReadQuery
PUBLIC: Initialize the query to use the specified call.
dataRecord - Variable in class org.eclipse.persistence.descriptors.DescriptorEvent
Optionally a database row may be provided on some events, (such as aboutToUpdate).
dataRecord - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
This is used for Document Preservation to cache the record that this object was built from
DataRecord - Interface in org.eclipse.persistence.sessions
This interface defines the public interface for the EclipseLink DatabaseRecord (was Record), and the other record types XMLRecord, EISRecord.
dataResults - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Stored all row results to -m joining.
dataResults - Variable in class org.eclipse.persistence.queries.BatchFetchPolicy
Stores temporary list of rows from parent batch query per batched mapping.
dataResultsByPrimaryKey - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Stored all row results to -m joining by cache key.
dataSource - Variable in class org.eclipse.persistence.sessions.JNDIConnector
 
DATASOURCE_LOOKUP_TYPE_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
DatasourceAccessor - Class in org.eclipse.persistence.internal.databaseaccess
INTERNAL: DatasourceAccessor is an abstract implementation of the Accessor interface providing common functionality to the concrete database and EIS accessors.
DatasourceAccessor() - Constructor for class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Default Constructor.
DatasourceCall - Class in org.eclipse.persistence.internal.databaseaccess
INTERNAL: Purpose: Used as an abstraction of a datasource invocation.
DatasourceCall() - Constructor for class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
DatasourceCall.ParameterType - Enum in org.eclipse.persistence.internal.databaseaccess
 
DatasourceCallQueryMechanism - Class in org.eclipse.persistence.internal.queries
Purpose: Mechanism used for call queries.
DatasourceCallQueryMechanism() - Constructor for class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
 
DatasourceCallQueryMechanism(DatabaseQuery) - Constructor for class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Initialize the state of the query
DatasourceCallQueryMechanism(DatabaseQuery, DatasourceCall) - Constructor for class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Initialize the state of the query
datasourceConnection - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Store the reference to the driver level connection.
datasourceLogin - Variable in class org.eclipse.persistence.sessions.Project
 
DatasourceLogin - Class in org.eclipse.persistence.sessions
Purpose: Hold the configuration information necessary to connect to a datasource.
DatasourceLogin() - Constructor for class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Create a new login.
DatasourceLogin(Platform) - Constructor for class org.eclipse.persistence.sessions.DatasourceLogin
ADVANCED: Create a new login for the given platform.
DatasourcePlatform - Class in org.eclipse.persistence.internal.databaseaccess
DatasourcePlatform is private to TopLink.
DatasourcePlatform() - Constructor for class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
dataType - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
dataType() - Method in annotation type org.eclipse.persistence.annotations.ObjectTypeConverter
(Optional) Specify the type stored on the database.
dataType() - Method in annotation type org.eclipse.persistence.annotations.TypeConverter
(Optional) Specify the type stored on the database.
datatypeFactory - Variable in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
dataTypeName - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
dataTypesConvertedFromAClass - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Store the list of Classes that can be converted to from the key.
dataTypesConvertedFromAClass - Variable in class org.eclipse.persistence.internal.helper.ConversionManager
Store the list of Classes that can be converted to from the key.
dataTypesConvertedToAClass - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Store the list of Classes that can be converted from to the key.
dataTypesConvertedToAClass - Variable in class org.eclipse.persistence.internal.helper.ConversionManager
Store the list of Classes that can be converted from to the key.
dataValue() - Method in annotation type org.eclipse.persistence.annotations.ConversionValue
(Required) Specify the database value.
date - Variable in class org.eclipse.persistence.logging.SessionLogEntry
 
DATE - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
DATE_FORMAT_STR - Static variable in class org.eclipse.persistence.logging.AbstractSessionLog
 
DATE_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
DATE_TIME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
DATE_TIME_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
DATE_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
DateConstantExpression - Class in org.eclipse.persistence.internal.expressions
INTERNAL: This expression represents a date represented in JDBC escape syntax, for instance, the String: {d '1901-01-01'} can be used to represent a Date and use used only by the JPQL parser.
DateConstantExpression() - Constructor for class org.eclipse.persistence.internal.expressions.DateConstantExpression
 
DateConstantExpression(Object, Expression) - Constructor for class org.eclipse.persistence.internal.expressions.DateConstantExpression
 
dateDifference() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
dateDifference(String, Date) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, Return the difference between the queried part of a date(i.e.
dateDifference(String, Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, Return the difference between the queried part of a date(i.e.
DateDifference - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
dateFormat - Variable in class org.eclipse.persistence.logging.AbstractSessionLog
Format use to print the current date/time.
dateFromCalendar(Calendar) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a sql.Date from a Calendar.
dateFromLong(Long) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Date from a long This implementation is based on the java.sql.Date class, not java.util.Date.
dateFromString(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Date from a string representation.
dateFromTimestamp(Timestamp) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Date from a timestamp This implementation is based on the java.sql.Date class, not java.util.Date.
dateFromYearMonthDate(int, int, int) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Date with the year, month, date.
dateName() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
dateName(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: return a string that represents the given part of a date.
DateName - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
datePart() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
datePart(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function return an integer which represents the requested part of the date.
DatePart - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
dateToString() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the date converted to the string value in the default database format.
dateToString() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
DateToString - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
dateToStringOperator() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Build MySQL equivalent to TO_CHAR.
dateToStringOperator() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Cloned from MySQLPlatform.java
DB2 - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
DB2Mainframe - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
DB2MainframePlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides DB2 Mainframe specific behavior.
DB2MainframePlatform() - Constructor for class org.eclipse.persistence.platform.database.DB2MainframePlatform
 
DB2Platform - Class in org.eclipse.persistence.platform.database
Purpose: Provides DB2 specific behavior.
DB2Platform() - Constructor for class org.eclipse.persistence.platform.database.DB2Platform
 
DB2ZPlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides DB2 z/OS specific behavior.
DB2ZPlatform() - Constructor for class org.eclipse.persistence.platform.database.DB2ZPlatform
 
DBase - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
DBasePlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides DBase specific behavior.
DBasePlatform() - Constructor for class org.eclipse.persistence.platform.database.DBasePlatform
Default constructor.
dbltab - Static variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
dbplatform - Variable in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
DBPlatformHelper - Class in org.eclipse.persistence.internal.helper
 
DBPlatformHelper() - Constructor for class org.eclipse.persistence.internal.helper.DBPlatformHelper
 
DBWS - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
DBWSException - Exception in org.eclipse.persistence.exceptions
PUBLIC: runtime exception for EclipseLink DBWS Service
DBWSException() - Constructor for exception org.eclipse.persistence.exceptions.DBWSException
 
DBWSException(String) - Constructor for exception org.eclipse.persistence.exceptions.DBWSException
 
DBWSException(String, Throwable) - Constructor for exception org.eclipse.persistence.exceptions.DBWSException
 
DBWSExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: Purpose:
DBWSExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.DBWSExceptionResource
Default constructor.
dcl - Variable in class org.eclipse.persistence.dynamic.DynamicEnumBuilder
 
DDL - org.eclipse.persistence.logging.LogCategory
 
DDL - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
DDL_BOTH_GENERATION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "both" specifies that DDL will be written to file(s) and the database.
DDL_DATABASE_GENERATION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "database" specifies that DDL will be written to the database.
DDL_GENERATION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.ddl-generation" property allows the database schema to be generated on deployment.
DDL_GENERATION_INDEX_FOREIGN_KEYS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.ddl-generation.index-foreign-keys" property specifies if an index should be automatically generated for foreign key constraints.
DDL_GENERATION_MODE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.ddl-generation.output-mode" property specifies if database schema should be generated on the database, to a file, or both.
DDL_SQL_SCRIPT_GENERATION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "sql-script" specifies that DDL will be written to file(s).
DEAD_CHECK_TIME - Static variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
deadCheckTime - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
DeadLockComponent - Class in org.eclipse.persistence.internal.helper.type
 
DeadLockComponent(Thread) - Constructor for class org.eclipse.persistence.internal.helper.type.DeadLockComponent
Constructor to be used when we start undoing our recursion due to having found a repeated thread that allows to conclude we have discovered our dead lock.
DeadLockComponent(Thread, boolean, boolean, boolean, ConcurrencyManager, boolean, boolean, DeadLockComponent) - Constructor for class org.eclipse.persistence.internal.helper.type.DeadLockComponent
Create a new DeadLockComponent.
deadLockFoundCreateConcurrencyManagerStateDeferredThreadCouldNotAcquireWriteLock(DeadLockComponent, Thread, ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
Create a deadlock component for a thread known to be stuck trying to release deferred locks.
deadLockFoundCreateConcurrencyManagerStateReaderThreadCouldNotAcquireWriteLock(DeadLockComponent, Thread, ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
Dto component participating in a dead lock.
deadLockFoundCreateConcurrencyManagerStateWriterThreadCouldNotAcquireWriteLock(DeadLockComponent, Thread, ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
Create a dead lock dto component.
Death - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
Dec - org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
DECIMAL - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
DECIMAL_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
DECIMAL_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
declaredType - Variable in class org.eclipse.persistence.internal.oxm.Root
 
declareTarget(StringBuilder, PLSQLargument, DatabaseType) - Method in enum org.eclipse.persistence.internal.helper.DatabaseType.DatabaseTypeHelper
 
decode() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
decode(Map, String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function Convert values returned by the query to values given in the decodeableItems Map.
Decode - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
decrementCallCount() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Decrement the number of calls in progress.
decrementCallCount() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Used for load balancing and external pooling.
decrementDatabaseCount(Object) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
Decrement the count for object
decrementDepth() - Method in class org.eclipse.persistence.internal.helper.DeferredLockManager
decrement the depth of the thread
decrypt(String) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Security method called by the children classes
decryptPassword(String) - Method in class org.eclipse.persistence.internal.security.JCEEncryptor
Decrypts a string.
decryptPassword(String) - Method in interface org.eclipse.persistence.internal.security.Securable
 
deepClone() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Clone the query, including its selection criteria.
deepClone() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Clone the query, including its selection criteria.
deepMergeClone(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Merge the attributes of the clone into the unit of work copy.
deepMergeClone(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Merge the attributes of the clone into the unit of work copy.
deepRevertObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Revert the object's attributes from the parent.
deepRevertObject(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Revert the object's attributes from the parent.
deepUnregisterObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Unregister the object with the unit of work.
deepUnregisterObject(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Unregister the object with the unit of work.
DEFAULT - Static variable in class org.eclipse.persistence.config.BatchWriting
 
DEFAULT - Static variable in class org.eclipse.persistence.config.CacheType
The default cache type is SoftWeak.
DEFAULT - Static variable in class org.eclipse.persistence.config.CacheUsage
 
DEFAULT - Static variable in class org.eclipse.persistence.config.CacheUsageIndirectionPolicy
The default type is Exception.
DEFAULT - Static variable in class org.eclipse.persistence.config.CascadePolicy
 
DEFAULT - Static variable in class org.eclipse.persistence.config.CommitOrderType
 
DEFAULT - Static variable in class org.eclipse.persistence.config.ExclusiveConnectionMode
 
DEFAULT - Static variable in class org.eclipse.persistence.config.FlushClearCache
 
DEFAULT - Static variable in class org.eclipse.persistence.config.LoggerType
 
DEFAULT - Static variable in class org.eclipse.persistence.config.ParameterDelimiterType
 
DEFAULT - Static variable in class org.eclipse.persistence.config.ParserType
 
DEFAULT - Static variable in class org.eclipse.persistence.config.ParserValidationType
 
DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Default Suffix could be appended to some prefixes to form a property name setting the default for the persistence unit.
DEFAULT - Static variable in class org.eclipse.persistence.config.PessimisticLock
 
DEFAULT - Static variable in class org.eclipse.persistence.config.ProfilerType
 
DEFAULT - Static variable in class org.eclipse.persistence.config.QueryType
 
DEFAULT - Static variable in class org.eclipse.persistence.config.ResultSetConcurrency
The default type is Updatable.
DEFAULT - Static variable in class org.eclipse.persistence.config.ResultSetType
The default type is ScrollInsensitive.
DEFAULT - Static variable in class org.eclipse.persistence.config.ResultType
The default type is Array.
DEFAULT - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
DEFAULT - Static variable in class org.eclipse.persistence.config.TargetServer
 
DEFAULT() - Constructor for class org.eclipse.persistence.oxm.annotations.XmlVariableNode.DEFAULT
 
DEFAULT_ANNOUNCEMENT_DELAY - Static variable in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
 
DEFAULT_APP_LOCATION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The default location in the file system to output DDL files.
DEFAULT_ASYNCHRONOUS_MODE - Static variable in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
DEFAULT_ATTRIBUTE_GROUP - Static variable in interface org.eclipse.persistence.internal.oxm.record.XMLRecord
 
DEFAULT_CALLBACK_NAME - Static variable in class org.eclipse.persistence.oxm.JSONWithPadding
 
DEFAULT_CDI_INJECTION_MANAGER - Static variable in interface org.eclipse.persistence.internal.sessions.cdi.InjectionManager
 
DEFAULT_CHANNEL - Static variable in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
DEFAULT_CHAR_SIZE - Static variable in class org.eclipse.persistence.platform.database.PervasivePlatform
 
DEFAULT_CHARSET - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
DEFAULT_CONCURRENCY_MANAGER_OBJECT_BUILDING_NO_THREADS - Static variable in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
DEFAULT_CONCURRENCY_MANAGER_WRITE_LOCK_MANAGER_ACQUIRE_REQUIRED_LOCKS_NO_THREADS - Static variable in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
DEFAULT_CONCURRENCY_SEMAPHORE_LOG_TIMEOUT - Static variable in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
DEFAULT_CONCURRENCY_SEMAPHORE_MAX_TIME_PERMIT - Static variable in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
DEFAULT_CONNECTION_FACTORY - Static variable in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
 
DEFAULT_CONTEXT_FACTORY - Static variable in class org.eclipse.persistence.sessions.coordination.TransportManager
Default JNDI properties for remote access
DEFAULT_CREATE_JDBC_FILE_NAME - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The default name of the DDL file which is used to create database tables.
DEFAULT_DATABASE_DELIMITER - Static variable in class org.eclipse.persistence.internal.helper.Helper
 
DEFAULT_DDL_GENERATION_MODE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The eclipselink.ddl-generation.output-mode parameter is configured to the default value of database.
DEFAULT_DEDICATED_CONNECTION_KEY - Static variable in class org.eclipse.persistence.sessions.coordination.TransportManager
 
DEFAULT_DEDICATED_CONNECTION_VALUE - Static variable in class org.eclipse.persistence.sessions.coordination.TransportManager
 
DEFAULT_DROP_JDBC_FILE_NAME - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The default name of the DDL file which is used to drop database tables.
DEFAULT_IDENTITY_GENERATOR - Static variable in class org.eclipse.persistence.tools.schemaframework.TableCreator
Default identity generator sequence name.
DEFAULT_IIOP_URL_PORT - Static variable in class org.eclipse.persistence.sessions.coordination.TransportManager
 
DEFAULT_IIOP_URL_PROTOCOL - Static variable in class org.eclipse.persistence.sessions.coordination.TransportManager
 
DEFAULT_LOCK_MODE - Static variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
 
DEFAULT_MAX_BATCH_WRITING_SIZE - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Bug#3214927 The default is 32000 for DynamicSQLBatchWritingMechanism.
DEFAULT_MULTICAST_GROUP - Static variable in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
Default value constants
DEFAULT_MULTICAST_PORT - Static variable in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
 
DEFAULT_NAMING_SERVICE - Static variable in class org.eclipse.persistence.sessions.coordination.TransportManager
 
DEFAULT_PACKET_TIME_TO_LIVE - Static variable in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
 
DEFAULT_PARAMETERIZED_MAX_BATCH_WRITING_SIZE - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
DEFAULT_POOL - Static variable in class org.eclipse.persistence.sessions.server.ServerSession
 
DEFAULT_REMOVE_CONNECTION_ON_ERROR_MODE - Static variable in class org.eclipse.persistence.sessions.coordination.TransportManager
 
DEFAULT_RESOURCE_NAME - Static variable in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
 
DEFAULT_RESOURCE_NAME_IN_META_INF - Static variable in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
 
DEFAULT_ROOT_ELEMENT_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
DEFAULT_SEQUENCE_NAME_ALREADY_USED_BY_SEQUENCE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
DEFAULT_SERVER_NAME_AND_VERSION - Static variable in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: Answer "unknown" as a default for platforms that do not implement getModuleName()
DEFAULT_TOPIC - Static variable in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
 
DEFAULT_TOPLINK_NAMESPACE - Static variable in class org.eclipse.persistence.logging.JavaLog
 
DEFAULT_UNMAPPED_CONTENT_HANDLER - Static variable in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
DEFAULT_URL_PORT - Static variable in class org.eclipse.persistence.sessions.coordination.TransportManager
 
DEFAULT_URL_PROTOCOL - Static variable in class org.eclipse.persistence.sessions.coordination.TransportManager
Defaults for RMI applications
DEFAULT_USE_SEMAPHORE_TO_SLOW_DOWN_OBJECT_BUILDING_CONCURRENCY - Static variable in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
DEFAULT_USE_SEMAPHORE_TO_SLOW_DOWN_WRITE_LOCK_MANAGER_ACQUIRE_REQUIRED_LOCKS - Static variable in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
DEFAULT_USER_NAME - Static variable in class org.eclipse.persistence.sessions.coordination.TransportManager
 
DEFAULT_VARCHAR_SIZE - Static variable in class org.eclipse.persistence.platform.database.DatabasePlatform
 
DEFAULT_XML_CONVERSION_TIME_SUFFIX - Static variable in class org.eclipse.persistence.internal.oxm.OXMSystemProperties
 
DEFAULT_XML_ENCODING - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
DEFAULT_XML_TYPE_ATTRIBUTE - Static variable in class org.eclipse.persistence.oxm.XMLConstants
 
DEFAULT_XML_VERSION - Static variable in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
defaultAttributeValue - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
defaultAttributeValueString - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
defaultBuilder - Variable in class org.eclipse.persistence.queries.ModifyAllQuery
Provide a default builder so that it's easier to be consistent
defaultBuilder - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Provide a default builder so that it's easier to be consistent
defaultCacheIsolation - Variable in class org.eclipse.persistence.sessions.Project
Default value for ClassDescriptor.isIsolated.
defaultConnectionPolicy - Variable in class org.eclipse.persistence.sessions.server.ServerSession
 
defaultConnectionPool - Variable in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
The default connection pool is used for any unmapped values.
defaultConnectionPool() - Method in annotation type org.eclipse.persistence.annotations.ValuePartitioning
The default connection pool is used for any unmapped values.
DefaultConnector - Class in org.eclipse.persistence.sessions
Purpose:Use this Connector to build a java.sql.Connection in the "standard" fashion, via the DriverManager.
DefaultConnector() - Constructor for class org.eclipse.persistence.sessions.DefaultConnector
PUBLIC: Construct a Connector with default settings The database URL will still need to be set.
DefaultConnector(String, String, String) - Constructor for class org.eclipse.persistence.sessions.DefaultConnector
PUBLIC: Construct a Connector with the specified settings.
defaultContainerClass - Static variable in class org.eclipse.persistence.internal.queries.ContainerPolicy
Allow the default collection class to be set.
defaultContainerSize - Static variable in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
 
defaultDeleteObjectQueryRedirector - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultDeleteObjectQueryRedirectorClassName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
DefaultErrorHandler - Class in org.eclipse.persistence.platform.xml
INTERNAL: A default implementation of ErrorHandler that simply rethrows the SAXParseExceptions.
defaultEventListeners - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
defaultIdentityMapClass - Variable in class org.eclipse.persistence.sessions.Project
Default value for ClassDescriptor.identityMapClass.
defaultIdentityMapSize - Variable in class org.eclipse.persistence.sessions.Project
Default value for ClassDescriptor.identityMapSize.
defaultIdValidation - Variable in class org.eclipse.persistence.sessions.Project
Default value for ClassDescriptor.idValidation.
defaultInsertObjectQueryRedirector - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultInsertObjectQueryRedirectorClassName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultJavaTypes - Static variable in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
defaultLog - Static variable in class org.eclipse.persistence.logging.AbstractSessionLog
Represents the singleton SessionLog
DefaultLogger - Static variable in class org.eclipse.persistence.config.LoggerType
 
defaultManager - Static variable in class org.eclipse.persistence.internal.helper.ConversionManager
 
defaultManager - Static variable in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Store the default instance.
defaultNamespaceDeclaration(String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
defaultNamespaceDeclaration(String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
defaultNamespaceDeclaration(String) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Add the defaultNamespace declaration
defaultNamespaceDeclaration(String) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
defaultNativeSequenceToTable - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
If the native sequence type is not supported, if table sequencing should be used.
defaultNullValues - Variable in class org.eclipse.persistence.internal.helper.ConversionManager
 
defaultObjectValue() - Method in annotation type org.eclipse.persistence.annotations.ObjectTypeConverter
(Optional) Specify a default object value.
defaultQueryRedirector - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultQueryRedirectorClassName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultQueryResultsCachePolicy - Variable in class org.eclipse.persistence.sessions.Project
Default value for query caching options for all named queries.
defaultReadAllQueryRedirector - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultReadAllQueryRedirectorClassName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultReadObjectQueryRedirector - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultReadObjectQueryRedirectorClassName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultReadOnlyClasses - Variable in class org.eclipse.persistence.sessions.Project
Holds the default set of read-only classes that apply to each UnitOfWork.
defaultReferenceMode - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Stores the default reference mode that a UnitOfWork will use when referencing managed objects.
defaultReportQueryRedirector - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultReportQueryRedirectorClassName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultRootElementNotSpecified(Descriptor) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
defaultRootElementNotSpecified(XMLDescriptor) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
defaultSeqenceAtNextValue - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
If sequences should start at Next Value
defaultSequence - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Store default sequence
DefaultSequence - Class in org.eclipse.persistence.sequencing
Purpose: Reference to the default sequence.
DefaultSequence() - Constructor for class org.eclipse.persistence.sequencing.DefaultSequence
 
DefaultSequence(String) - Constructor for class org.eclipse.persistence.sequencing.DefaultSequence
Create a new sequence with the name.
DefaultSequence(String, int) - Constructor for class org.eclipse.persistence.sequencing.DefaultSequence
Create a new sequence with the name and sequence pre-allocation size.
DefaultSequence(String, int, int) - Constructor for class org.eclipse.persistence.sequencing.DefaultSequence
 
DefaultSequenceConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.sequencing
INTERNAL:
DefaultSequenceConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.sequencing.DefaultSequenceConfig
 
defaultSequenceNameAlreadyUsedBySequence(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
defaultSession - Variable in class org.eclipse.persistence.sessions.factories.SessionManager
 
DefaultSessionLog - Class in org.eclipse.persistence.logging
Purpose: Default log used for the session when message logging is enabled.
DefaultSessionLog() - Constructor for class org.eclipse.persistence.logging.DefaultSessionLog
 
DefaultSessionLog(Writer) - Constructor for class org.eclipse.persistence.logging.DefaultSessionLog
 
DefaultSessionLogConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.log
INTERNAL:
DefaultSessionLogConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.log.DefaultSessionLogConfig
 
defaultSize - Variable in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
defaultSourceTable - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Default source table that should be used with the default source fields of this mapping.
defaultSubSize - Variable in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
defaultTable - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultTableCreator - Variable in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
DefaultTableGenerator - Class in org.eclipse.persistence.tools.schemaframework
DefaultTableGenerator is a utility class used to generate a default table schema for a EclipseLink project object.
DefaultTableGenerator(Project) - Constructor for class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Default constructor
DefaultTableGenerator(Project, boolean) - Constructor for class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
This constructor will create a DefaultTableGenerator that can be set to create fk constraints
defaultTableName - Static variable in class org.eclipse.persistence.sequencing.TableSequence
Deprecated.
Use an empty string as a default sequence table name instead, that triggers usage of platform.getDefaultSequenceTableName() when the sequence is connected.
defaultTemporalMutable - Variable in class org.eclipse.persistence.sessions.Project
Define the default setting for configuring if dates and calendars are mutable.
DefaultTimeout - Static variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
DefaultTimeoutUnit - Static variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
defaultTimeZone - Static variable in class org.eclipse.persistence.internal.helper.Helper
PERF: Cache default timezone for calendar conversion.
defaultTransactionManager - Static variable in class org.eclipse.persistence.transaction.JTATransactionController
 
defaultTsr - Static variable in class org.eclipse.persistence.transaction.JTA11TransactionController
Allows TransactionSynchronizationRegistry to be set statically.
DefaultUnmappedContentHandler<UNMARSHAL_RECORD extends UnmarshalRecord> - Class in org.eclipse.persistence.internal.oxm.unmapped
Purpose:Provide a default implementation of the UnmappedContentHandler
DefaultUnmappedContentHandler - Class in org.eclipse.persistence.oxm.unmapped
Purpose:Provide a default implementation of the UnmappedContentHandler
DefaultUnmappedContentHandler() - Constructor for class org.eclipse.persistence.internal.oxm.unmapped.DefaultUnmappedContentHandler
 
DefaultUnmappedContentHandler() - Constructor for class org.eclipse.persistence.oxm.unmapped.DefaultUnmappedContentHandler
 
defaultUpdateObjectQueryRedirector - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultUpdateObjectQueryRedirectorClassName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
defaultWriter - Variable in class org.eclipse.persistence.dynamic.DynamicClassLoader
Default writer to use if one is not specified.
defaultXMLManager - Static variable in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
defaultXMLTypes - Static variable in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
deferEvent(DescriptorEvent) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Add an event to the deferred list.
DeferrableChangeRecord - Class in org.eclipse.persistence.internal.sessions
Abstract change record for collection type records that allow deferrable change detection.
DeferrableChangeRecord() - Constructor for class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
 
DeferrableChangeRecord(ObjectChangeSet) - Constructor for class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
 
DEFERRED - org.eclipse.persistence.annotations.ChangeTrackingType
A DEFERRED change tracking policy defers all change detection to the UnitOfWork's change detection process.
DEFERRED_LOCK_MANAGERS - Static variable in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
deferredCalls - Variable in class org.eclipse.persistence.internal.sessions.CommitManager
Map of deferred calls groups by their table.
DeferredChangeDetectionPolicy - Class in org.eclipse.persistence.descriptors.changetracking
PUBLIC: A DeferredChangeDetectionPolicy defers all change detection to the UnitOfWork's change detection process.
DeferredChangeDetectionPolicy() - Constructor for class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
 
deferredDetectionRequiredOn(String) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: This method is used during attribute level change tracking when a particular change was detected but that change can not be tracked (ie customer set entire collection in object).
deferredEvents - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
temporarily holds a list of events that must be fired after the current operation completes.
DeferredLockManager - Class in org.eclipse.persistence.internal.helper
INTERNAL:
DeferredLockManager() - Constructor for class org.eclipse.persistence.internal.helper.DeferredLockManager
DeferredLockManager constructor comment.
deferredLocks - Variable in class org.eclipse.persistence.internal.helper.DeferredLockManager
 
deferredModifyAllQueries - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Contains deferred ModifyAllQuery's that have translation row for execution only.
deferredSet - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
This is used during attribute level change tracking when a particular change was detected but that change can not be tracked (ie customer set entire collection in object).
defineDynamicClass(String, byte[]) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
Converts an array of bytes into an instance of class Class.
definitions - Variable in class org.eclipse.persistence.internal.codegen.HierarchyNode
This member will hold the different definition types that should be implemented by the code generated children Used mostly in CMP code generation
delayBetweenConnectionAttempts - Variable in class org.eclipse.persistence.sessions.DatabaseLogin
Stores the number of milliseconds that EclipseLink will wait between attempts to reconnect a DatabaseConnection in the case EclipseLink is attempting to retry a query.
delegate - Variable in class org.eclipse.persistence.indirection.IndirectList
Reduce type casting.
delegate - Variable in class org.eclipse.persistence.indirection.IndirectMap
Reduce type casting
delegateSequence - Variable in class org.eclipse.persistence.sequencing.NativeSequence
Allow sequencing to be delegated to another sequence if native sequencing is not supported.
delete() - Method in annotation type org.eclipse.persistence.annotations.QueryRedirectors
A Default Delete Object Query Redirector will be applied to any executing DeleteObjectQuery or DeleteAllQuery that does not have a redirector set directly on the query.
Delete - Static variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
Used for data modification events.
DELETE_ALL_QUERY_SPECIFIES_OBJECTS_BUT_NOT_SELECTION_CRITERIA - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
deleteAll() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
 
deleteAll() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
INTERNAL: Delete a collection of objects.
deleteAll(DeleteObjectQuery) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
Delete all the reference objects.
deleteAll(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
Delete all the reference objects.
deleteAll(DeleteObjectQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
To delete all the entries matching the selection criteria from the table stored in the referenced descriptor
deleteAll(DeleteObjectQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
Delete all the reference objects with a single query.
DeleteAll - Annotation Type in org.eclipse.persistence.annotations
A DeleteAll annotation is specified to indicate that when an relationship is deleted, it should use a delete all query.
DeleteAll - Static variable in class org.eclipse.persistence.config.QueryType
 
DeleteAll - Static variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
deleteAllObjects(Class<?>, List, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Delete all of the objects with the matching class.
deleteAllObjects(Collection) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: delete all of the objects and all of their privately owned parts in the database.
deleteAllObjects(Collection) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: delete all of the objects and all of their privately owned parts in the database.
deleteAllObjects(Collection) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Delete all of the objects and all of their privately owned parts in the database.
deleteAllObjects(List) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
delete all of the objects as a single transaction.
deleteAllQuery - Variable in class org.eclipse.persistence.mappings.CollectionMapping
Used for delete all in m-m, dc and delete all optimization in 1-m.
DeleteAllQuery - Class in org.eclipse.persistence.queries
Purpose: Query used to delete a collection of objects.
DeleteAllQuery() - Constructor for class org.eclipse.persistence.queries.DeleteAllQuery
PUBLIC:
DeleteAllQuery(Class<?>) - Constructor for class org.eclipse.persistence.queries.DeleteAllQuery
PUBLIC: Create a new delete all query for the class specified.
DeleteAllQuery(Class<?>, Expression) - Constructor for class org.eclipse.persistence.queries.DeleteAllQuery
PUBLIC: Create a new delete all query for the class and the selection criteria specified.
deleteAllQuerySpecifiesObjectsButNotSelectionCriteria(ClassDescriptor, DatabaseQuery, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
deleteAllUsingTempTables() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Execute deleteAll using temp tables
DeleteAtIndex - Static variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
deleteAtIndexQuery - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
Used (only in case listOrderField != null) to delete object with particular orderFieldValue
deletedObjects - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
 
deletedObjects - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
deletedPrivateOwnedObjects - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Stores all of the private owned objects that have been removed and may need to cascade deletion
deleteMapKey(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: For mappings used as MapKeys in MappedKeyContainerPolicy, Delete the passed object if necessary.
deleteMapKey(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: For mappings used as MapKeys in MappedKeyContainerPolicy, Delete the passed object if necessary.
deleteMapKey(Object, AbstractSession) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: For mappings used as MapKeys in MappedKeyContainerPolicy, Delete the passed object if necessary.
deleteMapKey(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: For mappings used as MapKeys in MappedKeyContainerPolicy, Delete the passed object if necessary.
deleteObject() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Delete an object This should be overridden by subclasses.
deleteObject() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
INTERNAL: Delete an object.
deleteObject() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
INTERNAL: delete the object
deleteObject(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Delete the object and all of its privately owned parts from the database.
deleteObject(Object) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Delete the object and all of its privately owned parts from the database.
deleteObject(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Delete the object and all of their privately owned parts in the database.
DeleteObjectQuery - Class in org.eclipse.persistence.queries
Purpose: Used for deleting objects.
DeleteObjectQuery() - Constructor for class org.eclipse.persistence.queries.DeleteObjectQuery
 
DeleteObjectQuery(Object) - Constructor for class org.eclipse.persistence.queries.DeleteObjectQuery
 
DeleteObjectQuery(Call) - Constructor for class org.eclipse.persistence.queries.DeleteObjectQuery
 
deleteQuery - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
deleteQuery - Variable in class org.eclipse.persistence.mappings.RelationTableMechanism
Query used for single row deletion.
deleteReferenceObjectsLeftOnDatabase(DeleteObjectQuery) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
This method will make sure that all the records privately owned by this mapping are actually removed.
deleteReferenceObjectsLeftOnDatabase(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
This method will make sure that all the records privately owned by this mapping are actually removed.
deleteSchema - Variable in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
 
deleteWrappedObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Delete the passed object This may be overridden by subclasses to deal with composite objects
deleteWrappedObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Delete the key and value of the passed association passed object.
deletionDependencies - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Used to store deleted objects that have reference to other deleted objects.
deletionStringFor(DatabaseAccessor) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Return the delete SQL string.
DEPLOY_FAILED - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
DEPLOY_ON_STARTUP - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.deploy-on-startup" property controls whether EclipseLink creates the persistence unit when the application starts up, or when the persistence unit is first actually accessed by the application.
deployFailed(String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
depth - Variable in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
depth - Variable in class org.eclipse.persistence.sequencing.Sequence
 
depth - Variable in class org.eclipse.persistence.sessions.CopyGroup
Policy depth that determines how the copy will cascade to the object's related parts
depthFirstSearch() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
 
Derby - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
DerbyPlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides Derby DBMS specific behavior.
DerbyPlatform() - Constructor for class org.eclipse.persistence.platform.database.DerbyPlatform
 
deref() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
Deref - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
DERIVED_ID_CIRCULAR_REFERENCE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
derivedExpressionNamed(String) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
derivedExpressions - Variable in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
derivedFields - Variable in class org.eclipse.persistence.internal.expressions.DataExpression
 
derivedIdMapping - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
The id mapping this mapping derives.
derivedManualExpressionNamed(String, ClassDescriptor) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
derivedTables - Variable in class org.eclipse.persistence.internal.expressions.DataExpression
 
derivesId - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
Used by the CMP3Policy to see if this mapping should be used in processing pk classes for find methods
derivesId() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: Returns true if the mapping references a JPA ID attribute for the CMP3Policy and JPA ID classes.
derivesIdMappings - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
descending() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This can only be used within an ordering expression.
descending() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the DESCENDING operator.
Descending - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
descendingOperator() - Method in class org.eclipse.persistence.platform.database.DB2Platform
Disable binding support.
describesNonPersistentSubclasses - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
descriptionOfNodeType() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Used in debug printing of this node.
descriptionOfNodeType() - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.DateConstantExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.FromAliasExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.LogicalExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.ManualQueryKeyExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
INTERNAL: Used in debug printing of this node.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.TableExpression
INTERNAL: Used for debug printing.
descriptionOfNodeType() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
descriptor - Variable in class org.eclipse.persistence.descriptors.CMPPolicy
 
descriptor - Variable in class org.eclipse.persistence.descriptors.copying.AbstractCopyPolicy
 
descriptor - Variable in class org.eclipse.persistence.descriptors.DescriptorEvent
 
descriptor - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
descriptor - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
descriptor - Variable in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
 
descriptor - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
descriptor - Variable in class org.eclipse.persistence.descriptors.InterfacePolicy
 
descriptor - Variable in class org.eclipse.persistence.descriptors.MethodClassExtractor
 
descriptor - Variable in class org.eclipse.persistence.descriptors.ReturningPolicy
owner of the policy
descriptor - Variable in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
 
descriptor - Variable in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
 
descriptor - Variable in class org.eclipse.persistence.descriptors.VersionLockingPolicy
 
descriptor - Variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
descriptor - Variable in class org.eclipse.persistence.history.HistoryPolicy
 
descriptor - Variable in class org.eclipse.persistence.internal.descriptors.AbstractSerializedObjectPolicy
 
descriptor - Variable in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
 
descriptor - Variable in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Backpointer to descriptor.
descriptor - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
descriptor - Variable in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
descriptor - Variable in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
descriptor - Variable in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
PERF: Store the descriptor to allow lastAccessed cache lookup optimization.
descriptor - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Stores the descriptor that these joins apply on
descriptor - Variable in class org.eclipse.persistence.internal.queries.ReportItem
Descriptor for object result that is not based on an expression
descriptor - Variable in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
descriptor - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Cache the descriptor as it is useful and required in some places.
descriptor - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
ClassDescriptor to which this mapping belongs to
descriptor - Variable in class org.eclipse.persistence.mappings.querykeys.QueryKey
 
descriptor - Variable in class org.eclipse.persistence.queries.DatabaseQuery
The descriptor cached on the prepare for object level queries.
Descriptor<ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CORE_MAPPING extends CoreMapping,​FIELD extends CoreField,​INHERITANCE_POLICY extends CoreInheritancePolicy,​INSTANTIATION_POLICY extends CoreInstantiationPolicy,​NAMESPACE_RESOLVER extends NamespaceResolver,​OBJECT_BUILDER extends CoreObjectBuilder,​TABLE extends CoreTable,​UNMARSHAL_RECORD extends UnmarshalRecord,​UNMARSHALLER extends Unmarshaller> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
DESCRIPTOR_CUSTOMIZER_ - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.descriptor.customizer." is a prefix for a property used to configure a DescriptorCustomizer.
DESCRIPTOR_FOR_INTERFACE_IS_MISSING - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
DESCRIPTOR_IS_MISSING - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
DESCRIPTOR_IS_MISSING - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
DESCRIPTOR_IS_MISSING_FOR_NAMED_QUERY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
DESCRIPTOR_MUST_NOT_BE_INITIALIZED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
DESCRIPTOR_NOT_FOUND_IN_PROJECT - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
DESCRIPTOR_PROPERTY - Static variable in interface org.eclipse.persistence.dynamic.DynamicType
Property name used to store the EntityTypeImpl on each descriptor in its ClassDescriptor.properties.
DescriptorCompare - Class in org.eclipse.persistence.internal.helper
INTERNAL: Use to sort vectors of strings.
DescriptorCompare() - Constructor for class org.eclipse.persistence.internal.helper.DescriptorCompare
Default constructor.
DescriptorCustomizer - Interface in org.eclipse.persistence.config
Customize a ClassDescriptor when the DescriptorCustomizer.customize(ClassDescriptor) method is called during the loading/population of the mappings.
descriptorCustomizerClassName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
JPA DescriptorCustomizer list stored here to preserve it when caching the project
DescriptorEvent - Class in org.eclipse.persistence.descriptors
Purpose: Encapsulate the information provided with descriptor events.
DescriptorEvent - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
DescriptorEvent(int, ObjectLevelModifyQuery) - Constructor for class org.eclipse.persistence.descriptors.DescriptorEvent
PUBLIC: Most events are trigger from queries, so this is a helper method.
DescriptorEvent(Object) - Constructor for class org.eclipse.persistence.descriptors.DescriptorEvent
PUBLIC: All events require a source object.
DescriptorEvent_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
DescriptorEventAdapter - Class in org.eclipse.persistence.descriptors
Purpose: Provides an empty implementation of DescriptorEventListener.
DescriptorEventAdapter() - Constructor for class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
descriptorEventHolders - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
DescriptorEventListener - Interface in org.eclipse.persistence.descriptors
Purpose: Used to support Java event listener event model on descriptors.
DescriptorEventManager - Class in org.eclipse.persistence.descriptors
Purpose: The event manager allows for a descriptor to specify that an object should be notified when a EclipseLink event occurs.
DescriptorEventManager() - Constructor for class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: Returns a new DescriptorEventManager for the specified ClassDescriptor.
DescriptorException - Exception in org.eclipse.persistence.exceptions
Purpose: This exception is used for any problem that is detected with a descriptor or mapping.
DescriptorException(String) - Constructor for exception org.eclipse.persistence.exceptions.DescriptorException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
DescriptorException(String, ClassDescriptor) - Constructor for exception org.eclipse.persistence.exceptions.DescriptorException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
DescriptorException(String, ClassDescriptor, Throwable) - Constructor for exception org.eclipse.persistence.exceptions.DescriptorException
 
DescriptorException(String, DatabaseMapping) - Constructor for exception org.eclipse.persistence.exceptions.DescriptorException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
DescriptorExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for DescriptorException messages.
DescriptorExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.DescriptorExceptionResource
Default constructor.
descriptorForInterfaceIsMissing(String) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
DescriptorHelper - Class in org.eclipse.persistence.internal.descriptors
Purpose: Define any useful static methods to manipulate with descriptors content.
descriptorIsAggregate() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Sets the descriptor to be an aggregate.
descriptorIsAggregateCollection() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Sets the descriptor to be part of an aggregate collection.
descriptorIsForInterface() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Sets the descriptor to be for an interface.
descriptorIsMissing(Class<?>, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
descriptorIsMissing(String, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
descriptorIsMissingForNamedQuery(Class<?>, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
descriptorIsNormal() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Sets the descriptor to be normal.
DescriptorIterator - Class in org.eclipse.persistence.internal.descriptors
This class provides a generic way of using the descriptor information to traverse an object graph.
DescriptorIterator() - Constructor for class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Construct a typical iterator: iterate over all the objects process the objects contained by "value holders"...
DescriptorIterator.CascadeCondition - Class in org.eclipse.persistence.internal.descriptors
 
DescriptorLevelDocumentPreservationPolicyConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.login
 
DescriptorLevelDocumentPreservationPolicyConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.login.DescriptorLevelDocumentPreservationPolicyConfig
Default constructor.
descriptorMethodNames - Variable in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
descriptorMustBeNotInitialized(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
descriptorNotFoundInProject(String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
DescriptorQueryManager - Class in org.eclipse.persistence.descriptors
Purpose: The query manager allows for the database operations that EclipseLink performs to be customized by the application.
DescriptorQueryManager() - Constructor for class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Initialize the state of the descriptor query manager
descriptors - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
PERF: cache descriptors from project.
descriptors - Variable in class org.eclipse.persistence.queries.DatabaseQuery
The list of descriptors this query deals with.
descriptors - Variable in class org.eclipse.persistence.sessions.Project
 
descriptorsByGlobalType - Variable in class org.eclipse.persistence.internal.oxm.Context.ContextState
 
descriptorsByQName - Variable in class org.eclipse.persistence.internal.oxm.Context.ContextState
 
descriptorsLock - Variable in class org.eclipse.persistence.sessions.Project
Ensures that only one thread at a time can add/remove descriptors
descriptorType - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
deserialize(byte[]) - Static method in class org.eclipse.persistence.internal.helper.SerializationHelper
Deserialize an object from a byte array
deserialize(InputStream) - Static method in class org.eclipse.persistence.internal.helper.SerializationHelper
Deserialze an object from an InputStream
deserialize(Object, Session) - Method in class org.eclipse.persistence.sessions.serializers.JavaSerializer
 
deserialize(Object, Session) - Method in class org.eclipse.persistence.sessions.serializers.JSONSerializer
 
deserialize(Object, Session) - Method in interface org.eclipse.persistence.sessions.serializers.Serializer
 
deserialize(Object, Session) - Method in class org.eclipse.persistence.sessions.serializers.XMLSerializer
 
destroy() - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Destroy current session manager instance.
destroyAllSessions() - Method in class org.eclipse.persistence.sessions.factories.SessionManager
INTERNAL: Destroy all sessions held onto by this manager.
destroySession(String) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
INTERNAL: Destroy the session defined by sessionName on this manager.
detach(Object) - Method in class org.eclipse.persistence.sessions.factories.SessionFactory
Build a detached copy using a one-off UnitOfWork.
detach(Collection) - Method in class org.eclipse.persistence.sessions.factories.SessionFactory
 
detectServerPlatform(AbstractSession) - Static method in class org.eclipse.persistence.platform.server.ServerPlatformUtils
 
determineIfReleaseDeferredLockAppearsToBeDeadLocked(ConcurrencyManager, long, DeferredLockManager, ReadLockManager, boolean) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Throw an interrupted exception if appears that eclipse link code is taking too long to release a deferred lock.
DevelopmentServices - Class in org.eclipse.persistence.services
Purpose: Provide a dynamic interface into the EclipseLink Identity Map Manager.
DevelopmentServices() - Constructor for class org.eclipse.persistence.services.DevelopmentServices
Default constructor
DevelopmentServices(Session) - Constructor for class org.eclipse.persistence.services.DevelopmentServices
Constructor
difference() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
difference(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function return a value which indicates how much difference there is between two expressions.
Difference - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
DIRECT_FIELD_NAME_NOT_SET - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
DIRECT_KEY_NOT_SET - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
DirectCollectionChangeRecord - Class in org.eclipse.persistence.internal.sessions
Purpose: This class holds the record of the changes made to a collection attribute of an object.
DirectCollectionChangeRecord - Interface in org.eclipse.persistence.sessions.changesets
Purpose: This interface defines the API for the ChangeRecord that holds the changes made to a direct collection attribute of an object.
DirectCollectionChangeRecord() - Constructor for class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
This default constructor.
DirectCollectionChangeRecord(ObjectChangeSet) - Constructor for class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
This constructor returns a changeRecord representing the DirectCollection mapping.
DirectCollectionChangeRecord.NULL - Class in org.eclipse.persistence.internal.sessions
 
DirectCollectionMapping - Class in org.eclipse.persistence.mappings
Purpose: This mapping is used to store a collection of simple types (String, Number, Date, etc.) into a single table.
DirectCollectionMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​CONVERTER extends CoreConverter,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​SESSION extends CoreSession,​UNMARSHALLER extends Unmarshaller,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
DirectCollectionMapping() - Constructor for class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Default constructor.
DirectCollectionQueryKey - Class in org.eclipse.persistence.mappings.querykeys
Purpose:Represents a direct collection join query.
DirectCollectionQueryKey() - Constructor for class org.eclipse.persistence.mappings.querykeys.DirectCollectionQueryKey
 
directConnect(Properties) - Method in class org.eclipse.persistence.sessions.DefaultConnector
INTERNAL: Connect directly - without using DriverManager.
DirectConnector - Class in org.eclipse.persistence.sessions
Purpose:Use this Connector to build a java.sql.Connection by directly instantiating the Driver, as opposed to using the DriverManager.
DirectConnector() - Constructor for class org.eclipse.persistence.sessions.DirectConnector
PUBLIC: Construct a Connector with default settings (Sun JDBC-ODBC bridge).
DirectConnector(String, String, String) - Constructor for class org.eclipse.persistence.sessions.DirectConnector
PUBLIC: Construct a Connector with the specified settings.
DirectConnector_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
directField - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
The direct field name is converted and stored
directFieldNameNotSet(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
direction - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
direction - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
direction - Variable in class org.eclipse.persistence.queries.ReadAllQuery
 
direction() - Method in annotation type org.eclipse.persistence.annotations.StoredProcedureParameter
Deprecated. 
direction() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLParameter
(Optional) The direction of the stored procedure parameter.
Direction - Enum in org.eclipse.persistence.annotations
An enum that is used within the StoredProcedureParameter annotation.
directKeyNotSet(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
DirectMapChangeRecord - Class in org.eclipse.persistence.internal.sessions
Change record used by DirectMapMapping.
DirectMapChangeRecord() - Constructor for class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
 
DirectMapChangeRecord(ObjectChangeSet) - Constructor for class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
 
DirectMapMapping - Class in org.eclipse.persistence.mappings
Mapping for a collection of key-value pairs.
DirectMapMapping() - Constructor for class org.eclipse.persistence.mappings.DirectMapMapping
DirectMapCollectionMapping constructor
DirectMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​CONVERTER extends CoreConverter,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​SESSION extends CoreSession,​UNMARSHALLER extends Unmarshaller,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
directMarshal(Field, AbstractMarshalRecord, Object) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
INTERNAL
directMarshal(Field, AbstractMarshalRecord, Object) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
INTERNAL
directMarshal(XPathFragment, MarshalRecord, Object, CoreSession, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
INTERNAL: When using the SAX or DOM Platform, this method is responsible for marshalling null values for the XML Direct Mapping.
directMarshal(XPathFragment, MarshalRecord, Object, CoreSession, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
 
directoryIsSubdirectory(File, File) - Static method in class org.eclipse.persistence.tools.PackageRenamer
Return true if directory2 is contained within directory1.
DirectQueryKey - Class in org.eclipse.persistence.mappings.querykeys
Purpose: Define an alias to a database field.
DirectQueryKey() - Constructor for class org.eclipse.persistence.mappings.querykeys.DirectQueryKey
 
DirectRead - Static variable in class org.eclipse.persistence.config.QueryType
 
DirectReadQuery - Class in org.eclipse.persistence.queries
Purpose: Concrete class to perform a direct read.
DirectReadQuery() - Constructor for class org.eclipse.persistence.queries.DirectReadQuery
PUBLIC: Initialize the state of the query.
DirectReadQuery(String) - Constructor for class org.eclipse.persistence.queries.DirectReadQuery
PUBLIC: Initialize the query to use the specified SQL string.
DirectReadQuery(Call) - Constructor for class org.eclipse.persistence.queries.DirectReadQuery
PUBLIC: Initialize the query to use the specified call.
DirectToFieldChangeRecord - Class in org.eclipse.persistence.internal.sessions
Purpose: To record the changes for attributes that can be represented as DirectToField
DirectToFieldChangeRecord - Interface in org.eclipse.persistence.sessions.changesets
Purpose: This interface provides public API to the class responsible for holding the change made to a directToFieldMapping.
DirectToFieldChangeRecord() - Constructor for class org.eclipse.persistence.internal.sessions.DirectToFieldChangeRecord
This default constructor.
DirectToFieldChangeRecord(ObjectChangeSet) - Constructor for class org.eclipse.persistence.internal.sessions.DirectToFieldChangeRecord
This constructor returns a changeRecord representing the DirectToField mapping.
DirectToFieldMapping - Class in org.eclipse.persistence.mappings
Purpose: Maps an attribute to the corresponding database field type.
DirectToFieldMapping() - Constructor for class org.eclipse.persistence.mappings.DirectToFieldMapping
Default constructor.
DirectToXMLTypeMapping - Class in org.eclipse.persistence.mappings.xdb
Purpose: Mapping used to map from a DOM (org.w3c.Document) or XML String into an Oracle XMLType field, in Oracle 9i XDB.
DirectToXMLTypeMapping() - Constructor for class org.eclipse.persistence.mappings.xdb.DirectToXMLTypeMapping
 
DirectToXMLTypeMappingHelper - Class in org.eclipse.persistence.internal.sessions.factories
Helper class to abstract the XML mapping for DirectToXMLType.
DirectToXMLTypeMappingHelper() - Constructor for class org.eclipse.persistence.internal.sessions.factories.DirectToXMLTypeMappingHelper
 
dirtyUOWChangeSet() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
DISABLE_SECURE_PROCESSING - Static variable in class org.eclipse.persistence.internal.oxm.OXMSystemProperties
 
disableAllBindingExpression() - Static method in class org.eclipse.persistence.platform.database.DB2Platform
Create an ExpressionOperator that disables all parameter binding
disableAtLeast1BindingExpression() - Static method in class org.eclipse.persistence.platform.database.DB2Platform
Create an ExpressionOperator that requires at least 1 typed argument
disableCacheHits() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Allow for cache hits on primary key read object queries to be disabled.
disableCacheHitsOnRemote() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Allow for remote session cache hits on primary key read object queries to be disabled.
disableConversion - Variable in class org.eclipse.persistence.mappings.converters.ConverterClass
 
DisabledInjectionManager<T> - Class in org.eclipse.persistence.internal.sessions.cdi
 
DisabledInjectionManager() - Constructor for class org.eclipse.persistence.internal.sessions.cdi.DisabledInjectionManager
 
disableForeignKey - Variable in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
disableForeignKey() - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
disableHits() - Method in annotation type org.eclipse.persistence.annotations.Cache
(Optional) Setting to true will force all queries to bypass the cache for hits but still resolve against the cache for identity.
disableJTA() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: disableJTA(): Configure the receiver such that my external transaction controller class will be ignored, and will NOT be used to populate DatabaseSession's external transaction controller class at runtime.
disableJTA() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: disableJTA(): Configure the receiver such that my external transaction controller class will be ignored, and will NOT be used to populate DatabaseSession's external transaction controller class at runtime.
disableRuntimeServices() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: disableRuntimeServices(): Configure the receiver such that no JMX/MBean will be registered to provide runtime services for my DatabaseSession at runtime.
disableRuntimeServices() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: disableRuntimeServices(): Configure the receiver such that no JMX/MBean will be registered to provide runtime services for my DatabaseSession at runtime.
discardConnections() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Remove all remote connections for its list and the local connection from JNDI or JMS Subsriber
disconnect() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Disconnect the accessor only.
disconnect() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Disconnect not required.
disconnect() - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Disconnect the accessor only.
disconnect(Accessor) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Disconnect the accessor only (this must be the write connection as the read is shared).
disconnect(AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Disconnect from the data store.
disconnect(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Disconnect from the datasource.
disconnect(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Disconnect from the datasource.
Disconnects - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
discoverAllUnregisteredNewObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Search for any objects in the parent that have not been registered.
discoverAllUnregisteredNewObjectsInParent() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Search for any objects in the parent that have not been registered.
discoverAndPersistUnregisteredNewObjects(Object, boolean, Map, Map, Map, Set) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Discover any new objects referenced from registered objects and persist them.
discoverUnregisteredNewObjects(Map, Map, Map, Map) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Traverse the object to find references to objects not registered in this unit of work.
discoverUnregisteredNewObjects(Map, Map, Map, Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Traverse the object to find references to objects not registered in this unit of work.
discoverUnregisteredNewObjectsWithoutPersist - Variable in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
Alters the behaviour of the RWUOW commit to function like the UOW with respect to Entity lifecycle
DiscoveryConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.transport.discovery
INTERNAL:
DiscoveryConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.transport.discovery.DiscoveryConfig
 
DiscoveryException - Exception in org.eclipse.persistence.exceptions
Instances of this exception are raised if a problem is detected during the discovery of a TopLink cluster.
DiscoveryException() - Constructor for exception org.eclipse.persistence.exceptions.DiscoveryException
 
DiscoveryException(String) - Constructor for exception org.eclipse.persistence.exceptions.DiscoveryException
 
DiscoveryExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for ConcurrencyException messages.
DiscoveryExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.DiscoveryExceptionResource
Default constructor.
discoveryManager - Variable in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
Manages the detection of new services as they join the cluster
DiscoveryManager - Class in org.eclipse.persistence.sessions.coordination
Purpose: Detects new members of a logical EclipseLink cluster.
DiscoveryManager(String, int, int, RemoteCommandManager) - Constructor for class org.eclipse.persistence.sessions.coordination.DiscoveryManager
 
DiscoveryManager(String, int, RemoteCommandManager) - Constructor for class org.eclipse.persistence.sessions.coordination.DiscoveryManager
 
DiscoveryManager(RemoteCommandManager) - Constructor for class org.eclipse.persistence.sessions.coordination.DiscoveryManager
Constructors to create a discovery manager.
discoveryTime - Variable in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
discriminator() - Method in annotation type org.eclipse.persistence.annotations.DiscriminatorClass
(Required) The discriminator to be stored on the database.
DISCRIMINATOR_COLUMN_NOT_SELECTED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
DiscriminatorClass - Annotation Type in org.eclipse.persistence.annotations
A DiscriminatorClass is used within a VariableOneToOne annotation.
discriminatorClasses() - Method in annotation type org.eclipse.persistence.annotations.VariableOneToOne
(Optional) The list of discriminator types that can be used with this VariableOneToOne.
discriminatorColumn - Variable in class org.eclipse.persistence.queries.EntityResult
Stores the column that will contain the value to determine the correct subclass to create if applicable.
discriminatorColumn() - Method in annotation type org.eclipse.persistence.annotations.VariableOneToOne
(Optional) The discriminator column will hold the type indicators.
discriminatorColumnNotSelected(String, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
discriminatorType() - Method in annotation type org.eclipse.persistence.annotations.TenantDiscriminatorColumn
(Optional) The type of object/column to use as a class discriminator.
displayString - Variable in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
 
dissableEventProcessing(Object) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: This method is used to disable changetracking temporarily
dissableEventProcessing(Object) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: This method is used to disable changetracking temporarily
dissableEventProcessing(Object) - Method in class org.eclipse.persistence.descriptors.changetracking.ObjectChangeTrackingPolicy
INTERNAL: This method is used to disable changetracking temporarily
distinct() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, This represents the distinct option inside an aggregate function.
distinct() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the DISTINCT operator.
distinct() - Method in class org.eclipse.persistence.platform.database.DB2Platform
Disable binding support.
Distinct - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
DISTINCT_COUNT_ON_OUTER_JOINED_COMPOSITE_PK - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
DISTINCT_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
distinctCountOnOuterJoinedCompositePK(ClassDescriptor, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
distinctOperator() - Method in class org.eclipse.persistence.platform.database.Informix11Platform
Fixes EclipseLink bug 402600 by making sure that the Distinct ExpressionOperator is set to print as DISTINCT&nbsp; (no parentheses, one trailing space), and fixes
distinctState - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Used for "Select Distinct" option.
distinctState - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Indicates if distinct should be used or not.
DistributedMerge - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
DistributedSession - Class in org.eclipse.persistence.sessions.remote
Purpose: Super class to all remote client session's.
DistributedSession(int) - Constructor for class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Create a blank session, used for proxy session.
DistributedSession(RemoteConnection) - Constructor for class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Creates a DistributedSession.
DistributedSessionIdentityMapAccessor - Class in org.eclipse.persistence.internal.sessions
INTERNAL: Subclass of IdentityMapAccessor for distributed sessions Overrides some IdentityMapInitialization code
DistributedSessionIdentityMapAccessor(AbstractSession, IdentityMapManager) - Constructor for class org.eclipse.persistence.internal.sessions.DistributedSessionIdentityMapAccessor
 
divide() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the DISTINCT operator.
divide(Expression, int) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
divide(Expression, Object) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Divide - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
divideOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
DMS - org.eclipse.persistence.logging.LogCategory
 
DMS - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
DMSLocalization - Class in org.eclipse.persistence.internal.localization
Purpose: This is for DMS related messages
DMSLocalization() - Constructor for class org.eclipse.persistence.internal.localization.DMSLocalization
 
DMSProfiler - Static variable in class org.eclipse.persistence.config.ProfilerType
 
DMSProfilerClassName - Static variable in class org.eclipse.persistence.config.ProfilerType
 
DO_NOT_PROCESS_XTOMANY_FOR_QBE - Static variable in class org.eclipse.persistence.config.SystemProperties
This property can be set to disable processing of X-Many relationship attributes for Query By Example objects.
DO_NOT_SEND_CHANGES - Static variable in class org.eclipse.persistence.descriptors.CachePolicy
 
DO_NOT_SEND_CHANGES - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
DO_NOT_THROW_CONFORM_EXCEPTIONS - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Used for Conforming Queries
doctTypeId40 - Static variable in class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
 
doctTypeId45 - Static variable in class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
 
doctTypeId904 - Static variable in class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
 
document - Variable in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
DOCUMENT - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
DocumentPreservationPolicy - Class in org.eclipse.persistence.oxm.documentpreservation
Purpose:Provides an interface for customizing how Documents are preserved.
DocumentPreservationPolicy() - Constructor for class org.eclipse.persistence.oxm.documentpreservation.DocumentPreservationPolicy
Default constructor.
DocumentPreservationPolicyConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.login
 
DocumentPreservationPolicyConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.login.DocumentPreservationPolicyConfig
Default constructor.
doesAnyOfLeftValuesConform(Vector, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
Conform in-memory the collection of left values with the right value for this expression.
doesConform(Object, AbstractSession, AbstractRecord, int) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Check if the object conforms to the expression in memory.
doesConform(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: New parameter added to doesConform for feature 2612601
doesConform(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Check if the object conforms to the expression in memory.
doesConform(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.internal.expressions.LogicalExpression
INTERNAL: Check if the object conforms to the expression in memory.
doesConform(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
INTERNAL: Check if the object conforms to the expression in memory.
DoesExist() - Constructor for class org.eclipse.persistence.internal.sessions.remote.SequencingFunctionCall.DoesExist
 
doesExistQuery - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
DoesExistQuery - Class in org.eclipse.persistence.queries
Purpose: This should only be used by the descriptor, this should not be executed directly.
DoesExistQuery() - Constructor for class org.eclipse.persistence.queries.DoesExistQuery
PUBLIC: Initialize the state of the query .
DoesExistQuery(Object) - Constructor for class org.eclipse.persistence.queries.DoesExistQuery
PUBLIC: Create a query to check if the object exists.
DoesExistQuery(Call) - Constructor for class org.eclipse.persistence.queries.DoesExistQuery
PUBLIC: Create a query to check if the object exists.
doesFileExist(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Returns true if the file of this name does indeed exist
doesNotRepresentAnObjectInTheQuery() - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: There are cases (which we might want to eliminate?) where the expression builder doesn't actually correspond to an object to be read.
doesObjectConform(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
INTERNAL: Check if the object conforms to the expression in memory.
doesObjectExist(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if the object exists on the database or not.
doesObjectExist(Object) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if the object exists on the database or not.
doesRelationConform(Object, Object) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Compare the values in memory.
domainClass - Variable in class org.eclipse.persistence.tools.profiler.Profile
 
DOMInputSource - Class in org.eclipse.persistence.internal.oxm.record
 
DOMInputSource(Node) - Constructor for class org.eclipse.persistence.internal.oxm.record.DOMInputSource
 
domMethod - Static variable in class org.eclipse.persistence.eis.EISDOMRecord
Used for introspected DOM records.
domMethod - Variable in class org.eclipse.persistence.eis.EISPlatform
Used to reflectively provide XML record support as DOMRecord is not part of the JCA-CCI spec.
DOMPlatform - Class in org.eclipse.persistence.oxm.platform
INTERNAL:
DOMPlatform() - Constructor for class org.eclipse.persistence.oxm.platform.DOMPlatform
 
DOMReader - Class in org.eclipse.persistence.internal.oxm.record
INTERNAL:
DOMReader() - Constructor for class org.eclipse.persistence.internal.oxm.record.DOMReader
 
DOMReader(Unmarshaller) - Constructor for class org.eclipse.persistence.internal.oxm.record.DOMReader
 
DOMReader.IndexedAttributeList - Class in org.eclipse.persistence.internal.oxm.record
Implementation of Attributes - used to pass along a given node's attributes to the startElement method of the reader's content handler.
DOMReader.LocatorImpl - Class in org.eclipse.persistence.internal.oxm.record
 
DOMRecord - Class in org.eclipse.persistence.oxm.record
PUBLIC: Provides a Record/Map API on an XML DOM element.
DOMRecord - Interface in org.eclipse.persistence.eis
DOMRecord is an extension of the JCA Record interface that provides support for XML data.
DOMRecord() - Constructor for class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Default constructor.
DOMRecord(String) - Constructor for class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Create a record with the root element name.
DOMRecord(String, String) - Constructor for class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Create a record with the root element name get the namespace URI from the namespaceResolver.
DOMRecord(String, NamespaceResolver) - Constructor for class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Create a record with the root element name get the namespace URI from the namespaceResolver.
DOMRecord(String, NamespaceResolver, Node) - Constructor for class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Create a record with the local root element name, that is a child of the parent.
DOMRecord(String, Node) - Constructor for class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Create a record with the local root element name, that is a child of the parent.
DOMRecord(Document) - Constructor for class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Create a record with the element.
DOMRecord(Element) - Constructor for class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Create a record with the element.
DOMRecord(Node) - Constructor for class org.eclipse.persistence.oxm.record.DOMRecord
 
domToEventWriterClass - Static variable in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
domToStreamWriterClass - Static variable in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
DomToXMLEventWriter - Class in org.eclipse.persistence.internal.oxm.record
 
DomToXMLEventWriter() - Constructor for class org.eclipse.persistence.internal.oxm.record.DomToXMLEventWriter
 
DomToXMLEventWriter(XMLEventFactory) - Constructor for class org.eclipse.persistence.internal.oxm.record.DomToXMLEventWriter
 
DomToXMLStreamWriter - Class in org.eclipse.persistence.internal.oxm.record
 
DomToXMLStreamWriter() - Constructor for class org.eclipse.persistence.internal.oxm.record.DomToXMLStreamWriter
 
DOMUnmarshaller - Class in org.eclipse.persistence.internal.oxm.record
INTERNAL:
DOMUnmarshaller(XMLUnmarshaller, Map<String, Boolean>) - Constructor for class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
doNotCacheQueryResults() - Method in class org.eclipse.persistence.queries.ReadQuery
ADVANCED:
DoNotCheckCache - Static variable in class org.eclipse.persistence.config.CacheUsage
Do not check the cache first, this is the default for JPA Queries.
DoNotCheckCache - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
doNotRedirect - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Can be set to true in the case there is a redirector or a default redirector but the user does not want the query redirected.
doNotUseOuterJoin() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
DONT_USE_DISTINCT - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
dontAcquireLocks() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Set the query not to lock.
dontAllowNull() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
PUBLIC: If all the fields in the database row for the aggregate object are NULL, then, by default, the mapping will place a null in the appropriate source object (as opposed to an aggregate object filled with nulls).
dontAlwaysConformResultsInUnitOfWork() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: The descriptor is defined to not conform the results in unit of work in read query.
dontAlwaysRefreshCache() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This method is the equivalent of calling ClassDescriptor.setShouldAlwaysRefreshCache(boolean) with an argument of false: it ensures that a ClassDescriptor is not configured to always refresh the cache if data is received from the database by any query.
dontAlwaysRefreshCacheOnRemote() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This method is the equivalent of calling ClassDescriptor.setShouldAlwaysRefreshCacheOnRemote(boolean) with an argument of false: it ensures that a ClassDescriptor is not configured to always remotely refresh the cache if data is received from the database by any query in a RemoteSession.
dontBindAllParameters() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Do not Bind all arguments to any SQL statement.
dontBindAllParameters() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Do not bind all arguments to any SQL statement.
dontBindUpdateAllQueryUsingTempTables() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: May need to override this method if the sql generated for UpdateAllQuery using temp tables fails in case parameter binding is used.
dontBindUpdateAllQueryUsingTempTables() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 has issues with binding with temp table queries.
dontBindUpdateAllQueryUsingTempTables() - Method in class org.eclipse.persistence.platform.database.Informix11Platform
Returns true when invoked to indicate that parameter binding must not be used when working with temporary tables as part of an UPDATE query.
dontBindUpdateAllQueryUsingTempTables() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: In SQLServer local temporary table created by one PreparedStatement can't be used in another PreparedStatement.
dontCacheAllStatements() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Do not cache all prepared statements.
dontCacheStatement() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Don't cache the prepared statements, this requires full parameter binding as well.
dontCascade() - Method in class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: Set if the copy should not cascade relationships when copying the object(s)
dontCascadeOnDelete() - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
PUBLIC: Disables delete cascading on the database, this is the default.
dontCascadeParts() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Merge only direct parts, this can be used to merge clone when using RMI.
dontCascadeParts() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Do not cascade the query and its properties on the queries object(s) relationships.
dontCatchExceptions() - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: This method is used for don't catching all the Descriptor Exceptions
dontCheckCache() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: This can be used to explicitly disable the cache hit.
dontCheckDatabase() - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: This method is used for don't checking the database tables and fields.
dontCheckInstantiationPolicy() - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: This method is used for don't checking the InstantiationPolicy.
dontDisableCacheHits() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Allow for cache hits on primary key read object queries.
dontDisableCacheHitsOnRemote() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Allow for remote session cache hits on primary key read object queries.
dontDoMerge(Object, Object, MergeManager) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return true if the merge should be bypassed.
dontLoadResultIntoSelectionObject() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Do not refesh/load into the selection object, this is the default.
dontLogMessages() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Turn off logging
dontLogMessages() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Turn off logging
dontLogProfile() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
PUBLIC: Set whether after each query execution the profile result should be logged.
dontMaintainCache() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Set for the identity map (cache) to be ignored completely.
dontOnlyRefreshCacheIfNewerVersion() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This method is the equivalent of calling ClassDescriptor.setShouldOnlyRefreshCacheIfNewerVersion(boolean) with an argument of false: it ensures that a ClassDescriptor is not configured to only refresh the cache if the data received from the database by a query is newer than the data in the cache (as determined by the optimistic locking field).
dontOptimizeDataConversion() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Disable driver level data conversion optimization.
dontPerformValidation() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not referred in the unit of work cache.
dontPerformValidation() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not referred in the unit of work cache.
dontReadSubclassesOnQueries() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Set the descriptor to only read instance of itself when queried.
dontRefreshIdentityMapResult() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
PUBLIC: When unset means perform read normally and dont do refresh.
dontRefreshIdentityMapResult() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: When unset means perform read normally and dont do refresh.
dontRefreshRemoteIdentityMapResult() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
PUBLIC: When unset means perform read normally and dont do refresh.
dontRefreshRemoteIdentityMapResult() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: When unset means perform read normally and dont do refresh.
dontRetrievePrimaryKeys() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Set if the query results should contain the primary keys or each associated object.
dontReturnSingleAttribute() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Don't simplify the result by returning the single attribute.
dontReturnSingleResult() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by only returning the first result.
dontReturnSingleValue() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by only returning a single value.
dontReturnWithoutReportQueryResult() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by only returning a single value.
dontUseBatchReading() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Indicates whether the referenced object should always be batch read on read all queries.
dontUseBatchWriting() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use batch writing.
dontUseByteArrayBinding() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use parameter binding for large binary data.
dontUseClassNameAsIndicator() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Set the descriptor not to use the class' full name as the indicator.
dontUseDistinct() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
ADVANCED: If a distinct has been set the DISTINCT clause will be printed.
dontUseDistinct() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
ADVANCED: If a distinct has been set the DISTINCT clause will be printed.
dontUseExternalConnectionPooling() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Do not use external connection pooling.
dontUseExternalTransactionController() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Let EclipseLink control transactions instead of some external transaction service such as JTS.
dontUseIndirection() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Indirection means that a ValueHolder will be put in-between the attribute and the real object.
dontUseIndirection() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Indirection means that a ValueHolder will be put in-between the attribute and the real object.
dontUseJDBCBatchWriting() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Indicate to EclipseLink that the JDBC driver does not support batch writing.
dontUseLazyConnection() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: A lazy connection only acquires a physical connection when a transaction is started and releases the connection when the transaction completes.
dontUseNativeSQL() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use database-specific SQL grammar, as opposed to the JDBC standard grammar.
dontUseStreamsForBinding() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use streams to store large binary data.
dontUseStringBinding() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Do not bind strings of any size.
doQueryToManyRelationship() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL:
DOT - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
Dot.
DOT - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
DOUBLE - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
DOUBLE - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
DOUBLE_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
DOUBLE_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
doubleSlashes(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Double up \ to allow printing of directories for source code generation.
doUseOuterJoin() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
doValuesConform(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
Conform in-memory the two values.
dpInitializatonPolicy - Variable in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
 
dpm - Variable in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
driver - Variable in class org.eclipse.persistence.sessions.DefaultConnector
cache up the instantiated Driver to speed up reconnects
driverClass - Variable in class org.eclipse.persistence.sessions.DefaultConnector
cache up the driver class to speed up reconnects
driverClassName - Variable in class org.eclipse.persistence.sessions.DefaultConnector
 
driverIs(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
INTERNAL: Return whether the specified driver is being used.
driverName - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
driverSupportsNationalCharacterVarying - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
True if the current jdbc driver supports get/setNString methods
driverURLHeader - Variable in class org.eclipse.persistence.sessions.DefaultConnector
 
Drop - Static variable in class org.eclipse.persistence.config.FlushClearCache
Call to clear method causes to drop the whole EntityManager cache.
DROP_AND_CREATE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "drop-and-create-tables" specifies that database tables should be dropped, then created.
DROP_JDBC_DDL_FILE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The property "eclipselink.drop-ddl-jdbc-file-name" specifies the name of the DDL file which is used to drop database tables.
DROP_ONLY - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "drop-tables" specifies that database tables should be dropped only.
dropConstraints(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Execute the SQL alter table constraint creation string.
dropConstraints(DatabaseSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Drop the table constraints from the database.
dropConstraints(DatabaseSession, SchemaManager) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Drop the table constraints from the database.
dropConstraints(DatabaseSession, SchemaManager, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Drop the table constraints from the database.
dropConstraints(TableDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Use the table definition to drop the constraints from the table, this is normally done in two steps to avoid dependencies.
dropConstraintsOnDatabase(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Execute the SQL alter table constraint creation string.
dropDatabaseSchema(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Execute the DDL to drop the database schema for this object.
dropDatabaseSchema(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Execute the DDL to drop the database schema for this object.
dropDatabaseSchema(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
INTERNAL: Execute the DDL to drop the database schema for this object.
dropDatabaseSchemaOnDatabase(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Execute the DDL to drop the database schema for this object.
dropDatabaseSchemaOnDatabase(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Execute the DDL to drop the database schema for this object.
dropDatabaseSchemaOnDatabase(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
INTERNAL: Execute the DDL to drop the database schema for this object.
dropDatabaseSchemas - Variable in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
dropDatabaseSchemas() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
INTERNAL: Iterate over the schemas that need to be dropped.
dropDefaultTables() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Create the default table schema for the project this session associated with.
dropFromDatabase(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Execute the DDL to drop the object.
dropIndexes(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL:
Write the SQL drop index string to drop indexes if passed a writer, else delegate to a method that executes the string on the database.
DropInvalidate - Static variable in class org.eclipse.persistence.config.FlushClearCache
Call to clear method causes to drops the whole EntityManager cache, on commit the classes that have at least one object updated or deleted are invalidated in the shared cache.
dropObject(AbstractSession, Writer, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Execute the DDL to drop the object.
dropObject(DatabaseObjectDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Use the definition object to drop the schema entity from the database.
dropSchemaWriter - Variable in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
dropSequences() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
This will drop the database schemas if managing the database schemas.
dropTable(String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Drop (delete) the table named tableName from the database.
dropTables(DatabaseSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Drop the tables from the database.
dropTables(DatabaseSession, SchemaManager) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Drop the tables from the database.
dropTables(DatabaseSession, SchemaManager, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Drop the tables from the database.
DTD_VALIDATION - Static variable in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
DTD_VALIDATION - Static variable in class org.eclipse.persistence.oxm.XMLUnmarshaller
 
DTD_VALIDATION - Static variable in class org.eclipse.persistence.oxm.XMLValidator
 
DTD_VALIDATION - Static variable in interface org.eclipse.persistence.platform.xml.XMLParser
 
dtdFileName40 - Static variable in class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
 
dtdFileName45 - Static variable in class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
 
dtdFileName904 - Static variable in class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
 
dumpConcurrencyManagerInformationIfAppropriate() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
dumpConcurrencyManagerInformationStep01(Map<Thread, DeferredLockManager>, Map<Thread, ReadLockManager>, Map<Thread, ConcurrencyManager>, Map<Thread, String>, Map<Thread, Set<ConcurrencyManager>>, Map<Thread, ConcurrencyManager>, Map<Thread, String>, Set<Thread>, Map<Thread, String>, Map<Thread, Set<Object>>) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
The current working thread is having problems.
dumpConcurrencyManagerInformationStep02(ConcurrencyManagerState) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Dump the server log all of the information that we managed to aggregate about the current state of the concurrency manager.
dumpDeadLockExplanationIfPossible(ConcurrencyManagerState) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
dumpResults() - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
Log the results to the session's log (System.out).
dumpTime - Variable in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
dumpTime - Static variable in class org.eclipse.persistence.tools.profiler.QueryMonitor
 
DUPLICATE_ELEMENT_NAME - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
DUPLICATE_PARTITION_VALUE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
DUPLICATE_PROPERTY_NAME - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
duplicateElementName(QName) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
duplicatePartitionValue(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
ValuePartitioning using the same value twice.
duplicatePropertyName(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
DURATION - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
DURATION - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
DURATION_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
DYNAMIC_ENTITY_HAS_NULL_TYPE - Static variable in exception org.eclipse.persistence.exceptions.DynamicException
 
DYNAMIC_ENTITY_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.DynamicException
 
DYNAMIC_PROPERTIES_MANAGER_CLASSNAME_SLASHES - Static variable in class org.eclipse.persistence.dynamic.DynamicClassWriter
 
DynamicClassLoader - Class in org.eclipse.persistence.dynamic
This custom ClassLoader provides support for dynamically generating classes within an EclipseLink application using byte codes created using a DynamicClassWriter.
DynamicClassLoader(ClassLoader) - Constructor for class org.eclipse.persistence.dynamic.DynamicClassLoader
Create a DynamicClassLoader providing the delegate loader and leaving the defaultWriter as DynamicClassWriter
DynamicClassLoader(ClassLoader, DynamicClassWriter) - Constructor for class org.eclipse.persistence.dynamic.DynamicClassLoader
Create a DynamicClassLoader providing the delegate loader and a default DynamicClassWriter.
DynamicClassLoader.EnumInfo - Class in org.eclipse.persistence.dynamic
 
DynamicClassWriter - Class in org.eclipse.persistence.dynamic
Write the byte codes of a dynamic entity class.
DynamicClassWriter() - Constructor for class org.eclipse.persistence.dynamic.DynamicClassWriter
 
DynamicClassWriter(Class<?>) - Constructor for class org.eclipse.persistence.dynamic.DynamicClassWriter
 
DynamicClassWriter(String) - Constructor for class org.eclipse.persistence.dynamic.DynamicClassWriter
Create using a loader and class name so that the parent class can be lazily loaded when the writer is used to generate a dynamic class.
DynamicEntity - Interface in org.eclipse.persistence.dynamic
DynamicEntity is the public interface for dealing with dynamic persistent objects.
DynamicEntityImpl - Class in org.eclipse.persistence.internal.dynamic
This abstract class is used to represent an entity which typically is not realized in Java code.
DynamicEntityImpl() - Constructor for class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
Instantiates a new dynamic entity impl.
DynamicEntityImpl.PropertyWrapper - Class in org.eclipse.persistence.internal.dynamic
 
DynamicEnumBuilder - Class in org.eclipse.persistence.dynamic
 
DynamicEnumBuilder(String, AbstractDirectMapping, DynamicClassLoader) - Constructor for class org.eclipse.persistence.dynamic.DynamicEnumBuilder
 
DynamicException - Exception in org.eclipse.persistence.exceptions
Custom exception type that provides information about failure cases encountered when using a GenericEntity with TopLink.
DynamicException(String) - Constructor for exception org.eclipse.persistence.exceptions.DynamicException
 
DynamicException(String, Throwable) - Constructor for exception org.eclipse.persistence.exceptions.DynamicException
 
DynamicHelper - Class in org.eclipse.persistence.dynamic
A DynamicHelper provides some utility methods to simplify application development with dynamic types.
DynamicHelper(DatabaseSession) - Constructor for class org.eclipse.persistence.dynamic.DynamicHelper
 
DynamicHelper.SessionCustomizer - Class in org.eclipse.persistence.dynamic
A SessionCustomizer which configures all descriptors as dynamic entity types.
DynamicPropertiesInitializatonPolicy - Class in org.eclipse.persistence.internal.dynamic
 
DynamicPropertiesInitializatonPolicy() - Constructor for class org.eclipse.persistence.internal.dynamic.DynamicPropertiesInitializatonPolicy
Default constructor.
DynamicPropertiesManager - Class in org.eclipse.persistence.internal.dynamic
Information about a property is extracted (thru DynamicType) from the entity's ClassDescriptor
DynamicPropertiesManager() - Constructor for class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
 
DynamicSchemaManager - Class in org.eclipse.persistence.tools.schemaframework
Extended SchemaManager to handle the creation of tables for dynamic types.
DynamicSchemaManager(DatabaseSession) - Constructor for class org.eclipse.persistence.tools.schemaframework.DynamicSchemaManager
 
DynamicSQLBatchWritingMechanism - Class in org.eclipse.persistence.internal.databaseaccess
INTERNAL:
DynamicSQLBatchWritingMechanism(DatabaseAccessor) - Constructor for class org.eclipse.persistence.internal.databaseaccess.DynamicSQLBatchWritingMechanism
 
dynamicSQLMechanism - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
These two attributes store the available BatchWritingMechanisms.
dynamicStatement - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
PERF: Cache the statement object for dynamic SQL execution.
DynamicType - Interface in org.eclipse.persistence.dynamic
An EntityType provides a metadata facade into the EclipseLink object-relational metadata (descriptors & mappings) with specific knowledge of the entity types being dynamic.
DynamicTypeBuilder - Class in org.eclipse.persistence.dynamic
The EntityTypeBuilder is a factory class for creating and extending dynamic entity types.
DynamicTypeBuilder(Class<?>, DynamicType, String...) - Constructor for class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Create an EntityType for a new dynamic type.
DynamicTypeBuilder(DynamicClassLoader, ClassDescriptor, DynamicType) - Constructor for class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Create an EntityTypeBuilder for an existing descriptor.
DynamicTypeImpl - Class in org.eclipse.persistence.internal.dynamic
An EntityType provides a metadata facade into the EclipseLink object-relational metadata (descriptors & mappings) with specific knowledge of the entity types being dynamic.
DynamicTypeImpl() - Constructor for class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
DynamicTypeImpl(ClassDescriptor, DynamicType) - Constructor for class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
Creation of an EntityTypeImpl for an existing Descriptor with mappings.

E

eagerMappings - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Cache mappings that are eager loaded.
earlyPreDelete(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: This method is called to update collection tables prior to commit.
earlyPreDelete(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: This method is called to update collection tables prior to commit.
earlyPreDelete(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Delete join tables before the start of the deletion process to avoid constraint errors.
earlyPreDelete(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Record deletion dependencies for foreign key constraints.
EclipseLink - Static variable in class org.eclipse.persistence.config.ParserValidationType
 
ECLIPSELINK_1_0_SCHEMA - Static variable in class org.eclipse.persistence.sessions.factories.XMLProjectReader
 
ECLIPSELINK_NAMESPACE - Static variable in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
ECLIPSELINK_PERSISTENCE_UNITS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
This "eclipselink.persistenceunits" property specifies the set of persistence unit names that will be processed when generating the canonical model.
ECLIPSELINK_PERSISTENCE_XML - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.persistencexml" property specifies the full resource name to look for the persistence XML files in.
ECLIPSELINK_PERSISTENCE_XML_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The default resource location used to locate the persistence.xml configuration files.
ECLIPSELINK_PREFIX - Static variable in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
EclipseLink_Product_Name - Static variable in class org.eclipse.persistence.services.RuntimeServices
 
ECLIPSELINK_SCHEMA - Static variable in class org.eclipse.persistence.sessions.factories.XMLProjectReader
 
ECLIPSELINK_SE_PUINFO - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.se-puinfo" property specifies a org.eclipse.persistence.internal.jpa.deployment.SEPersistenceUnitInfo that is used create an EntityManagerFactory.
ECLIPSELINK_SESSIONS_SCHEMA - Static variable in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
 
EclipseLinkClassWriter - Interface in org.eclipse.persistence.dynamic
 
EclipseLinkException - Exception in org.eclipse.persistence.exceptions
Purpose: Any exception raised by EclipseLink should be a subclass of this exception class.
EclipseLinkException() - Constructor for exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL: Return a new exception.
EclipseLinkException(String) - Constructor for exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL: EclipseLink exception should only be thrown by EclipseLink.
EclipseLinkException(String, Throwable) - Constructor for exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL: EclipseLink exception should only be thrown by EclipseLink.
EclipseLinkLocalization - Class in org.eclipse.persistence.internal.localization
Purpose: Any EclipseLink message in Foundation Library & J2EE Integration JARs should be a subclass of this class.
EclipseLinkLocalization() - Constructor for class org.eclipse.persistence.internal.localization.EclipseLinkLocalization
 
EclipseLinkLogRecord - Class in org.eclipse.persistence.logging
INTERNAL:
EclipseLinkLogRecord(Level, String) - Constructor for class org.eclipse.persistence.logging.EclipseLinkLogRecord
 
EclipseLinkObjectPersistenceRuntimeXMLProject - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: Define the EclipseLInk OX project and descriptor information to read an EclipseLink project from an XML file.
EclipseLinkObjectPersistenceRuntimeXMLProject() - Constructor for class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
INTERNAL: Return a new descriptor project.
EIS_DESCRIPTOR_CLASS - Static variable in class org.eclipse.persistence.internal.sessions.factories.MissingDescriptorListener
 
EIS_EXCEPTION - Static variable in exception org.eclipse.persistence.eis.EISException
 
EIS_LOGIN_CLASS - Static variable in class org.eclipse.persistence.internal.sessions.factories.MissingDescriptorListener
 
EISAccessor - Class in org.eclipse.persistence.eis
EISAccessor is an implementation of the Accessor interface.
EISAccessor() - Constructor for class org.eclipse.persistence.eis.EISAccessor
Default Constructor.
EISCollectionChangeRecord - Class in org.eclipse.persistence.eis
INTERNAL: Capture the changes for an unordered collection as collections of adds and removes.
EISCollectionChangeRecord - Interface in org.eclipse.persistence.sessions.changesets
Purpose: To provide API into the EISCollectionChangeSet.
EISCollectionChangeRecord(ObjectChangeSet, String, DatabaseMapping) - Constructor for class org.eclipse.persistence.eis.EISCollectionChangeRecord
Construct a ChangeRecord that can be used to represent the changes to an unordered collection.
EISCompositeCollectionMapping - Class in org.eclipse.persistence.eis.mappings
EIS Composite Collection Mappings map a java.util.Map or java.util.Collection of Java objects to an EIS record in a privately owned, one-to-many relationship according to its descriptor's record type.
EISCompositeCollectionMapping() - Constructor for class org.eclipse.persistence.eis.mappings.EISCompositeCollectionMapping
 
EISCompositeDirectCollectionMapping - Class in org.eclipse.persistence.eis.mappings
EIS Composite Direct Collection Mappings map a collection of simple Java attributes to and from an EIS Record according to its descriptor's record type.
EISCompositeDirectCollectionMapping() - Constructor for class org.eclipse.persistence.eis.mappings.EISCompositeDirectCollectionMapping
 
EISCompositeObjectMapping - Class in org.eclipse.persistence.eis.mappings
EIS Composite Object Mappings map a Java object to a privately owned, one-to-one relationship to an EIS Record according to its descriptor's record type.
EISCompositeObjectMapping() - Constructor for class org.eclipse.persistence.eis.mappings.EISCompositeObjectMapping
 
EISConnectionSpec - Class in org.eclipse.persistence.eis
An EISConnectionSpec specifies how the jakarta.resource.cci.Connection is accessed.
EISConnectionSpec() - Constructor for class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Construct a EISConnectionSpec with no settings.
EISConnectionSpec(String) - Constructor for class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Construct a EISConnectionSpec with the specified settings.
EISConnectionSpec(Context, String) - Constructor for class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Construct a EISConnectionSpec with the specified settings.
EISConnectionSpec(Context, Name) - Constructor for class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Construct a EISConnectionSpec with the specified settings.
EISConnectionSpec(Name) - Constructor for class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Construct a EISConnectionSpec with the specified settings.
EISDescriptor - Class in org.eclipse.persistence.eis
An EISDescriptor defines the mapping from a JCA data structure to a Java object.
EISDescriptor() - Constructor for class org.eclipse.persistence.eis.EISDescriptor
Default constructor.
EISDirectMapping - Class in org.eclipse.persistence.eis.mappings
EIS Direct Mappings map a simple Java attribute to and from an EIS Record according to its descriptor's record type.
EISDirectMapping() - Constructor for class org.eclipse.persistence.eis.mappings.EISDirectMapping
 
EISDOMRecord - Class in org.eclipse.persistence.eis
An EISDOMRecord is a wrapper for a DOM tree.
EISDOMRecord() - Constructor for class org.eclipse.persistence.eis.EISDOMRecord
Default constructor.
EISDOMRecord(Record) - Constructor for class org.eclipse.persistence.eis.EISDOMRecord
Create a TopLink record from the JCA adapter record.
EISDOMRecord(Record, Element) - Constructor for class org.eclipse.persistence.eis.EISDOMRecord
Create a TopLink record from the JCA adapter record and DOM tree.
EISDOMRecord(Element) - Constructor for class org.eclipse.persistence.eis.EISDOMRecord
Create a TopLink record from a DOM tree.
EISException - Exception in org.eclipse.persistence.eis
Use an EISException when any problem is detected while interacting with an EIS datasource
EISException(Exception) - Constructor for exception org.eclipse.persistence.eis.EISException
 
EISException(Exception, String) - Constructor for exception org.eclipse.persistence.eis.EISException
 
EISException(String) - Constructor for exception org.eclipse.persistence.eis.EISException
 
EISExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for EISException messages.
EISExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.EISExceptionResource
Default constructor.
EISInteraction - Class in org.eclipse.persistence.eis.interactions
Defines the specification for a call to a JCA interaction.
EISInteraction() - Constructor for class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: Default constructor.
EISLogin - Class in org.eclipse.persistence.eis
An EISLogin defines connection information and datasource properties.
EISLogin() - Constructor for class org.eclipse.persistence.eis.EISLogin
Default constructor.
EISLogin(Platform) - Constructor for class org.eclipse.persistence.eis.EISLogin
Constructor.
EISLoginConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.login
INTERNAL:
EISLoginConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.login.EISLoginConfig
 
EISMappedRecord - Class in org.eclipse.persistence.eis
An EISMappedRecord acts as a Record wrapper.
EISMappedRecord(Map, EISAccessor) - Constructor for class org.eclipse.persistence.eis.EISMappedRecord
Create a database row wrapper for the record.
EISMapping - Interface in org.eclipse.persistence.eis.mappings
INTERNAL All mappings which can be added to org.eclipse.persistence.eis.EISDescriptor must implement this interface.
EISObjectPersistenceXMLProject - Class in org.eclipse.persistence.eis
INTERNAL:
EISObjectPersistenceXMLProject() - Constructor for class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
INTERNAL: Return a new descriptor project.
EISObjectPersistenceXMLProject(NamespaceResolverWithPrefixes) - Constructor for class org.eclipse.persistence.eis.EISObjectPersistenceXMLProject
 
EISOneToManyMapping - Class in org.eclipse.persistence.eis.mappings
An EIS one-to-many mapping is a reference mapping that represents the relationship between a single source object and a collection of mapped persistent Java objects.
EISOneToManyMapping() - Constructor for class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
 
EISOneToManyMappingHelper - Class in org.eclipse.persistence.eis.mappings
INTERNAL: Helper class to consolidate all the heinous comparing and merging code for the EIS one to many mappings.
EISOneToManyMappingHelper(EISOneToManyMapping) - Constructor for class org.eclipse.persistence.eis.mappings.EISOneToManyMappingHelper
Constructor.
EISOneToManyQueryBasedValueHolder<T> - Class in org.eclipse.persistence.internal.indirection
Value holder used to defer an EIS 1-m mapping query.
EISOneToManyQueryBasedValueHolder(EISOneToManyMapping, ReadQuery, AbstractRecord, AbstractSession) - Constructor for class org.eclipse.persistence.internal.indirection.EISOneToManyQueryBasedValueHolder
 
EISOneToOneMapping - Class in org.eclipse.persistence.eis.mappings
An EIS one-to-one mapping is a reference mapping that represents the relationship between a single source object and a single mapped persistent Java object.
EISOneToOneMapping() - Constructor for class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
 
EISOrderedCollectionChangeRecord - Class in org.eclipse.persistence.eis
INTERNAL: Capture the changes for an ordered collection where the entire collection is simply replaced if it has changed.
EISOrderedCollectionChangeRecord - Interface in org.eclipse.persistence.sessions.changesets
Purpose: To provide API into the EISCollectionChangeSet.
EISOrderedCollectionChangeRecord(ObjectChangeSet, String, DatabaseMapping) - Constructor for class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
Construct a ChangeRecord that can be used to represent the changes to an ordered collection.
EISPlatform - Class in org.eclipse.persistence.eis
An EISPlatform defines any EIS adapter specific behavior.
EISPlatform() - Constructor for class org.eclipse.persistence.eis.EISPlatform
Default constructor.
EISSequence - Class in org.eclipse.persistence.eis
The EISSequence class allows access to sequence resources using custom read (ValueReadQuery) and update (DataModifyQuery) queries and a user specified preallocation size.
EISSequence() - Constructor for class org.eclipse.persistence.eis.EISSequence
 
EISSequence(String) - Constructor for class org.eclipse.persistence.eis.EISSequence
 
EISSequence(String, int) - Constructor for class org.eclipse.persistence.eis.EISSequence
 
EISTransformationMapping - Class in org.eclipse.persistence.eis.mappings
EIS Transformation Mappings allow the creation of custom mappings where one or more fields in an EIS Record can be used to create the object to be stored in a Java class's attribute.
EISTransformationMapping() - Constructor for class org.eclipse.persistence.eis.mappings.EISTransformationMapping
 
EJB - org.eclipse.persistence.logging.LogCategory
 
EJB - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
EJB_CANNOT_LOAD_REMOTE_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EJB_CONTAINER_EXCEPTION_RAISED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EJB_DESCRIPTOR_NOT_FOUND_IN_SESSION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EJB_FINDER_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EJB_INVALID_FINDER_ON_HOME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EJB_INVALID_PLATFORM_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EJB_INVALID_PROJECT_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EJB_INVALID_SESSION_TYPE_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EJB_MUST_BE_IN_TRANSACTION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EJB_NO_SUCH_SESSION_SPECIFIED_IN_PROPERTIES - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EJB_PRIMARY_KEY_REFLECTION_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EJB_SESSION_TYPE_CLASS_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EJB_TOPLINK_PROPERTIES_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ejbCannotLoadRemoteClass(Exception, Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
ejbContainerExceptionRaised(Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
ejbDescriptorNotFoundInSession(Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: The descriptor listed was not found in the session specified on the deployment descriptor.
ejbFinderException(Object, Throwable, Vector) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
ejbInvalidHomeInterfaceClass(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
ejbInvalidPlatformClass(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
ejbInvalidProjectClass(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: The project class specified in the sessions.xml file for the session specified on the toplink_session_name environment variable can not be found.
ejbInvalidSessionTypeClass(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: The session type specified in the sessions.xml file for the session specified on the toplink_session_name environment variable is not a valid type.
ejbMustBeInTransaction(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: An attempt was made to create or remove a been outside of a transaction.
ejbPrimaryKeyReflectionException(Exception, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: An incorrect primary key object is being used with a bean.
ejbqlCall - Variable in class org.eclipse.persistence.internal.queries.JPQLCallQueryMechanism
 
ejbSessionTypeClassNotFound(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: The session type specified in the sessions.xml file for the session specified on the toplink_session_name environment variable is not found using the default class loader.
element(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
INTERNAL:
element(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.FormattedOutputStreamRecord
INTERNAL:
element(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.FormattedWriterRecord
INTERNAL:
element(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
INTERNAL:
element(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
element(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
element(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Receive notification of an element.
element(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL:
element(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL:
element(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
element(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL:
element(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
element(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
Element - Class in org.eclipse.persistence.internal.oxm.schema.model
A Value Object class representing XML Schema's Element.
Element() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Element
 
ELEMENT - Static variable in interface org.eclipse.persistence.platform.xml.XMLSchemaReference
 
ELEMENT_FORM_QUALIFIED_KEY - Static variable in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGeneratorProperties
 
elementAt(int) - Method in class org.eclipse.persistence.indirection.IndirectList
 
elementAt(int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
elementAt(int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
elementAt(int) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
If the index is beyond the size wait until complete.
elementClass - Variable in class org.eclipse.persistence.internal.queries.MapContainerPolicy
 
elementClassName - Variable in class org.eclipse.persistence.internal.queries.MapContainerPolicy
 
elementDataTypeName - Variable in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
This is the "data type" associated with each element in the nested collection.
elementDescriptor - Variable in class org.eclipse.persistence.internal.queries.ContainerPolicy
The descriptor is used to wrap and unwrap objects using the wrapper policy.
elementExistsInSequence(String, String, Sequence) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Convenience method for determining if an element already exists in a given sequence.
elements() - Method in class org.eclipse.persistence.indirection.IndirectList
 
elements() - Method in class org.eclipse.persistence.indirection.IndirectMap
 
elements() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
elements() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
elements() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
elements() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Allow concurrent streaming of the elements.
elements() - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Allow for the cache to be iterated on.
elements() - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Allow for the cache CacheKey.getObject() elements to be iterated.
elements() - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Allow for the cache to be iterated on.
elements() - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Return an empty enumerator.
elements() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Returns an Enumeration of the values.
elements() - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Allow for the cache to be iterated on.
EMBEDDABLE_ASSOCIATION_OVERRIDE_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EMBEDDABLE_ATTRIBUTE_NAME_FOR_CONVERT_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EMBEDDABLE_ATTRIBUTE_OVERRIDE_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
embeddableAssociationOverrideNotFound(Object, String, Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
embeddableAttributeNameForConvertNotFound(String, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
embeddableAttributeOverrideNotFound(Object, String, Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
EmbeddableMapping - Interface in org.eclipse.persistence.mappings
INTERNAL Common interface to those mappings that are used to map JPA Embedded objects.
EMBEDDED_ID_AND_ID_ANNOTATIONS_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EMBEDDED_ID_CLASS_HAS_NO_ATTRIBUTES - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
embeddedIdAndIdAnnotationFound(Object, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
embeddedIdHasNoAttributes(Object, Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
EMPTY - Static variable in class org.eclipse.persistence.internal.identitymaps.CacheId
 
EMPTY_CHAR_ARRAY - Static variable in class org.eclipse.persistence.oxm.XMLConstants
 
EMPTY_CONTAINER_DEFAULT - Static variable in interface org.eclipse.persistence.internal.oxm.mappings.XMLContainerMapping
This is the default setting for the defaultEmptyContainer property.
EMPTY_NODE - org.eclipse.persistence.oxm.annotations.XmlMarshalNullRepresentation
 
EMPTY_NODE - org.eclipse.persistence.oxm.mappings.nullpolicy.XMLNullRepresentationType
Write out an empty node.
EMPTY_STRING - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
Empty String.
EMPTY_STRING - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
EMPTY_VECTOR - Static variable in class org.eclipse.persistence.internal.oxm.VectorUtils
The empty vector (immutable).
emptyAttribute(XPathFragment, NAMESPACE_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
emptyAttribute(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
emptyAttribute(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
emptyAttribute(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Used when an nil attribute should be written
emptyCollection - Variable in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
emptyCollection(XPathFragment, NAMESPACE_RESOLVER, boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
emptyCollection(XPathFragment, NamespaceResolver, boolean) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
Handle marshal of an empty collection.
emptyCollection(XPathFragment, NamespaceResolver, boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
Handle marshal of an empty collection.
emptyCollection(XPathFragment, NamespaceResolver, boolean) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Handle marshal of an empty collection.
emptyCollectionGenerated - Variable in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
emptyComplex(XPathFragment, NAMESPACE_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
emptyComplex(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
Used when an empty complex item should be written
emptyComplex(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
Used when an empty complex item should be written
emptyComplex(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Used when an nil attribute should be written
emptyNodeRepresentsNull() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlIsSetNullPolicy
 
emptyNodeRepresentsNull() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNullPolicy
 
emptyRecord - Static variable in class org.eclipse.persistence.internal.sessions.EmptyRecord
PERF: Store a singleton empty record to avoid creation when not required.
EmptyRecord - Class in org.eclipse.persistence.internal.sessions
Purpose: Define a singleton empty record to avoid record creation when not required.
EmptyRecord() - Constructor for class org.eclipse.persistence.internal.sessions.EmptyRecord
 
emptySimple(NAMESPACE_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
emptySimple(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
Used when an empty simple value should be written
emptySimple(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
Used when an empty simple value should be written
emptySimple(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Used when an nil attribute should be written
emptyVector() - Static method in class org.eclipse.persistence.internal.oxm.VectorUtils
Returns an empty vector (immutable).
ENABLE_JTA_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
ENABLE_RUNTIME_SERVICES_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
enableEventProcessing(Object) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: This method is used to enable changetracking temporarily
enableEventProcessing(Object) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: This method is used to enable changetracking temporarily
enableEventProcessing(Object) - Method in class org.eclipse.persistence.descriptors.changetracking.ObjectChangeTrackingPolicy
INTERNAL: This method is used to enable changetracking temporarily
enableFieldAliasesCaching() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
enableRuntimeServices() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: enableRuntimeServices(): Configure the receiver such that JMX/MBeans will be registered to provide runtime services for my DatabaseSession at runtime.
EncodedData(byte[], String) - Constructor for class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper.EncodedData
 
encoder - Variable in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
encoder - Variable in class org.eclipse.persistence.oxm.record.WriterRecord
 
encoding - Variable in class org.eclipse.persistence.internal.oxm.Root
 
ENCODING - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
encounteredSubSelectExpressions() - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
INTERNAL: Were subselect expressions found while normalizing the selection criteria? Assumes underlying collection is initialized on first add.
encrypt(String) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Security method.
ENCRYPTION_CLASS_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
encryptPassword(String) - Method in class org.eclipse.persistence.internal.security.JCEEncryptor
Encrypts a string.
encryptPassword(String) - Method in interface org.eclipse.persistence.internal.security.Securable
 
END_FROM - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
END_FROM_ID - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
endAddingToConstructorItem() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Used in conjunction with beginAddingConstructorArguments to signal that expressions should no longer be be added to the collection used in the constructor.
endCallback() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
endCDATA() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
endCDATA() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
endCDATA() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
endCDATA() - Method in class org.eclipse.persistence.oxm.record.NodeRecord.NodeRecordContentHandler
 
endCDATA() - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
endCDATA() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
endCDATA() - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
endCDATA() - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
endCollection() - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
endCollection() - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord
 
endCollection() - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
 
endCollection() - Method in class org.eclipse.persistence.oxm.record.JsonGeneratorRecord
 
endCollection() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
endCollection() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
This method is used to inform the MarshalRecord that it is done receiving element events that are part of a collection.
endDelimiter - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
endDocument() - Method in class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
endDocument() - Method in class org.eclipse.persistence.internal.oxm.IDResolver
Called when unmarshalling ends.
endDocument() - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
endDocument() - Method in class org.eclipse.persistence.internal.oxm.record.BinaryDataUnmarshalRecord
 
endDocument() - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
Trigger an endDocument event on the contenthandler.
endDocument() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
endDocument() - Method in class org.eclipse.persistence.internal.oxm.record.UnmappedContentHandlerWrapper
 
endDocument() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
endDocument() - Method in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
Trigger an endDocument event on the contenthandler.
endDocument() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
endDocument() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
endDocument() - Method in class org.eclipse.persistence.internal.oxm.unmapped.DefaultUnmappedContentHandler
 
endDocument() - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
INTERNAL:
endDocument() - Method in class org.eclipse.persistence.oxm.record.FormattedOutputStreamRecord
INTERNAL:
endDocument() - Method in class org.eclipse.persistence.oxm.record.FormattedWriterRecord
INTERNAL:
endDocument() - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
INTERNAL:
endDocument() - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
endDocument() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
endDocument() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
endDocument() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
endDocument() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Recieve notification that a document is being ended.
endDocument() - Method in class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL:
endDocument() - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL:
endDocument() - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
endDocument() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
endDocument() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
endDocument() - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL:
endDocument() - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
endDocument() - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
endDocument() - Method in class org.eclipse.persistence.oxm.record.XMLRootRecord
 
endDocument() - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
endDocument() - Method in class org.eclipse.persistence.oxm.XMLUnmarshallerHandler
 
endDocument() - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
endDTD() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
endDTD() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
endDTD() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
endDTD() - Method in class org.eclipse.persistence.oxm.record.NodeRecord.NodeRecordContentHandler
 
endDTD() - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
endDTD() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
endDTD() - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
endDTD() - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
endElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
endElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
endElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.BinaryDataUnmarshalRecord
 
endElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
endElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmappedContentHandlerWrapper
 
endElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
endElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
endElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
endElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.SAXFragmentBuilder
 
endElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.unmapped.DefaultUnmappedContentHandler
 
endElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryAttachmentHandler
 
endElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLInlineBinaryHandler
 
endElement(String, String, String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
endElement(String, String, String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
endElement(String, String, String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
endElement(String, String, String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
endElement(String, String, String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
endElement(String, String, String) - Method in class org.eclipse.persistence.oxm.record.XMLRootRecord
 
endElement(String, String, String) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
endElement(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.ChoiceUnmarshalContext
 
endElement(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectUnmarshalContext
 
endElement(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedUnmarshalContext
 
endElement(UnmarshalRecord) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalContext
An event indicating that endElement has been called on the unmarshalRecord.
endElement(XPathFragment, NAMESPACE_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
endElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
INTERNAL:
endElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.FormattedOutputStreamRecord
INTERNAL:
endElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.FormattedWriterRecord
INTERNAL:
endElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
INTERNAL:
endElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
endElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
endElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Receive notification that an element is being ended.
endElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL:
endElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL:
endElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
endElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL:
endElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
endElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.CollectionGroupingElementNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.FieldTransformerNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL:
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyObjectMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceObjectMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
Handle endElement operation.
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLDirectMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectReferenceMappingNodeValue
Handle endElement operation.
endElement(XPathFragment, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord, Object) - Method in class org.eclipse.persistence.internal.oxm.CollectionGroupingElementNodeValue
 
endElement(XPathFragment, UnmarshalRecord, Object) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
 
endElement(XPathFragment, UnmarshalRecord, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
endElement(XPathFragment, UnmarshalRecord, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
endElementProcessText(UnmarshalRecord, XMLConverterMapping, XPathFragment, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLRelationshipMappingNodeValue
 
endEmptyCollection() - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
 
endEmptyCollection() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
endEntity(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
endEntity(String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
endEntity(String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
endEntity(String) - Method in class org.eclipse.persistence.oxm.record.NodeRecord.NodeRecordContentHandler
 
endEntity(String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
endEntity(String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
endEntity(String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
endEntity(String) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
endFields - Variable in class org.eclipse.persistence.history.HistoryPolicy
 
endOperationProfile() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: End call
endOperationProfile(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: End the operation timing.
endOperationProfile(String) - Method in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
Profile the operation.
endOperationProfile(String) - Method in interface org.eclipse.persistence.sessions.SessionProfiler
INTERNAL: End the operation timing.
endOperationProfile(String) - Method in class org.eclipse.persistence.sessions.SessionProfilerAdapter
INTERNAL: End the operation timing.
endOperationProfile(String) - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
INTERNAL: End the operation timing.
endOperationProfile(String) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
INTERNAL: End the operation timing.
endOperationProfile(String, DatabaseQuery, int) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: End the operation timing.
endOperationProfile(String, DatabaseQuery, int) - Method in interface org.eclipse.persistence.sessions.SessionProfiler
INTERNAL: End the operation timing.
endOperationProfile(String, DatabaseQuery, int) - Method in class org.eclipse.persistence.sessions.SessionProfilerAdapter
INTERNAL: End the operation timing.
endOperationProfile(String, DatabaseQuery, int) - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
INTERNAL: End the operation timing.
endOperationProfile(String, DatabaseQuery, int) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
INTERNAL: End the operation timing.
endPrefixMapping(String) - Method in class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
endPrefixMapping(String) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmappedContentHandlerWrapper
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.internal.oxm.unmapped.DefaultUnmappedContentHandler
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
INTERNAL:
endPrefixMapping(String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Receive notification that the scope of this namespace declaration has ended.
endPrefixMapping(String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
endPrefixMapping(String) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
endPrefixMappings(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL: override so we don't iterate over namespaces when endPrefixMapping doesn't do anything
endPrefixMappings(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
endPrefixMappings(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
endPrefixMappings(Element) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
endPrefixMappings(Element) - Method in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
If there is a temporary namespace resolver for a given element, each entry contains a prefix that requires an endPrefixMapping event to be triggered
endSelfElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.SAXFragmentBuilder
 
endSelfNodeValue(UnmarshalRecord, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
 
endSelfNodeValue(UnmarshalRecord, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
endSelfNodeValue(UnmarshalRecord, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
endSelfNodeValue(UnmarshalRecord, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentMappingNodeValue
 
endUnmappedElement(String, String, String) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
endUnmappedElement(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
endUnmappedElement(String, String, String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
endValue - Variable in class org.eclipse.persistence.descriptors.partitioning.RangePartition
 
endValue() - Method in annotation type org.eclipse.persistence.annotations.RangePartition
The String representation of the range start value.
endValueName - Variable in class org.eclipse.persistence.descriptors.partitioning.RangePartition
 
ENFORCE_TARGET_SERVER - Static variable in class org.eclipse.persistence.config.SystemProperties
This system property can be set to override target server platform set by the Java EE container with the one either set in persistence.xml or auto detected.
enrichGenerateThreadDumpForCurrentThread() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
This helper API is created due to the problem of the corruption of the eclipselink cache.
enrichMapOfCacheKeyToDtosExplainingThreadExpectationsOnCacheKeyInfoAboutActiveAndDeferredLocks(Map<ConcurrencyManager, CacheKeyToThreadRelationships>, Map<Thread, DeferredLockManager>) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Enrich our map map of cache key to threads having a relationship with that object in regards to active locks on the cache key and deferred locks on the cache key
enrichMapOfCacheKeyToDtosExplainingThreadExpectationsOnCacheKeyInfoAboutReadLocks(Map<ConcurrencyManager, CacheKeyToThreadRelationships>, Map<Thread, ReadLockManager>) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Enrich the mapOfCacheKeyToDtosExplainingThreadExpectationsOnCacheKey based on the read locks
enrichMapOfCacheKeyToDtosExplainingThreadExpectationsOnCacheKeyInfoThreadsStuckOnAcquire(Map<ConcurrencyManager, CacheKeyToThreadRelationships>, Map<Thread, Set<ConcurrencyManager>>) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Enrich the mapOfCacheKeyToDtosExplainingThreadExpectationsOnCacheKey by setting on the cache keys the threads that are stuck trying to acquire the cache key.
enrichMapOfCacheKeyToDtosExplainingThreadExpectationsOnCacheKeyInfoThreadsStuckOnAcquireLockForReading(Map<ConcurrencyManager, CacheKeyToThreadRelationships>, Map<Thread, ConcurrencyManager>) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Enrich the mapOfCacheKeyToDtosExplainingThreadExpectationsOnCacheKey by setting on the cache keys the threads that are stuck trying to acquire the cache key with a read lock.
enrichMapThreadToWaitOnAcquireInsideWriteLockManagerClone(Map<Thread, Set<ConcurrencyManager>>, Map<Thread, ConcurrencyManager>) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
We have two maps we are using to trace threads that are stuck acquiring locks.
enrichStringBuildingExplainWhyThreadIsStuckInIsBuildObjectOnThreadComplete(List<Thread>, ConcurrencyManager, Thread, boolean, StringBuilder) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
When the recursive algorithm decides to return false it is because it is confronted with a cache key that had to be deferred.
ensureCapacity(int) - Method in class org.eclipse.persistence.indirection.IndirectList
 
ensureCapacity(int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
ensureFixedSize() - Method in class org.eclipse.persistence.internal.identitymaps.CacheIdentityMap
Reduces the size of the receiver down to the maxSize removing objects from the start of the linked list.
ensureNotLoggedIn() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: Make sure that the DatabaseSession has not logged in yet.
ENTITY_CLASS_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ENTITY_NOT_FOUND - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
ENTITY_NOT_IDEMPOTENT - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
ENTITY_TRANSACTION_WITH_JTA_NOT_ALLOWED - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
entityClass - Variable in class org.eclipse.persistence.queries.EntityResult
 
entityClassName - Variable in class org.eclipse.persistence.queries.EntityResult
Stores the class name of result
entityClassNotFound(String, ClassLoader, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
entityEventListener - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
entityEventManagers - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
entityFetchGroup - Variable in class org.eclipse.persistence.queries.FetchGroup
Caches the EntityFetch group for this FetchGroup
EntityFetchGroup - Class in org.eclipse.persistence.internal.queries
EntityFetchGroup reflects the state of the object.
EntityFetchGroup() - Constructor for class org.eclipse.persistence.internal.queries.EntityFetchGroup
 
EntityFetchGroup(String) - Constructor for class org.eclipse.persistence.internal.queries.EntityFetchGroup
 
EntityFetchGroup(String[]) - Constructor for class org.eclipse.persistence.internal.queries.EntityFetchGroup
 
EntityFetchGroup(Collection<String>) - Constructor for class org.eclipse.persistence.internal.queries.EntityFetchGroup
 
EntityFetchGroup(FetchGroup) - Constructor for class org.eclipse.persistence.internal.queries.EntityFetchGroup
 
EntityFetchGroup(FetchGroup, String) - Constructor for class org.eclipse.persistence.internal.queries.EntityFetchGroup
 
entityHasNullType(DynamicEntity) - Static method in exception org.eclipse.persistence.exceptions.DynamicException
The DynamicEntity has a null type indicating an illegal state of the entity.
entityListenerEventListeners - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
entityListenerEventManagers - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
EntityManagerProperties - Class in org.eclipse.persistence.config
The class defines EclipseLink properties' names for use at the EntityManager level.
EntityManagerSetupException - Exception in org.eclipse.persistence.exceptions
 
EntityManagerSetupException() - Constructor for exception org.eclipse.persistence.exceptions.EntityManagerSetupException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
EntityManagerSetupException(String) - Constructor for exception org.eclipse.persistence.exceptions.EntityManagerSetupException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
EntityManagerSetupException(String, Throwable) - Constructor for exception org.eclipse.persistence.exceptions.EntityManagerSetupException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
EntityManagerSetupExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for EntityManagerSetupException messages.
EntityManagerSetupExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.EntityManagerSetupExceptionResource
Default constructor.
entityNotFoundException(String) - Static method in exception org.eclipse.persistence.exceptions.DynamicException
A DynamicEntity could not be found
entityResolver - Variable in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
Used to store the entity resolver to validate the XML schema when parsing.
EntityResult - Class in org.eclipse.persistence.queries
Purpose: Concrete class to represent the EntityResult structure as defined by the EJB 3.0 Persistence specification.
EntityResult(Class<?>) - Constructor for class org.eclipse.persistence.queries.EntityResult
 
EntityResult(String) - Constructor for class org.eclipse.persistence.queries.EntityResult
 
entityTransactionNotActive() - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
entityTransactionWithJTANotAllowed() - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
entityType - Variable in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
The type being configured for dynamic use or being created/extended
entityTypeNotFound - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
entityTypeNotFound(String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
JPQLException Entity Type Not Found
entityTypeNotFound2 - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
entityTypeNotFound2(String, int, int, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
entrySet() - Method in class org.eclipse.persistence.indirection.IndirectMap
 
entrySet() - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Returns a collection view of the mappings contained in this IdentityWeakHashMap.
entrySet() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
entrySet() - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
Unmodifiable set of entries
entrySet() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Returns a set of the keys.
entrySet() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
PUBLIC:
entrySet() - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Returns a set of the keys.
EntrySet() - Constructor for class org.eclipse.persistence.internal.sessions.AbstractRecord.EntrySet
Default constructor.
EntrySet() - Constructor for class org.eclipse.persistence.queries.ReportQueryResult.EntrySet
 
ENUM_CLASS_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
ENUM_CONSTANT_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
enumClassNotSpecified() - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
enumConstantNotFound(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception is thrown if the user tries to get a non-existant enum constant from an enum class.
Enumeration_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
EnumInfo(String) - Constructor for class org.eclipse.persistence.dynamic.DynamicClassLoader.EnumInfo
 
enumInfoRegistry - Variable in class org.eclipse.persistence.dynamic.DynamicClassLoader
 
EnumTypeConverter - Class in org.eclipse.persistence.mappings.converters
Purpose: Object type converter is used to match a fixed number of database data values to a Java enum object value.
EnumTypeConverter(DatabaseMapping, Class<?>, boolean) - Constructor for class org.eclipse.persistence.mappings.converters.EnumTypeConverter
PUBLIC: Creating an enum converter this way will create the conversion values for you using ordinal or name values.
EnumTypeConverter(DatabaseMapping, String) - Constructor for class org.eclipse.persistence.mappings.converters.EnumTypeConverter
PUBLIC: Creating an enum converter this way expects that you will provide the conversion values separately.
EnumTypeConverter(DatabaseMapping, String, boolean) - Constructor for class org.eclipse.persistence.mappings.converters.EnumTypeConverter
PUBLIC: Creating an enum converter this way will create the conversion values for you using ordinal or name values.
equal() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
 
equal(boolean) - Method in class org.eclipse.persistence.expressions.Expression
 
equal(byte) - Method in class org.eclipse.persistence.expressions.Expression
 
equal(char) - Method in class org.eclipse.persistence.expressions.Expression
 
equal(double) - Method in class org.eclipse.persistence.expressions.Expression
 
equal(float) - Method in class org.eclipse.persistence.expressions.Expression
 
equal(int) - Method in class org.eclipse.persistence.expressions.Expression
 
equal(long) - Method in class org.eclipse.persistence.expressions.Expression
 
equal(short) - Method in class org.eclipse.persistence.expressions.Expression
 
equal(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receiver's value is equal to the other value.
equal(Expression) - Method in class org.eclipse.persistence.expressions.Expression
Returns an expression that compares if the receiver's value is equal to the other value.
Equal - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
Comparison operators
equalNameAndSize(Sequence, Sequence) - Static method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: Used in equals.
equalNamespaceResolvers - Variable in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
equalNamespaceResolvers - Variable in class org.eclipse.persistence.oxm.record.XMLRecord
 
equalOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
DB2 z/OS requires that at least one argument be a known type
equalOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
equalOuterJoin() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Initialize the outer join operator Note: This is merely a shell which is incomplete, and so will be replaced by the platform's operator when we go to print.
equalOuterJoin(Object) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Return an expression representing an outer join comparison
equalOuterJoin(Expression) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Return an expression representing an outer join comparison
EqualOuterJoin - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
equals(Object) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
equals(Object) - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
equals(Object) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
equals(Object) - Method in class org.eclipse.persistence.eis.EISSequence
 
equals(Object) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Return if the operator is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.history.AsOfClause
INTERNAL: Return if the as of is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.indirection.IndirectList
 
equals(Object) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
equals(Object) - Method in class org.eclipse.persistence.indirection.IndirectSet
 
equals(Object) - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
equals(Object) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
equals(Object) - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeMethodInfo
 
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.ManualQueryKeyExpression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.TableExpression
INTERNAL: Return if the expression is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
equals(Object) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Determine whether the receiver is equal to a DatabaseField.
equals(Object) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Two tables are equal if their names and tables are equal, or their names are equal and one does not have a qualifier assigned.
equals(Object) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
equals(Object) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
equals(Object) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
equals(Object) - Method in class org.eclipse.persistence.internal.helper.type.ReadLockAcquisitionMetadata
 
equals(Object) - Method in class org.eclipse.persistence.internal.identitymaps.CacheId
Determine if the receiver is equal to anObject.
equals(Object) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Determine if the receiver is equal to anObject.
equals(Object) - Method in class org.eclipse.persistence.internal.oxm.Root
 
equals(Object) - Method in class org.eclipse.persistence.internal.oxm.WeakObjectWrapper
 
equals(Object) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
equals(Object) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
equals(Object) - Method in class org.eclipse.persistence.internal.oxm.XPathPredicate
 
equals(Object) - Method in class org.eclipse.persistence.internal.oxm.XPathQName
 
equals(Object) - Method in class org.eclipse.persistence.internal.queries.AttributeItem
 
equals(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return if the policy is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Return if the policy is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordEntry
 
equals(Object) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord.NULL
 
equals(Object) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Ensure change sets with the same primary key are equal.
equals(Object) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Only the id is checked for equality check.
equals(Object) - Method in class org.eclipse.persistence.oxm.XMLField
 
equals(Object) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return if the query is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Return if the query is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Return if the query is equal to the other.
equals(Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Compare if the two results are equal.
equals(Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult.RecordEntry
 
equals(Object) - Method in class org.eclipse.persistence.sequencing.DefaultSequence
 
equals(Object) - Method in class org.eclipse.persistence.sequencing.NativeSequence
 
equals(Object) - Method in class org.eclipse.persistence.sequencing.QuerySequence
 
equals(Object) - Method in class org.eclipse.persistence.sequencing.Sequence
 
equals(Object) - Method in class org.eclipse.persistence.sequencing.TableSequence
 
equals(Object) - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
equals(Object) - Method in class org.eclipse.persistence.sequencing.UUIDSequence
 
equals(Object) - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
 
equals(Object, boolean) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
equals(DatabaseField) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Determine whether the receiver is equal to a DatabaseField.
equals(DatabaseTable) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Two tables are equal if their names and tables are equal, or their names are equal and one does not have a qualifier assigned.
equals(CacheId) - Method in class org.eclipse.persistence.internal.identitymaps.CacheId
Determine if the receiver is equal to key.
equals(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Determine if the receiver is equal to key.
equals(CacheKey) - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
equals(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Ensure change sets with the same primary key are equal.
equals(ReportQueryResult) - Method in class org.eclipse.persistence.queries.ReportQueryResult
INTERNAL: Used in testing to compare if results are correct.
equalsIgnoreCase(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receiver's value is equal to the other value, ignoring case.
equalsIgnoreCase(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receiver's value is equal to the other value, ignoring case.
error(SAXParseException) - Method in class org.eclipse.persistence.platform.xml.DefaultErrorHandler
 
error(SAXParseException) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader.XMLSessionConfigLoaderErrorHandler
 
ERROR - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
ERROR_ACCESSING_EXTERNALIZABLEDELEGATOR - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_BEGINNING_TRANSACTION - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_BINDING_CONNECTION - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_BINDING_TO_TRANSACTION - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_CLOSING_PERSISTENCE_XML - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ERROR_COMMITTING_TRANSACTION - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_CREATE_URL - Static variable in exception org.eclipse.persistence.exceptions.XMLConversionException
 
ERROR_CREATING_DATAOBJECT_FOR_CLASS - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_CREATING_DATAOBJECT_FOR_TYPE - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_CREATING_DYNAMICJAXBCONTEXT - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
ERROR_CREATING_FIELD_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
ERROR_CREATING_INITIAL_CONTEXT - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_CREATING_JGROUPS_CONNECTION - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_CREATING_JMS_CONNECTION - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_CREATING_LOCAL_JMS_CONNECTION - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_CREATING_PROPERTY_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
ERROR_DECRYPTING_PASSWORD - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ERROR_DEFINING_PROPERTY_INVALID_NAME - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_DEFINING_TYPE - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_DEFINING_TYPE_INVALID_NAME - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_DEFINING_TYPE_NO_NAME - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_DESERIALIZE_REMOTE_COMMAND - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_DISCOVERING_IP_ADDRESS - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_DOING_JNDI_LOOKUP - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_ENCRYPTING_PASSWORD - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ERROR_GETTING_HOST_NAME - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_GETTING_OBJECTNAME - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_GETTING_SERVERPLATFORM - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_GETTING_TRANSACTION - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_GETTING_TRANSACTION_STATUS - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_IN_INVOCATION - Static variable in exception org.eclipse.persistence.exceptions.CommunicationException
 
ERROR_IN_SESSION_XML - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ERROR_IN_SETUP_OF_EM - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
ERROR_INACTIVE_UOW - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_INIT_CORBA - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_INSTANTIATING_ACCESSOR_FACTORY - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
ERROR_INSTANTIATING_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ERROR_INSTANTIATING_CLASS_FOR_QUERY_HINT - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
ERROR_INSTANTIATING_CONVERSION_VALUE_DATA - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ERROR_INSTANTIATING_CONVERSION_VALUE_OBJECT - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ERROR_INSTANTIATING_SCHEMA_PLATFORM - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
ERROR_INSTANTIATING_UNMAPPED_CONTENTHANDLER - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
ERROR_INVALID_DOCUMENT - Static variable in exception org.eclipse.persistence.exceptions.JSONException
 
ERROR_INVOKING_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
ERROR_INVOKING_CHARACTER_ESCAPE_HANDLER - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
ERROR_INVOKING_ID_RESOLVER - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
ERROR_INVOKING_NAMESPACE_PREFIX_MAPPER - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
ERROR_JOINING_MULTICAST_GROUP - Static variable in exception org.eclipse.persistence.exceptions.DiscoveryException
 
ERROR_LOOKING_UP_LOCAL_HOST - Static variable in exception org.eclipse.persistence.exceptions.DiscoveryException
 
ERROR_LOOKING_UP_REMOTE_CONNECTION - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_MAKING_WLS_REFLECTIVE_CALL - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_MARKING_TRANSACTION_FOR_ROLLBACK - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_NO_ENTITY_TRANSACTION_ACTIVE - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_NO_EXTERNAL_TRANSACTION_ACTIVE - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_NO_TRANSACTION_ACTIVE - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_OBTAINING_CONTEXT_FOR_JNDI - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_OBTAINING_TRANSACTION_MANAGER - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_OBTAINING_TSR - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_OCCURED_IN_AMENDMENT_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ERROR_PARSING_MAPPING_FILE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ERROR_PERFORMING_WLS_LOOKUP - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_PREALLOCATING_SEQUENCE_NUMBERS - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
ERROR_PROCESSING_CHARACTER_ESCAPE_HANDLER - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
ERROR_PROCESSING_ID_RESOLVER - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
ERROR_PROCESSING_IMPORT - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_PROCESSING_INCLUDE - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_PROCESSING_NAMED_QUERY - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ERROR_PROCESSING_PREFIX_MAPPER - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
ERROR_PROCESSING_REMOTE_COMMAND - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_PROCESSING_XPATH - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_PROPAGATING_COMMAND - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_READING_BLOB_DATA - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
ERROR_RECEIVED_JMS_MESSAGE_IS_NULL - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_RECEIVING_ANNOUNCEMENT - Static variable in exception org.eclipse.persistence.exceptions.DiscoveryException
 
ERROR_RECEIVING_JMS_MESSAGE - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_RESOLVING_ENTITY - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ERROR_RESOLVING_XML_SCHEMA - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
ERROR_RETRIEVE_DB_METADATA_THROUGH_JDBC_CONNECTION - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
ERROR_ROLLING_BACK_TRANSACTION - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_SENDING_ANNOUNCEMENT - Static variable in exception org.eclipse.persistence.exceptions.DiscoveryException
 
ERROR_SENDING_CONNECTION_SERVICE - Static variable in exception org.eclipse.persistence.exceptions.CommunicationException
PUBLIC: Creates a CommunicationException.
ERROR_SENDING_MESSAGE - Static variable in exception org.eclipse.persistence.exceptions.CommunicationException
 
ERROR_SERIALIZE_OR_DESERIALIZE_COMMAND - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
ERROR_SETTING_SCHEMAS - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
ERROR_TRANSACTION_IS_ACTIVE - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
ERROR_UNBINDING_LOCAL_CONNECTION - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorAccessingExternalizableDelegator(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL:
errorAccessingSetMethodOfEntity(Class<?>, String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
errorBeginningExternalTransaction(Exception) - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
errorBindingConnection(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorBindingToExternalTransaction(Exception) - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
errorClosingPersistenceXML(Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
errorCode - Variable in exception org.eclipse.persistence.exceptions.EclipseLinkException
 
errorCommittingExternalTransaction(Exception) - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
errorCreateURLForFile(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.XMLConversionException
 
errorCreatingDataObjectForClass(Exception, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to create a dataObject with a type with the given interface
errorCreatingDataObjectForType(String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to create a dataObject with a type with the given uri and name
errorCreatingDynamicJAXBContext(Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This is a general exception, thrown if a problem was encountered during DynamicJAXBContext creation.
errorCreatingFieldAccessor(Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
errorCreatingJGroupsConnection(String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorCreatingJMSConnection(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorCreatingLocalJMSConnection(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorCreatingPropertyAccessor(Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
errorCreatingWLSInitialContext(Exception) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when acquiring the SDOHelperContext cache key for WLS.
errorDecryptingPassword(Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
errorDefiningPropertyInvalidName(String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to create a type with property of invalid name.
errorDefiningType() - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to define a type
errorDefiningTypeInvalidName(String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to create a type with invalid name.
errorDefiningTypeNoName() - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to create a type without a name
errorDeserializeRemoteCommand(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorDiscoveringLocalHostIPAddress(Exception) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorEncryptingPassword(Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
errorGettingExternalTransaction(Exception) - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
errorGettingExternalTransactionStatus(Exception) - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
errorGettingHostName(Exception) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorGettingServerPlatform() - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorGettingWLSObjectName(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when acquiring the SDOHelperContext cache key for WLS.
errorInInvocation(Exception) - Static method in exception org.eclipse.persistence.exceptions.CommunicationException
 
errorInitCorba(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorInSessionsXML(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: The session named "name" could not be found in the Sessions.XML
errorInSetupOfEM() - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
errorInstantiatedClassForQueryHint(Exception, DatabaseQuery, Class<?>, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
errorInstantiatingAccessorFactory(Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: An exception occured while trying to instantiate an instance of the user specified AccessorFactory
errorInstantiatingClass(Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
errorInstantiatingConversionValueData(String, String, Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
errorInstantiatingConversionValueObject(String, String, Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
errorInstantiatingSchemaPlatform(Exception) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
errorInstantiatingUnmappedContentHandler(Exception, String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
errorInvalidDocument(Exception) - Static method in exception org.eclipse.persistence.exceptions.JSONException
 
errorInvokingAccessor(Object, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
errorInvokingCharacterEscapeHandler(String, Object, Throwable) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
errorInvokingFromStringMethod(Exception, String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
errorInvokingIDResolver(String, Object, Throwable) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
errorInvokingPrefixMapperMethod(String, Object) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
errorInvokingWLSMethodReflectively(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when acquiring the SDOHelperContext cache key for WLS.
errorJMSMessageIsNull() - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorJoiningMulticastGroup(Exception) - Static method in exception org.eclipse.persistence.exceptions.DiscoveryException
 
errorLookingUpLocalHost(Exception) - Static method in exception org.eclipse.persistence.exceptions.DiscoveryException
 
errorLookingUpRemoteConnection(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorMarkingTransactionForRollback(Exception) - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
errorObtainingContext(Exception) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorObtainingTransactionManager(Exception) - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
errorObtainingTsr(Exception) - Static method in exception org.eclipse.persistence.exceptions.TransactionException
Build transaction exception instance when obtaining of TransactionSynchronizationRegistry instance failed.
errorOccuredInAmendmentMethod(Class<?>, String, Exception, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
errorParsingMappingFile(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
errorPerformingWLSLookup(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when acquiring the SDOHelperContext cache key for WLS.
errorPreallocatingSequenceNumbers() - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
errorProcessingCharacterEscapeHandler(String, Object, Throwable) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
errorProcessingIDResolver(String, Object, Throwable) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
errorProcessingImport(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when processing an import during xsdhelper.define
errorProcessingInclude(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when processing an include during xsdhelper.define
errorProcessingNamedQuery(Object, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
errorProcessingPrefixMapper(String, Object) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
errorProcessingRemoteCommand(String, String, String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorProcessingXPath(String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception processing an xpath during xmlhelper.load
errorReadingBlobData() - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
errorReceivingAnnouncement(Exception) - Static method in exception org.eclipse.persistence.exceptions.DiscoveryException
 
errorReceivingJMSMessage(Exception) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorResolvingSchema(Exception) - Static method in exception org.eclipse.persistence.exceptions.SDOException
 
errorResolvingXMLSchema(Exception) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
errorRetrieveDbMetadataThroughJDBCConnection() - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
errorRollingBackExternalTransaction(Exception) - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
errorSendingAnnouncement(Exception) - Static method in exception org.eclipse.persistence.exceptions.DiscoveryException
 
errorSendingConnectionService(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.CommunicationException
 
errorSendingMessage(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.CommunicationException
 
errorSerializeOrDeserialzeCommand(Exception) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorSettingSchemas(Exception, Object[]) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
errorUnbindingLocalConnection(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
errorUsingPrimaryKey(Object, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
escape(char[], int, int, boolean, Writer) - Method in interface org.eclipse.persistence.internal.oxm.CharacterEscapeHandler
Perform character escaping and write the result to the output.
escape(char[], int, int, boolean, Writer) - Method in class org.eclipse.persistence.internal.oxm.record.CharacterEscapeHandlerWrapper
 
escape(char[], int, int, boolean, Writer) - Method in interface org.eclipse.persistence.oxm.CharacterEscapeHandler
Perform character escaping and write the result to the output.
EVENT - org.eclipse.persistence.logging.LogCategory
 
EVENT - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
eventCode - Variable in class org.eclipse.persistence.descriptors.DescriptorEvent
The code of the descriptor event being raised.
eventCode - Variable in class org.eclipse.persistence.sessions.SessionEvent
The code of the event being raised.
eventListeners - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
eventManager - Variable in class org.eclipse.persistence.core.descriptors.CoreDescriptor
 
eventManager - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Stores the event listeners for this session.
eventMethods - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
eventNames - Static variable in class org.eclipse.persistence.descriptors.DescriptorEvent
Event names for toString()
eventSelectors - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
EXAMPLE_AND_REFERENCE_OBJECT_CLASS_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
exampleAndReferenceObjectClassMismatch(Class<?>, Class<?>, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
Oct 18, 2000 JED Added this method and exception value
exampleObject - Variable in class org.eclipse.persistence.internal.queries.QueryByExampleMechanism
Used for Query By Example.
except() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the EXCEPT operator.
except(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a except expression with the subquery.
except(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a except expression with the subquery.
except(ReportQuery) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Except the query results with the other query.
Except - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
exceptAll() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the EXCEPT ALL operator.
exceptAll(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a except all expression with the subquery.
exceptAll(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a except all expression with the subquery.
ExceptAll - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
exception - Variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
exception - Variable in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Used to throw exception that occur from the concurrent population thread.
Exception - Static variable in class org.eclipse.persistence.config.CacheUsageIndirectionPolicy
If conforming encounters an uninstantiated indirection/lazy object an exception is thrown.
EXCEPTION - org.eclipse.persistence.annotations.OrderCorrectionType
Don't correct, throw QueryException with error code QueryException.LIST_ORDER_FIELD_WRONG_VALUE Example: a list of three objects: in the data base: {null, objectA}; {2, objectB}, {5, ObjectC}; read into application - exception.
EXCEPTION_ACCESSING_PRIMARY_KEY_INSTANCE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
EXCEPTION_BUILDING_PERSISTENCE_UNIT_NAME - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
EXCEPTION_CONFIGURING_EM_FACTORY - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EXCEPTION_CREATING_ARCHIVE_FACTORY - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
EXCEPTION_CREATING_DOCUMENT_BUILDER - Static variable in exception org.eclipse.persistence.exceptions.XMLParseException
 
EXCEPTION_CREATING_SAX_PARSER - Static variable in exception org.eclipse.persistence.exceptions.XMLParseException
 
EXCEPTION_CREATING_XML_READER - Static variable in exception org.eclipse.persistence.exceptions.XMLParseException
 
EXCEPTION_DURING_NAME_TRANSFORMATION - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
EXCEPTION_DURING_SCHEMA_GEN - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
EXCEPTION_FOR_ILLEGALE_LOGGING_LEVEL - Static variable in exception org.eclipse.persistence.exceptions.StaticWeaveException
 
EXCEPTION_HANDLER_CLASS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.exception-handler" property allows an ExceptionHandler to be specified.
EXCEPTION_IN_PROXY_EXECUTION - Static variable in exception org.eclipse.persistence.exceptions.TransactionException
 
EXCEPTION_IN_SETUP_OF_EM - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
EXCEPTION_LOADING_CLASS - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
EXCEPTION_LOADING_FROM_DIRECTORY - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
EXCEPTION_LOADING_FROM_JAR - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
EXCEPTION_LOADING_FROM_URL - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
EXCEPTION_LOADING_VALIDATION_GROUP_CLASS - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
EXCEPTION_NO_SOURCE_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.StaticWeaveException
 
EXCEPTION_NO_SUPPORT_WEAVING_INPLACE_FOR_JAR - Static variable in exception org.eclipse.persistence.exceptions.StaticWeaveException
 
EXCEPTION_NO_TARGET_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.StaticWeaveException
 
EXCEPTION_OBTAINING_REQUIRED_BEAN_VALIDATOR_FACTORY - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
EXCEPTION_OPEN_LOGGING_FILE - Static variable in exception org.eclipse.persistence.exceptions.StaticWeaveException
 
EXCEPTION_OPENING_ORM_XML - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
EXCEPTION_OPENNING_ARCHIVE - Static variable in exception org.eclipse.persistence.exceptions.StaticWeaveException
 
EXCEPTION_PROCESSING_PERSISTENCE_UNIT - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
EXCEPTION_PROCESSING_PERSISTENCE_XML - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
EXCEPTION_READING_XML_DOCUMENT - Static variable in exception org.eclipse.persistence.exceptions.XMLParseException
 
EXCEPTION_SEARCHING_FOR_ENTITIES - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
EXCEPTION_SEARCHING_FOR_PERSISTENCE_RESOURCES - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
EXCEPTION_SETTING_SCHEMA_SOURCE - Static variable in exception org.eclipse.persistence.exceptions.XMLParseException
 
EXCEPTION_WEAVING - Static variable in exception org.eclipse.persistence.exceptions.StaticWeaveException
 
EXCEPTION_WHILE_LOADING_CONSTRUCTOR - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
EXCEPTION_WHILE_READING_MAP_KEY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
EXCEPTION_WHILE_USING_CONSTRUCTOR_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
EXCEPTION_WITH_NAME_TRANSFORMER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
exceptionAccessingPrimaryKeyInstance(ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
exceptionConfiguringEMFactory(Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
exceptionCreatingArchiveFactory(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
exceptionCreatingDocumentBuilder(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.XMLParseException
INTERNAL:
exceptionCreatingSAXParser(URL, Exception) - Static method in exception org.eclipse.persistence.exceptions.XMLParseException
INTERNAL:
exceptionCreatingXMLReader(URL, Exception) - Static method in exception org.eclipse.persistence.exceptions.XMLParseException
INTERNAL:
exceptionDuringNameTransformation(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: An exception occurred during transformation to an xml name
exceptionDuringSchemaGeneration(Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: An exception occurred during schema generation.
exceptionHandler - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
ExceptionHandler handles database exceptions.
exceptionHandler - Variable in class org.eclipse.persistence.transaction.AbstractTransactionController
Allow exception in before/after completion to be wrapped.
ExceptionHandler - Interface in org.eclipse.persistence.exceptions
Exception handler can catch errors that occur on queries or during database access.
exceptionInSetupOfEM(Exception) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
exceptionLoadingClassWhileInitializingValidationGroups(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
exceptionLoadingClassWhileLookingForAnnotations(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
exceptionLoadingFromDirectory(File, Exception) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
exceptionLoadingFromJar(URL, Exception) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
exceptionLoadingFromUrl(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
exceptionLoadingORMXML(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
ExceptionLocalization - Class in org.eclipse.persistence.internal.localization
Purpose: This is for non EclipseLink exceptions
ExceptionLocalization() - Constructor for class org.eclipse.persistence.internal.localization.ExceptionLocalization
 
ExceptionMessageGenerator - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: Utility class to generate exception messages using ResourceBundles.
exceptionObtainingRequiredBeanValidatorFactory(Throwable) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
exceptionOpeningArchive(URL, Exception) - Static method in exception org.eclipse.persistence.exceptions.StaticWeaveException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
exceptionPerformWeaving(Exception, Object) - Static method in exception org.eclipse.persistence.exceptions.StaticWeaveException
 
exceptionProcessingPersistenceUnit(URL, Exception) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
exceptionProcessingPersistenceXML(URL, Exception) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
exceptionReadingXMLDocument(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.XMLParseException
INTERNAL:
ExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for EclipseLinkException messages.
ExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.ExceptionResource
Default constructor.
exceptions - Variable in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
exceptionSearchingForEntities(URL, Exception) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
exceptionSearchingForPersistenceResources(ClassLoader, Exception) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
exceptionsEqual(MethodDefinition) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
exceptionSettingSchemaSource(URL, URL, Exception) - Static method in exception org.eclipse.persistence.exceptions.XMLParseException
INTERNAL:
exceptionStore - Variable in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
Stores any exceptions that occurred to provide all the exceptions up front if the load fails.
exceptionWhileInitializingConstructor(Exception, DatabaseQuery, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.QueryException
An exception was thrown while initializing the constructor from the class.
exceptionWhileReadingMapKey(Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
exceptionWhileUsingConstructorExpression(Exception, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
An exception was throwing while using a ReportQuery with a constructor expression
exceptionWithNameTransformerClass(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: An exception occurred while attempting to get a new instance of the transformer class.
exceptOperator() - Static method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Create the EXCEPT operator, MINUS in Oracle.
EXCESSIVE_PRIMARY_KEY_JOIN_COLUMNS_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
excessivePrimaryKeyJoinColumnsSpecified(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
EXCLUDE_ECLIPSELINK_ORM_FILE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.exclude-eclipselink-orm" property configures the exclusion of an EclipseLink ORM mapping file for a specific persistence unit.
excludeDefaultListeners - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
excludeDefaultListeners() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: EJB 3.0 support.
ExcludeDefaultMappings - Annotation Type in org.eclipse.persistence.annotations
Specifies default mappings (those that are not explicitly decorated in XML or using annotations)should be omitted.
excludeDefaultPrimitiveValues() - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: Ignores attributes set to the default value for their primitive type.
excludeSuperclassListeners - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
excludeSuperclassListeners() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: EJB 3.0 support.
excludeValue(boolean) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: An attribute in the example object set to an excluded value will be ignored in a Query By Example.
excludeValue(byte) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: An attribute in the example object set to an excluded value will be ignored in a Query By Example.
excludeValue(char) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: An attribute in the example object set to an excluded value will be ignored in a Query By Example.
excludeValue(double) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: An attribute in the example object set to an excluded value will be ignored in a Query By Example.
excludeValue(float) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: An attribute in the example object set to an excluded value will be ignored in a Query By Example.
excludeValue(int) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: An attribute in the example object set to be an excluded value will be ignored in a Query By Example.
excludeValue(long) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: An attribute in the example object set to an excluded value will be ignored in a Query By Example.
excludeValue(short) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: An attribute in the example object set to an excluded value will be ignored in a Query By Example.
excludeValue(Object) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: An attribute in the example object set to an excluded value will be ignored in a Query By Example.
EXCLUSIVE_CONNECTION - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.exclusive-connection"
EXCLUSIVE_CONNECTION_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
EXCLUSIVE_CONNECTION_IS_LAZY - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
Determines when write connection is acquired lazily.
EXCLUSIVE_CONNECTION_IS_LAZY - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jdbc.exclusive-connection.is-lazy" property specifies when write connection is acquired lazily.
EXCLUSIVE_CONNECTION_MODE - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
Determines when reads are performed through the write connection.
EXCLUSIVE_CONNECTION_MODE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jdbc.exclusive-connection.mode" property specifies when reads are performed through the write connection.
You can set this property while creating either an EntityManagerFactory (either in the map passed to the createEntityManagerFactory method, or in the persistence.xml file), or an EntityManager (in the map passed to the createEntityManager method).
EXCLUSIVE_CONNECTION_NO_LONGER_AVAILABLE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
EXCLUSIVE_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
ExclusiveConnectionMode - Class in org.eclipse.persistence.config
This property could be specified while creating either EntityManagerFactory (createEntityManagerFactory or persistence.xml) or EntityManager (createEntityManager); the latter overrides the former.
ExclusiveConnectionMode() - Constructor for class org.eclipse.persistence.config.ExclusiveConnectionMode
 
ExclusiveIsolatedClientSession - Class in org.eclipse.persistence.internal.sessions
 
ExclusiveIsolatedClientSession(ServerSession, ConnectionPolicy) - Constructor for class org.eclipse.persistence.internal.sessions.ExclusiveIsolatedClientSession
 
ExclusiveIsolatedClientSession(ServerSession, ConnectionPolicy, Map) - Constructor for class org.eclipse.persistence.internal.sessions.ExclusiveIsolatedClientSession
 
exclusiveMode - Variable in class org.eclipse.persistence.sessions.server.ConnectionPolicy
This attribute is used by the ServerSession to determine if a client session with an exclusive connection should be built and how the exclusive connection should be used.
excusiveConnectionIsNoLongerAvailable(DatabaseQuery, AbstractSession) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
execute() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: This can be used by collection such as cursored stream to gain control over execution.
execute() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Execute a execute SQL call.
execute() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
INTERNAL: Execute a call.
execute() - Method in class org.eclipse.persistence.queries.CursoredStreamPolicy
INTERNAL: Execute the cursored select and build the stream.
execute() - Method in class org.eclipse.persistence.queries.CursorPolicy
INTERNAL: Execute the cursored select and build the stream.
execute() - Method in class org.eclipse.persistence.queries.ScrollableCursorPolicy
INTERNAL: Execute the cursored select and build the stream.
execute(DatabaseCall, Statement, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Execute the statement.
execute(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.remote.SequencingFunctionCall.DoesExist
 
execute(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.remote.SequencingFunctionCall.GetNextValue
 
execute(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.remote.SequencingFunctionCall.WhenShouldAcquireValueForAll
 
execute(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.remote.SimpleFunctionCall
PROTECTED: Convenience method
execute(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Execute the query.
execute(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.DataReadQuery
INTERNAL: Execute the query.
execute(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Execute the query.
execute(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Execute the query.
execute(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Execute the query.
execute(AbstractSession, RemoteSessionController) - Method in interface org.eclipse.persistence.internal.sessions.remote.RemoteCommand
INTERNAL: This method is used bye the remote Session to execute the command
execute(AbstractSession, RemoteSessionController) - Method in interface org.eclipse.persistence.internal.sessions.remote.RemoteFunctionCall
INTERNAL: This method is used by the remote session controller to execute the function call
execute(AbstractSession, RemoteSessionController) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoveServerSideRemoteValueHolderCommand
INTERNAL: This method is used bye the remote Session to execute the command
execute(AbstractSession, RemoteSessionController) - Method in class org.eclipse.persistence.internal.sessions.remote.SimpleFunctionCall
INTERNAL: This method is used by remote session controller to execute the function call
EXECUTE_UPDATE - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
executeBatch(Statement, boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Internal: This gets called on each batch statement execution Needs to be implemented so that it returns the number of rows successfully modified by this statement for optimistic locking purposes.
executeBatch(Statement, boolean) - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
executeBatchedStatement(PreparedStatement, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Execute the EclipseLink dynamically batched/concatenated statement.
executeBatchedStatements(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
INTERNAL: This method is used by the DatabaseAccessor to clear the batched statements in the case that a non batchable statement is being execute
executeBatchedStatements(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DynamicSQLBatchWritingMechanism
INTERNAL: This method is used by the DatabaseAccessor to execute and clear the batched statements in the case that a non batchable statement is being executed
executeBatchedStatements(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
INTERNAL: This method is used by the DatabaseAccessor to clear the batched statements in the case that a non batchable statement is being executed
executeBatchQuery(DatabaseQuery, CacheKey, Map, AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Prepare and execute the batch query and store the results for each source object in a map keyed by the mappings source keys of the source objects.
executeBatchQuery(DatabaseQuery, CacheKey, Map, AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Prepare and execute the batch query and store the results for each source object in a map keyed by the mappings source keys of the source objects.
executeBatchQuery(DatabaseQuery, CacheKey, Map, AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Prepare and execute the batch query and store the results for each source object in a map keyed by the mappings source keys of the source objects.
executeBatchQuery(DatabaseQuery, CacheKey, Map, AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Prepare and execute the batch query and store the results for each source object in a map keyed by the mappings source keys of the source objects.
executeBatchQuery(DatabaseQuery, CacheKey, Map, AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Prepare and execute the batch query and store the results for each source object in a map keyed by the mappings source keys of the source objects.
executeCall() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Execute the call.
executeCall(DatasourceCall) - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Execute the call.
executeCall(Call, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.eis.EISAccessor
Avoid super to have logging occur after possible manual auto-commit.
executeCall(Call, AbstractRecord, AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Execute the call.
executeCall(Call, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Execute the call.
executeCall(Call, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Execute the call.
executeCall(Call, AbstractRecord, DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Overridden by subclasses that do more than just execute the call.
executeCall(Call, AbstractRecord, DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Override From session.
executeCall(Call, AbstractRecord, DatabaseQuery) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Execute the call on the correct connection accessor.
executeCall(Call, AbstractRecord, DatabaseQuery) - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Execute the call on the correct connection accessor.
executeCommand(byte[]) - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: Publish the remote command.
executeCommand(byte[]) - Method in class org.eclipse.persistence.internal.sessions.coordination.RemoteConnection
INTERNAL: Execute the remote command.
executeCommand(byte[]) - Method in interface org.eclipse.persistence.internal.sessions.coordination.rmi.RMIRemoteCommandConnection
TODO
executeCommand(byte[]) - Method in class org.eclipse.persistence.internal.sessions.coordination.rmi.RMIRemoteCommandConnectionImpl
INTERNAL: No support currently exists for returning the result of the command execution.
executeCommand(byte[]) - Method in class org.eclipse.persistence.internal.sessions.coordination.rmi.RMIRemoteConnection
INTERNAL: This method invokes the remote object with the Command argument, and causes it to execute the command in the remote VM.
executeCommand(Command) - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: Publish the remote command.
executeCommand(Command) - Method in class org.eclipse.persistence.internal.sessions.coordination.RemoteConnection
INTERNAL: Execute the remote command.
executeCommand(Command) - Method in interface org.eclipse.persistence.internal.sessions.coordination.rmi.RMIRemoteCommandConnection
TODO
executeCommand(Command) - Method in class org.eclipse.persistence.internal.sessions.coordination.rmi.RMIRemoteCommandConnectionImpl
INTERNAL: No support currently exists for returning the result of the command execution.
executeCommand(Command) - Method in class org.eclipse.persistence.internal.sessions.coordination.rmi.RMIRemoteConnection
INTERNAL: This method invokes the remote object with the Command argument, and causes it to execute the command in the remote VM.
executeCommandInternal(Object) - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: Publish the remote command.
executeCommandInternal(Object) - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: Execute the remote command.
executeCommit() - Method in class org.eclipse.persistence.queries.InsertObjectQuery
INTERNAL: Perform an insert.
executeCommit() - Method in class org.eclipse.persistence.queries.UpdateObjectQuery
INTERNAL: Perform an update.
executeCommit() - Method in class org.eclipse.persistence.queries.WriteObjectQuery
INTERNAL: Perform a does exist check to decide whether to perform an insert or update and delegate the work to the mechanism.
executeCommitWithChangeSet() - Method in class org.eclipse.persistence.queries.InsertObjectQuery
INTERNAL: Perform an insert.
executeCommitWithChangeSet() - Method in class org.eclipse.persistence.queries.UpdateObjectQuery
INTERNAL: Perform an update.
executeCommitWithChangeSet() - Method in class org.eclipse.persistence.queries.WriteObjectQuery
INTERNAL: Perform a does exist check to decide whether to perform an insert or update and delegate the work to the mechanism.
executeDatabaseQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Execute the query
executeDatabaseQuery() - Method in class org.eclipse.persistence.queries.DataModifyQuery
INTERNAL: Perform the work to execute the SQL call.
executeDatabaseQuery() - Method in class org.eclipse.persistence.queries.DataReadQuery
INTERNAL: Execute the query.
executeDatabaseQuery() - Method in class org.eclipse.persistence.queries.DeleteAllQuery
INTERNAL: Perform the work to delete a collection of objects.
executeDatabaseQuery() - Method in class org.eclipse.persistence.queries.DeleteObjectQuery
INTERNAL: Perform the work to delete an object.
executeDatabaseQuery() - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Return if the object exists on the database.
executeDatabaseQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Executes the prepared query on the datastore.
executeDatabaseQuery() - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Execute the query.
executeDatabaseQuery() - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
INTERNAL: Executes the prepared query on the datastore.
executeDatabaseQuery() - Method in class org.eclipse.persistence.queries.UpdateAllQuery
INTERNAL: Issue the SQL to the database and then merge into the cache.
executeDatabaseQuery() - Method in class org.eclipse.persistence.queries.WriteObjectQuery
INTERNAL: Perform a does exist check to decide whether to perform an insert or update and delegate the work to the mechanism.
executeDeferredCall(DatasourceCall) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Execute the call that was deferred to the commit manager.
executeDeferredCall(DatasourceCall) - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Execute the call that was deferred to the commit manager.
executeDeferredEvents() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Causes any deferred events to be fired.
executeDeleteAll(AbstractSession, AbstractRecord, Vector) - Method in class org.eclipse.persistence.queries.DeleteAllQuery
INTERNAL: Delete all queries are executed specially to avoid cloning and ensure preparing.
executeDirectNoSelect(Statement, DatabaseCall, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Execute the statement.
executeEvent(int, ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Execute a descriptor event for the specified event code.
executeEvent(int, ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Execute a descriptor event for the specified event code.
executeEvent(DESCRIPTOR_EVENT) - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptorEventManager
 
executeEvent(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: Execute the given selector with the event as argument.
executeInUnitOfWork(UnitOfWorkImpl, AbstractRecord) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Override query execution where Session is a UnitOfWork.
executeInUnitOfWork(UnitOfWorkImpl, AbstractRecord) - Method in class org.eclipse.persistence.queries.DeleteAllQuery
INTERNAL: This method has to be broken.
executeInUnitOfWork(UnitOfWorkImpl, AbstractRecord) - Method in class org.eclipse.persistence.queries.ModifyAllQuery
INTERNAL: Override query execution where Session is a UnitOfWork.
executeInUnitOfWork(UnitOfWorkImpl, AbstractRecord) - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
INTERNAL: All have done is move code from UnitOfWork.internalExecuteQuery
executeInUnitOfWork(UnitOfWorkImpl, AbstractRecord) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Execute the query in the unit of work.
executeInUnitOfWorkObjectLevelModifyQuery(UnitOfWorkImpl, AbstractRecord) - Method in class org.eclipse.persistence.queries.DeleteObjectQuery
INTERNAL: Code was moved from UnitOfWork.internalExecuteQuery
executeInUnitOfWorkObjectLevelModifyQuery(UnitOfWorkImpl, AbstractRecord) - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
INTERNAL: This code was moved from UnitOfWork.internalExecuteQuery.
executeJDK12BatchStatement(Statement, DatabaseCall, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Execute the batched statement through the JDBC2 API.
executeNamedQuery(Transporter, Transporter, Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
A named query after serialization is executed locally.
executeNamedQuery(Transporter, Transporter, Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
A remote query after serialization is executed locally.
executeNamedQuery(Transporter, Transporter, Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
A remote query after serialization is executed locally.
executeNonCursor() - Method in class org.eclipse.persistence.queries.DataReadQuery
INTERNAL: The results are *not* in a cursor, build the collection.
executeNonSelectingCall(Call) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the call on the database.
executeNonSelectingCall(Call) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the call on the database.
executeNonSelectingSQL(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the sql on the database.
executeNonSelectingSQL(String) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the non-selecting (update/DML) SQL string.
executeNoSelect() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Execute a non selecting SQL call This should be overridden by subclasses.
executeNoSelect() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Execute a non selecting call.
executeNoSelect() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Update the object
executeNoSelect(DatabaseCall, Statement, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Execute the statement.
executeNoSelectCall() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Execute a non selecting call.
executeObjectLevelReadQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Executes the prepared query on the datastore.
executeObjectLevelReadQuery() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Execute the query.
executeObjectLevelReadQuery() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Execute the query.
executeObjectLevelReadQueryFromResultSet() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Executes the prepared query on the datastore.
executeObjectLevelReadQueryFromResultSet() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Execute the query building the objects directly from the database result-set.
executeObjectLevelReadQueryFromResultSet() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Execute the query building the objects directly from the database result-set.
executeQuery(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>, Object) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>, Object, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>, Object, Object) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>, Object, Object, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>, Object, Object, Object) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>, List) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>, List) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>, Vector) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>, Vector) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Class<?>, Vector) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Object) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Object, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Object, Object) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Object, Object, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Object, Object, Object) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, List) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, List) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Vector) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Vector) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(String, Vector) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Execute the pre-defined query by name and return the result.
executeQuery(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
A remote query after serialization is executed locally.
executeQuery(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
To execute remote query on the server side.
executeQuery(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
A remote query after serialization is executed locally.
executeQuery(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the database query.
executeQuery(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
Execute the database query.
executeQuery(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
PUBLIC: Execute the database query.
executeQuery(DatabaseQuery) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the database query.
executeQuery(DatabaseQuery, List) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the results from executing the database query.
executeQuery(DatabaseQuery, List) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return the results from executing the database query.
executeQuery(DatabaseQuery, List) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the results from executing the database query.
executeQuery(DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the results from executing the database query.
executeQuery(DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Execute the database query.
executeQuery(DatabaseQuery, AbstractRecord, int) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the results from executing the database query.
executeReturnValue - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
JPA 2.1 NamedStoredProcedureQuery execute API implementation.
executeSelect() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Execute a select SQL call and return the rows.
executeSelect() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
INTERNAL: Execute a selecting call.
executeSelect(DatabaseCall, Statement, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Execute the statement.
executeSelectCall() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
INTERNAL: Execute a selecting call.
executeSelectingCall(Call) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the call on the database and return the result.
executeSelectingCall(Call) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the call on the database and return the result.
executeSQL(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Execute the sql on the database and return the result.
executeSQL(String) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Execute the selecting SQL string.
executeStoredProcedure(DatabaseCall, PreparedStatement, DatabaseAccessor, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
because each platform has different requirements for accessing stored procedures and the way that we can combine resultsets and output params, the stored procedure call is being executed on the platform.
executeWithRCM(RemoteCommandManager) - Method in class org.eclipse.persistence.internal.sessions.coordination.ConnectToHostCommand
INTERNAL: Executed on the RCM when received.
executeWithRCM(RemoteCommandManager) - Method in class org.eclipse.persistence.internal.sessions.coordination.RCMCommand
 
executeWithSession(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.coordination.ConnectToHostCommand
 
executeWithSession(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.coordination.MetadataRefreshCommand
 
executeWithSession(AbstractSession) - Method in class org.eclipse.persistence.sessions.coordination.Command
INTERNAL: If the CommandProcessor is a EclipseLink session then this method will get executed.
executeWithSession(AbstractSession) - Method in class org.eclipse.persistence.sessions.coordination.MergeChangeSetCommand
INTERNAL: This method will be invoked by the RCM only when the CommandProcessor is a TopLink session.
executeWrite() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Check whether the object already exists on the database; then perform an insert or update, as appropriate.
executeWriteWithChangeSet() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Check whether the object already exists on the cadatabase; then perform an insert or update, as appropriate.
executionCount - Variable in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
 
executionSession - Variable in class org.eclipse.persistence.queries.Cursor
The root session that executed the call for the query.
executionSession - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Only used after the query is cloned for execution to store the execution session under which the query was executed.
executionTime - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
Used to set the read time on objects that use this query.
ExistenceChecking - Annotation Type in org.eclipse.persistence.annotations
The ExistenceChecking annotation is used to specify the type of checking EclipseLink should use when determining if an entity is new or existing.
existencePolicy - Variable in class org.eclipse.persistence.queries.DoesExistQuery
Flag to determine existence check policy.
ExistenceType - Enum in org.eclipse.persistence.annotations
An enum that is used within the ExistenceChecking annotation.
EXISTING_QUERY_TYPE_CONFLICT - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
existingDerivedExpressionNamed(String) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
existingDerivedField(DatabaseField) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL:
existingDerivedTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL:
existingDerivedTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
INTERNAL:
existingDirectoryFromPrompt() - Method in class org.eclipse.persistence.tools.PackageRenamer
 
existingQueryTypeConflict(DatabaseQuery, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
exists() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the EXISTS operator.
exists(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a sub query expression.
Exists - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
EXISTS - org.eclipse.persistence.annotations.BatchFetchType
This uses an SQL EXISTS and a sub-select in the batch query instead of a join.
existsNode() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the existsNode expression operator
existsNode(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: XMLType Function, gets the number of nodes returned by the given xpath expression returns 0 if there are none
ExistsNode - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
exp() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
exp(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Exp - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
expand(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.remote.Transporter
Deserialize the object.
EXPECTED_CONTENT_TYPES - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
EXPECTED_CONTENT_TYPES_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
EXPECTED_PROXY_PROPERTY_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
expectedCharFound - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
expectedCharFound(String, int, int, String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
expectedOrderableOrderByItem - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
expectedOrderableOrderByItem(String, int, int, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
expectedProxyPropertyNotFound(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Proxy property corresponding to the specified proxy type was not found.
expiry() - Method in annotation type org.eclipse.persistence.annotations.Cache
(Optional) Expire cached instance after a fix period of time (ms).
expiryTime - Variable in class org.eclipse.persistence.descriptors.invalidation.DailyCacheInvalidationPolicy
 
expiryTimeOfDay() - Method in annotation type org.eclipse.persistence.annotations.Cache
(Optional) Expire cached instance a specific time of day.
ExplainDeadLockUtil - Class in org.eclipse.persistence.internal.helper
The purpose of this class is to try explain the nature of a dead lock
explainPossibleDeadLockStartRecursion(ConcurrencyManagerState) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
Given the concurrency manager state try to explain why we are facing a dead lock.
ExposedNodeLinkedList - Class in org.eclipse.persistence.internal.helper.linkedlist
INTERNAL: A custom implementation of a linked list.
ExposedNodeLinkedList() - Constructor for class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
Constructs an empty list.
expression - Variable in class org.eclipse.persistence.internal.helper.FunctionField
 
Expression - Class in org.eclipse.persistence.expressions
Purpose: Define an object-level representation of a database query where clause.
Expression() - Constructor for class org.eclipse.persistence.expressions.Expression
Base Expression Constructor.
Expression_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
EXPRESSION_DOES_NOT_SUPPORT_PARTIAL_ATTRIBUTE_READING - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
ExpressionBuilder - Class in org.eclipse.persistence.expressions
Purpose: Allow for instances of expression to be created.
ExpressionBuilder() - Constructor for class org.eclipse.persistence.expressions.ExpressionBuilder
PUBLIC: Create a new ExpressionBuilder.
ExpressionBuilder(Class<?>) - Constructor for class org.eclipse.persistence.expressions.ExpressionBuilder
ADVANCED: Create a new ExpressionBuilder representing instances of the argument class.
expressionDoesNotSupportPartialAttributeReading(Expression) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
expressionFor(Expression) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create an expression for this operator, using the given base.
expressionFor(Expression, Object) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create an expression for this operator, using the given base and a single argument.
expressionForArguments(Expression, List) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create an expression for this operator, using the given base and arguments.
expressionForWithBaseLast(Expression, Object) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create an expression for this operator, using the given base and a single argument.
ExpressionIterator - Class in org.eclipse.persistence.internal.expressions
Used to itterate an expression tree, through inner subclasses.
ExpressionIterator() - Constructor for class org.eclipse.persistence.internal.expressions.ExpressionIterator
Block constructor comment.
ExpressionJavaPrinter - Class in org.eclipse.persistence.internal.expressions
Purpose: Expression Java printer.
ExpressionJavaPrinter(String, StringWriter, DatabasePlatform) - Constructor for class org.eclipse.persistence.internal.expressions.ExpressionJavaPrinter
 
ExpressionMath - Class in org.eclipse.persistence.expressions
Purpose: This class mirrors the java.lang.Math class to allow mathimetical function support within expressions.
ExpressionNormalizer - Class in org.eclipse.persistence.internal.expressions
This is used during the normalization process to allow for a single main expression traversal.
ExpressionNormalizer(SQLSelectStatement) - Constructor for class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
 
expressionNotSupported - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
expressionNotSupported(String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
ExpressionOperator - Class in org.eclipse.persistence.expressions
Purpose: ADVANCED: The expression operator is used internally to define SQL operations and functions.
ExpressionOperator() - Constructor for class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Create a new operator.
ExpressionOperator(int, List<String>) - Constructor for class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Create a new operator with the given name(s) and strings to print.
ExpressionOperatorConverter - Class in org.eclipse.persistence.internal.expressions
INTERNAL: Used by function operators in deployment xml generation to accomodate custom functions.
ExpressionOperatorConverter() - Constructor for class org.eclipse.persistence.internal.expressions.ExpressionOperatorConverter
 
ExpressionQueryMechanism - Class in org.eclipse.persistence.internal.queries
Purpose: Mechanism used for all expression read queries.
ExpressionQueryMechanism() - Constructor for class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
ExpressionQueryMechanism(DatabaseQuery) - Constructor for class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Initialize the state of the query
ExpressionQueryMechanism(DatabaseQuery, Expression) - Constructor for class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Initialize the state of the query
ExpressionSQLPrinter - Class in org.eclipse.persistence.internal.expressions
Purpose: Expression SQL printer.
ExpressionSQLPrinter(AbstractSession, AbstractRecord, SQLCall, boolean, ExpressionBuilder) - Constructor for class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
extendDefaultTables(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Create or extend the default table schema for the project this session associated with.
extendedBinaryNumericPromotion(Object, Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Implements binary numeric promotion as defined in JLS extended by wrapper classes, BigDecimal and BigInteger.
ExtendedContentHandler - Interface in org.eclipse.persistence.internal.oxm.record
This class is used to introduce new events to the standard ContentHandler interface that can be leveraged by MOXy.
ExtendedContentHandlerAdapter(ContentHandler) - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
ExtendedResult - Class in org.eclipse.persistence.internal.oxm.record
 
ExtendedResult() - Constructor for class org.eclipse.persistence.internal.oxm.record.ExtendedResult
 
ExtendedSource - Class in org.eclipse.persistence.internal.oxm.record
This class is used to introduce new methods to the standard Source interface that can be leveraged by MOXy.
ExtendedSource() - Constructor for class org.eclipse.persistence.internal.oxm.record.ExtendedSource
 
extendPessimisticLockScope() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Extends pessimistic lock scope.
extendPessimisticLockScopeInSourceQuery(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Called if shouldExtendPessimisticLockScopeInSourceQuery is true.
extendPessimisticLockScopeInSourceQuery(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Called only if both shouldExtendPessimisticLockScope and shouldExtendPessimisticLockScopeInSourceQuery are true.
extendPessimisticLockScopeInSourceQuery(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Called only if both shouldExtendPessimisticLockScope and shouldExtendPessimisticLockScopeInSourceQuery are true.
extendPessimisticLockScopeInTargetQuery(ObjectLevelReadQuery, ObjectBuildingQuery) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Called if shouldExtendPessimisticLockScopeInTargetQuery() is true.
extendPessimisticLockScopeInTargetQuery(ObjectLevelReadQuery, ObjectBuildingQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Adds locking clause to the target query to extend pessimistic lock scope.
extendPessimisticLockScopeInTargetQuery(ObjectLevelReadQuery, ObjectBuildingQuery) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Adds locking clause to the target query to extend pessimistic lock scope.
extendTables(DatabaseSession, SchemaManager) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Create or extend the tables on the database.
extendTables(DatabaseSession, SchemaManager, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
This creates/extends the tables on the database.
extendTablesAndConstraints(SchemaManager, DatabaseSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
 
Extension - Class in org.eclipse.persistence.internal.oxm.schema.model
 
Extension() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
EXTERNAL_CONNECTION_POOL_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
EXTERNAL_TRANSACTION_CONTROLLER_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
ExternalConnectionPool - Class in org.eclipse.persistence.sessions.server
Purpose: This subclass is intended to be used with external connection pools.
ExternalConnectionPool() - Constructor for class org.eclipse.persistence.sessions.server.ExternalConnectionPool
PUBLIC: Build a new external connection pool.
ExternalConnectionPool(String, Login, ServerSession) - Constructor for class org.eclipse.persistence.sessions.server.ExternalConnectionPool
PUBLIC: Build a new external connection pool.
externalTransactionController - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Delegate that handles synchronizing a UnitOfWork with an external transaction.
ExternalTransactionController - Interface in org.eclipse.persistence.sessions
Purpose: Interface for external transaction management.
externalTransactionControllerClass - Variable in class org.eclipse.persistence.platform.server.ServerPlatformBase
externalTransactionControllerClass: This is a user-specifiable class defining the class of external transaction controller to be set into the DatabaseSession
externalTransactionControllerNotNullWarning() - Method in class org.eclipse.persistence.platform.server.CustomServerPlatform
INTERNAL: externalTransactionControllerNotNullWarning(): When the external transaction controller is being initialized, we warn the developer if they have already defined the external transaction controller in some way other than subclassing ServerPlatformBase.
externalTransactionControllerNotNullWarning() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: externalTransactionControllerNotNullWarning(): When the external transaction controller is being initialized, we warn the developer if they have already defined the external transaction controller in some way other than subclassing ServerPlatformBase.
externalTransactionNotActive() - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
extract() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
extract(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Extract the date part from the date/time value.
Extract - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
extractBatchKeyFromRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Extract the primary key value from the source row.
extractBatchKeyFromRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Extract the primary key value from the source row.
extractBatchKeyFromRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Extract the batch key value from the source row.
extractBatchKeyFromRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Extract the primary key value from the source row.
extractBatchKeyFromRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
Extract the key field values from the specified row.
extractBatchKeyFromRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Extract the foreign key value from the source row.
extractBatchKeyFromRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Extract the foreign key value from the source row.
extractClassFromRow(DataRecord, Session) - Method in class org.eclipse.persistence.descriptors.ClassExtractor
Extract/compute the class from the database row and return the class.
extractClassFromRow(DataRecord, Session) - Method in class org.eclipse.persistence.descriptors.MethodClassExtractor
INTERNAL Extract/compute the class from the database row and return the class.
extractDefaultTable() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: The first table in the tables is always treated as default.
extractDefaultTable() - Method in class org.eclipse.persistence.eis.EISDescriptor
Aggregates use a dummy table as default.
extractDefaultTable() - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Aggregates use a dummy table as default.
extractDefaultTable() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
Aggregates use a dummy table as default.
extractFields(boolean, boolean, ClassDescriptor, List<DatabaseField>, Set<DatabaseField>) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Return if the expression is not a valid primary key expression and add all primary key fields to the set.
extractFields(boolean, boolean, ClassDescriptor, List<DatabaseField>, Set<DatabaseField>) - Method in class org.eclipse.persistence.internal.expressions.LogicalExpression
INTERNAL: Return if the expression is not a valid primary key expression and add all primary key fields to the set.
extractFields(boolean, boolean, ClassDescriptor, List<DatabaseField>, Set<DatabaseField>) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
INTERNAL: Return if the expression is not a valid primary key expression and add all primary key fields to the set.
extractIdentityFieldsForQuery(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Extract the fields for the Map key from the object to use in a query.
extractIdentityFieldsForQuery(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Extract the fields for the Map key from the object to use in a query.
extractIdentityFieldsForQuery(Object, AbstractSession) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Extract the fields for the Map key from the object to use in a query
extractIdentityFieldsForQuery(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Extract the fields for the Map key from the object to use in a query
extractJarNameFromURL(URL) - Static method in class org.eclipse.persistence.internal.helper.Helper
Extracts the actual path to the jar file.
extractKeyFromReferenceObject(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Extract the key value from the reference object.
extractKeyFromTargetRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Extract the source primary key value from the target row.
extractKeyFromTargetRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Extract the source primary key value from the target row.
extractKeyFromTargetRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Extract the source primary key value from the reference direct row.
extractKeyFromTargetRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Extract the source primary key value from the relation row.
extractKeyFromTargetRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Extract the source primary key value from the target row.
extractKeyFromTargetRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Extract the source primary key value from the relation row.
extractKeyRowFromReferenceObject(Object, AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
Build and return a database row that contains a foreign key for the specified reference object.
extractNestedExpressions(List<Expression>, ExpressionBuilder) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Extract the nested attribute expressions that apply to this mapping.
extractNestedNonAggregateExpressions(List<Expression>, ExpressionBuilder, boolean) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Extract the nested attribute expressions that apply to this mapping.
extractOperator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Derby does not support EXTRACT, but does have DATEPART.
ExtractOperator - Class in org.eclipse.persistence.internal.expressions
Expression operator customization for EXTRACT(<date-time-part> FROM <date-time>).
ExtractOperator() - Constructor for class org.eclipse.persistence.internal.expressions.ExtractOperator
Creates an instance of ExtractOperator expression.
ExtractOperator(List<String>) - Constructor for class org.eclipse.persistence.internal.expressions.ExtractOperator
Creates an instance of ExtractOperator expression.
extractPartitionValueForPersist(AbstractSession, Object, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.partitioning.FieldPartitioningPolicy
INTERNAL: If persist should be partitioned, extra value from object.
extractPrimaryKeyForReferenceObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return the primary key for the reference object (i.e.
extractPrimaryKeyForReferenceObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return the primary key for the reference object (i.e.
extractPrimaryKeyForReferenceObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the primary key for the reference object (i.e.
extractPrimaryKeyFromExpression(boolean, Expression, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the row with primary keys and their values from the given expression.
extractPrimaryKeyFromExpression(boolean, Expression, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
Override method in superclass in order to set the session on the record.
extractPrimaryKeyFromObject(Object, ABSTRACT_SESSION) - Method in class org.eclipse.persistence.internal.core.descriptors.CoreObjectBuilder
Extract primary key attribute values from the domainObject.
extractPrimaryKeyFromObject(Object, ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
extractPrimaryKeyFromObject(Object, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
extractPrimaryKeyFromObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Extract primary key attribute values from the domainObject.
extractPrimaryKeyFromObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
extractPrimaryKeyFromObject(Object, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Extract primary key attribute values from the domainObject.
extractPrimaryKeyFromRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Extract primary key values from the specified row.
extractPrimaryKeyFromRow(DataRecord, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Extract primary key from a row.
extractPrimaryKeyRowForSourceObject(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Extract the reference pk for rvh usage in remote model.
extractPrimaryKeyRowFromExpression(Expression, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the row with primary keys and their values from the given expression.
extractPrimaryKeyRowFromExpression(Expression, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
Override method in superclass in order to set the session on the record.
extractPrimaryKeyRowFromObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Extract primary key attribute values from the domainObject.
extractPrimaryKeysForReferenceObject(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Extract the reference pk for rvh usage in remote model.
extractPrimaryKeysForReferenceObjectFromRow(AbstractRecord) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: Return the primary key for the reference object (i.e.
extractPrimaryKeysForReferenceObjectFromRow(AbstractRecord) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Return the primary key for the reference object (i.e.
extractPrimaryKeysForReferenceObjectFromRow(AbstractRecord) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return the primary key for the reference object (i.e.
extractPrimaryKeysFromRealReferenceObject(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Extract the reference pk for rvh usage in remote model.
extractPrimaryKeyValues(boolean, ClassDescriptor, AbstractRecord, AbstractRecord) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Extract the primary key from the expression into the row.
extractReferenceRow(Object) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return the reference row for the reference object.
extractReferenceRow(Object) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return the reference row for the reference object.
extractReferenceRow(Object) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return the reference row for the reference object.
extractReferenceRow(Object) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return the reference row for the reference object.
extractReferenceRow(Object) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Return the reference row for the reference object.
extractReferenceRow(Object) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the reference row for the reference object.
extractRemoteResult(Transporter) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Extract the correct query result from the transporter.
extractRemoteResult(Transporter) - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Extract the correct query result from the transporter.
extractRemoteResult(Transporter) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Extract the correct query result from the transporter.
extractRemoteResult(Transporter) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Extract the correct query result from the transporter.
extractResultFromBatchQuery(ReadQuery, CacheKey, AbstractRecord, AbstractSession, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Extract the value from the batch optimized query, this should be supported by most query types.
extractResultFromBatchQuery(ReadQuery, CacheKey, AbstractRecord, AbstractSession, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Extract the value from the batch optimized query, this should be supported by most query types.
extractRowFromExpression(Expression, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the row from the given expression.
extractSourceKeyFromRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL: Extract the source primary key value from the target row.
extractValue() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the extractValue expression operator
extractValue(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: XMLType Function, extracts a value from an XMLType field
ExtractValue - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
extractValueFromObjectForField(Object, DatabaseField, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Extract the value of the primary key attribute from the specified object.
extractValues(boolean, boolean, ClassDescriptor, AbstractRecord, AbstractRecord) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Extract the primary key from the expression into the row.
extractValues(boolean, boolean, ClassDescriptor, AbstractRecord, AbstractRecord) - Method in class org.eclipse.persistence.internal.expressions.LogicalExpression
INTERNAL: Extract the values from the expression into the row.
extractValues(boolean, boolean, ClassDescriptor, AbstractRecord, AbstractRecord) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
INTERNAL: Extract the values from the expression into the row.
extractXml() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the extract expression operator
extractXml(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: XMLType Function, extracts a secton of XML from a larget XML document
ExtractXml - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 

F

factory - Variable in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
The object factory.
factory - Variable in class org.eclipse.persistence.internal.descriptors.PersistenceObjectInstantiationPolicy
The factory is an instance of the domain class.
FACTORY_CLASS_WITHOUT_FACTORY_METHOD - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
FACTORY_METHOD_NOT_DECLARED - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
FACTORY_METHOD_OR_ZERO_ARG_CONST_REQ - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
factoryClass - Variable in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
The class of the factory.
factoryClassName - Variable in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
factoryClassWithoutFactoryMethod(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
factoryMethodName - Variable in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Static method invoked on the factoryClass to get the factory instance.
factoryMethodNotDeclared(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
factoryMethodOrConstructorRequired(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
failDeserializeMessage(String, Exception) - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: Call this message in case there is failure to extract the object (to be passed to processReceivedObject) from the message.
FAILED_TO_INSTANTIATE_LOGGER - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
FAILED_TO_INSTANTIATE_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
FAILED_TO_INSTANTIATE_SERVER_PLATFORM - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
FAILED_TO_INSTANTIATE_TEMP_CLASSLOADER - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
FAILED_TO_LOAD_PROJECT_XML - Static variable in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
FAILED_WHILE_PROCESSING_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
failedToInstantiateLogger(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
failedToInstantiateProperty(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
failedToInstantiateServerPlatform(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
failedToInstantiateTemporaryClassLoader(Exception) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
INTERNAL: Reflective call with doPrivileged to create temporary classloader instance failed.
failedToLoadProjectClass(String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
failedToLoadProjectXml(String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
failedToLoadTag(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
failedToParseXML(String, int, int, Throwable) - Static method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
failedToParseXML(String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
failedWhileProcessingProperty(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
failover() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: The connection pool is dead fail over to the fail-over pool.
FAILOVER_FAILED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
failoverConnectionPools - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
failoverFailed(String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
FALSE - Static variable in class org.eclipse.persistence.config.HintValues
 
FAST_TABLE_CREATOR - Static variable in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Allow table creator to occur "fast" by just deleting all the rows.
FATAL_ERROR_OCCURRED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
fatalError(SAXParseException) - Method in class org.eclipse.persistence.platform.xml.DefaultErrorHandler
 
fatalError(SAXParseException) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader.XMLSessionConfigLoaderErrorHandler
 
fatalErrorOccurred(Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
FEATURE_NOT_SUPPORTED_IN_JDK_VERSION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
featureIsNotAvailableInRunningJDKVersion(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
fetch() - Method in annotation type org.eclipse.persistence.annotations.BasicCollection
Deprecated.
(Optional) Defines whether the value of the field or property should be lazily loaded or must be eagerly fetched.
fetch() - Method in annotation type org.eclipse.persistence.annotations.BasicMap
Deprecated.
(Optional) Defines whether the value of the field or property should be lazily loaded or must be eagerly fetched.
fetch() - Method in annotation type org.eclipse.persistence.annotations.Transformation
(Optional) Defines whether the value of the field or property should be lazily loaded or must be eagerly fetched.
fetch() - Method in annotation type org.eclipse.persistence.annotations.VariableOneToOne
(Optional) Defines whether the value of the field or property should be lazily loaded or must be eagerly fetched.
FETCH - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.join-fetch"
FETCH_FORWARD - Static variable in class org.eclipse.persistence.queries.ScrollableCursorPolicy
JDBC 2.0 The rows in a result set will be processed in a forward direction; first-to-last.
FETCH_GROUP - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.fetch-group"
FETCH_GROUP_ATTRIBUTE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.fetch-group.attribute"
FETCH_GROUP_ATTRIBUTE_NOT_MAPPED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
FETCH_GROUP_DEFAULT - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.fetch-group.default"
FETCH_GROUP_HAS_UNMAPPED_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
FETCH_GROUP_HAS_WRONG_REFERENCE_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
FETCH_GROUP_HAS_WRONG_REFERENCE_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
FETCH_GROUP_LOAD - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.fetch-group.load"
FETCH_GROUP_NAME - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.fetch-group.name"
FETCH_GROUP_NOT_SUPPORT_ON_PARTIAL_ATTRIBUTE_READING - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
FETCH_GROUP_NOT_SUPPORT_ON_REPORT_QUERY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
FETCH_REVERSE - Static variable in class org.eclipse.persistence.queries.ScrollableCursorPolicy
JDBC 2.0 The rows in a result set will be processed in a reverse direction; last-to-first.
FETCH_UNKNOWN - Static variable in class org.eclipse.persistence.queries.ScrollableCursorPolicy
JDBC 2.0 The order in which rows in a result set will be processed is unknown.
FetchAttribute - Annotation Type in org.eclipse.persistence.annotations
A fetch attribute is specified within a fetch group and is used as a performance enhancement that allows a group of attributes of an object to be loaded on demand, which means that the data for an attribute might not loaded from the underlying data source until an explicit access call for the attribute first occurs.
fetchedAttributes - Static variable in class org.eclipse.persistence.tools.profiler.FetchGroupMonitor
 
fetchGroup - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
FetchGroup specified on this query.
FetchGroup - Class in org.eclipse.persistence.queries
A FetchGroup is a performance enhancement that allows a group of attributes of an object to be loaded on demand, which means that the data for an attribute might not loaded from the underlying data source until an explicit access call for the attribute first occurs.
FetchGroup - Annotation Type in org.eclipse.persistence.annotations
A fetch group is a performance enhancement that allows a group of attributes of an object to be loaded on demand, which means that the data for an attribute might not loaded from the underlying data source until an explicit access call for the attribute first occurs.
FetchGroup() - Constructor for class org.eclipse.persistence.queries.FetchGroup
 
FetchGroup(String) - Constructor for class org.eclipse.persistence.queries.FetchGroup
 
FETCHGROUP_VALID_ONLY_IF_FETCHGROUP_MANAGER_IN_DESCRIPTOR - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
fetchGroupAttributeNotMapped(String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
fetchGroupHasUnmappedAttribute(AttributeGroup, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Fetch group has an attribute that doesn't have corresponding mapping.
fetchGroupHasWrongReferenceAttribute(FetchGroup, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Fetch group has an attribute that references nested fetch group but the corresponding mapping is either not ForeignReferenceMapping or does not have reference descriptor.
fetchGroupHasWrongReferenceClass(FetchGroup, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Fetch group has an attribute that references nested fetch group but target class does not support fetch groups..
fetchGroupManager - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
FetchGroupManager - Class in org.eclipse.persistence.descriptors
Purpose: The fetch group manager controls the named fetch groups defined at the descriptor level.
FetchGroupManager() - Constructor for class org.eclipse.persistence.descriptors.FetchGroupManager
Constructor
FetchGroupMonitor - Class in org.eclipse.persistence.tools.profiler
Purpose: Provide a very simple low overhead means for measuring fetch group field usage.
FetchGroupMonitor() - Constructor for class org.eclipse.persistence.tools.profiler.FetchGroupMonitor
 
fetchGroupName - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Name of FetchGroup stored in the FetchGroupManager of the reference class' descriptor or any of its parent descriptors.
fetchGroupNotDefinedInDescriptor(String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
fetchGroupNotSupportOnPartialAttributeReading() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
fetchGroupNotSupportOnReportQuery() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
FetchGroups - Annotation Type in org.eclipse.persistence.annotations
A FetchGroups annotation allows the definition of multiple FetchGroup.
FetchGroupTracker - Interface in org.eclipse.persistence.queries
Purpose: The fetch group tracker interface provides a set of APIs which the domain object must implement, in order to take advantage of the EclipseLink fetch group performance enhancement feature.
FetchGroupTracker_class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
fetchGroupValidOnlyIfFetchGroupManagerInDescriptor(String, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
fetchLocatorAndWriteValue(DatabaseCall, Object) - Method in class org.eclipse.persistence.internal.helper.LOBValueWriter
Fetch the locator(s) from the result set and write LOB value to the table
fetchPropertiesManager() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
Fetch properties manager.
fetchRow(Vector<DatabaseField>, ResultSet, ResultSetMetaData, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return a new DatabaseRow.
fetchRow(Vector<DatabaseField>, DatabaseField[], ResultSet, ResultSetMetaData, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return a new DatabaseRow.
fetchSize - Variable in class org.eclipse.persistence.queries.ReadQuery
Used to set statement fetch size
FF - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
Form feed
field - Variable in class org.eclipse.persistence.core.descriptors.CoreDescriptor
 
field - Variable in class org.eclipse.persistence.internal.descriptors.AbstractSerializedObjectPolicy
 
field - Variable in class org.eclipse.persistence.internal.descriptors.FieldTransformation
 
field - Variable in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
Cache the aliased field.
field - Variable in class org.eclipse.persistence.internal.expressions.FieldExpression
 
field - Variable in class org.eclipse.persistence.internal.expressions.ParameterExpression
The parameter field or name.
field - Variable in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
DatabaseField which this mapping represents.
field - Variable in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
The aggregate objects are stored in a single field.
field - Variable in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
This is the field holding the nested collection.
field - Variable in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
The aggregate object is stored in a single field.
field - Variable in class org.eclipse.persistence.mappings.structures.NestedTableMapping
A ref is always stored in a single field.
field - Variable in class org.eclipse.persistence.mappings.structures.ReferenceMapping
A ref is always stored in a single field.
field - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
DatabaseField stores the field name with case and delimiting information.
Field<CONVERSION_MANAGER extends ConversionManager,​NAMESPACE_RESOLVER extends NamespaceResolver> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
FIELD_IS_NOT_PRESENT_IN_DATABASE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
FIELD_LEVEL_LOCKING_NOTSUPPORTED_OUTSIDE_A_UNIT_OF_WORK - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
FIELD_NAME_NOT_SET_IN_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
FIELD_TRANSFORMER_CLASS_INVALID - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
FIELD_TRANSFORMER_CLASS_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
fieldAliases - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Used for caching the field alias written to the query
fieldClassification - Variable in class org.eclipse.persistence.mappings.converters.ConverterClass
 
fieldClassification - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
fieldClassificationClassName - Variable in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
 
fieldClassificationName - Variable in class org.eclipse.persistence.mappings.converters.ConverterClass
 
fieldClassificationName - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
fieldCounter - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Counter to generate unique alias names
FieldDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Define a database field definition for creation within a table.
FieldDefinition() - Constructor for class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
FieldDefinition(String, Class<?>) - Constructor for class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
FieldDefinition(String, Class<?>, int) - Constructor for class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
FieldDefinition(String, Class<?>, int, int) - Constructor for class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
FieldDefinition(String, String) - Constructor for class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
FieldExpression - Class in org.eclipse.persistence.internal.expressions
Field expressions represent a field of a table.
FieldExpression() - Constructor for class org.eclipse.persistence.internal.expressions.FieldExpression
FieldExpression constructor comment.
FieldExpression(DatabaseField) - Constructor for class org.eclipse.persistence.internal.expressions.FieldExpression
FieldExpression constructor comment.
FieldExpression(DatabaseField, Expression) - Constructor for class org.eclipse.persistence.internal.expressions.FieldExpression
FieldExpression constructor comment.
fieldIsNotFromDescriptor(DatabaseField) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
fieldIsNotPresentInDatabase(ClassDescriptor, String, String) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
fieldLevelLockingNotSupportedWithoutUnitOfWork() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
fieldMap - Variable in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Used to track the field definition: keyed by the database field object, and valued by the field definition.
fieldName - Variable in class org.eclipse.persistence.dynamic.DynamicEnumBuilder
 
fieldNameNotSetInMapping(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
FieldPartitioningPolicy - Class in org.eclipse.persistence.descriptors.partitioning
PUBLIC: FieldPartitioningPolicy partitions access to a database cluster by a field value from the object, such as the object's id, location, or tenant.
FieldPartitioningPolicy() - Constructor for class org.eclipse.persistence.descriptors.partitioning.FieldPartitioningPolicy
 
FieldPartitioningPolicy(String) - Constructor for class org.eclipse.persistence.descriptors.partitioning.FieldPartitioningPolicy
 
FieldPartitioningPolicy(String, boolean) - Constructor for class org.eclipse.persistence.descriptors.partitioning.FieldPartitioningPolicy
 
fieldQname - Variable in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
FieldResult - Class in org.eclipse.persistence.queries
Purpose: Concrete class to represent the FieldResult structure as defined by the EJB 3.0 Persistence specification.
FieldResult(String, String) - Constructor for class org.eclipse.persistence.queries.FieldResult
 
FieldResult(String, DatabaseField) - Constructor for class org.eclipse.persistence.queries.FieldResult
 
fieldResults - Variable in class org.eclipse.persistence.queries.EntityResult
Stores the list of FieldResult
fields - Variable in class org.eclipse.persistence.descriptors.CacheIndex
 
fields - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
fields - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
fields - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Fields being selected (can include expressions).
fields - Variable in class org.eclipse.persistence.internal.sessions.AbstractRecord
Use vector to store the fields/values for optimal performance.
fields - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
Fields associated with the mappings are cached
fields - Variable in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
fields - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
fields - Variable in class org.eclipse.persistence.queries.Cursor
The fields expected in the result set.
fields - Variable in class org.eclipse.persistence.tools.schemaframework.IndexDefinition
 
fields - Variable in class org.eclipse.persistence.tools.schemaframework.TableDefinition
 
fields - Variable in class org.eclipse.persistence.tools.schemaframework.TypeDefinition
 
fields() - Method in annotation type org.eclipse.persistence.annotations.Struct
(Optional) Defines the order of the fields contained in the database structure type.
fields() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.OracleObject
(Required) Defines the fields in the record type.
fields() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLRecord
(Required) Defines the fields in the record type.
FIELDS_FILTERING_BOTH_PARAMETERS_PRESENT - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
fieldsArray - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
fieldsArray - Variable in class org.eclipse.persistence.internal.sessions.ArrayRecord
 
fieldsContainField(List, Expression) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Check if the field from the field expression is already contained in the select clause of the statement.
FieldsLockingPolicy - Class in org.eclipse.persistence.descriptors
Purpose: An abstract superclass of some implementations of the OptimisticLockingPolicy interface.
FieldsLockingPolicy() - Constructor for class org.eclipse.persistence.descriptors.FieldsLockingPolicy
PUBLIC: Create a new field locking policy.
fieldsMap - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Used to maintain identity on the field objects.
fieldsNotFromDescriptor_DefaultTable - Variable in class org.eclipse.persistence.descriptors.ReturningPolicy
contains all default table the returning fields that are either unmapped or mapped supplied with types.
fieldsNotFromDescriptor_OtherTables - Variable in class org.eclipse.persistence.descriptors.ReturningPolicy
contains all the other tables returning fields that are either unmapped or mapped supplied with types.
fieldToAttributeValues - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
fieldToTransformers - Variable in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
The TransformerClassNames are converted into instances of FieldTransformer
FieldTransformation - Class in org.eclipse.persistence.internal.descriptors
INTERNAL: This class is used to store the field transformations on the TransformationMapping.
FieldTransformation() - Constructor for class org.eclipse.persistence.internal.descriptors.FieldTransformation
 
fieldTransformationMethod - Variable in class org.eclipse.persistence.mappings.transformers.MethodBasedFieldTransformer
 
fieldTransformations - Variable in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
Stores field name and the class name of a FieldTransformer in a vector to preserve order
FieldTransformer - Interface in org.eclipse.persistence.mappings.transformers
PUBLIC: This interface is used by the Transformation Mapping to build the value for a specific field.
FieldTransformerAdapter - Class in org.eclipse.persistence.mappings.transformers
Purpose: Provides an empty implementation of FieldTransformer.
FieldTransformerAdapter() - Constructor for class org.eclipse.persistence.mappings.transformers.FieldTransformerAdapter
 
fieldTransformerClassInvalid(String, AbstractTransformationMapping, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
fieldTransformerClassNotFound(String, AbstractTransformationMapping, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
FieldTransformerNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
FieldTransformerNodeValue(TransformationMapping) - Constructor for class org.eclipse.persistence.internal.oxm.FieldTransformerNodeValue
 
FieldTranslation - Class in org.eclipse.persistence.internal.descriptors
Purpose: Used to define aggregate mapping field translations deployment XML mappings.
FieldTranslation() - Constructor for class org.eclipse.persistence.internal.descriptors.FieldTranslation
Default constructor.
FieldTranslation(DatabaseField, DatabaseField) - Constructor for class org.eclipse.persistence.internal.descriptors.FieldTranslation
Create an association.
FieldTypeDefinition - Class in org.eclipse.persistence.internal.databaseaccess
INTERNAL: Purpose: Define a database platform specific definition for a platform independent Java class type.
FieldTypeDefinition() - Constructor for class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
FieldTypeDefinition(String) - Constructor for class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Return a new field type.
FieldTypeDefinition(String, boolean) - Constructor for class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Return a new field type with a required size defaulting to the defaultSize.
FieldTypeDefinition(String, boolean, boolean) - Constructor for class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Return a new field type with a required size defaulting to the defaultSize and shouldAllowNull set to allowsNull.
FieldTypeDefinition(String, int) - Constructor for class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Return a new field type with a required size defaulting to the defaultSize.
FieldTypeDefinition(String, int, int) - Constructor for class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Return a new field type with a required size defaulting to the defaultSize.
FieldTypeDefinition(String, int, String) - Constructor for class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
fieldTypes - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Holds a map of values used to map JAVA types to database types for table creation
FILE - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
FILE_ERROR - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
FILE_PATH_MISSING_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
FILE_SEPARATOR - Static variable in class org.eclipse.persistence.internal.helper.Helper
Prime the platform-dependent file separator
fileError(IOException) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
fileName - Variable in class org.eclipse.persistence.logging.DefaultSessionLog
The filename associated with this DefaultSessionLog, if it is being written out to a file
filePathMissingException(String) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
fileSeparator() - Static method in class org.eclipse.persistence.internal.helper.Helper
Return a string containing the platform-appropriate characters for separating directory and file names.
filter() - Static method in class org.eclipse.persistence.internal.expressions.SpatialExpressionOperators
ExpressionOperator for the MDSYS.SDO_FILTER Spatial Operator on the Oracle Database Use of this operator requires the Java spatial classes
FINAL_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
finalException(Vector) - Static method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
finalize() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Logout in case still connected.
finalize() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
This method is used to remove the RemoteValueHolder from the dispatcher on Garbage collection from the client
finalize() - Method in class org.eclipse.persistence.internal.sessions.SessionFinalizer
Release the session.
finalize() - Method in class org.eclipse.persistence.queries.Cursor
Close in case not closed.
finalize() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
INTERNAL: Close the schema writer when the schema manger is garbage collected
findClass(String) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
Create a new dynamic class if a ClassWriter is registered for the provided className.
findGroup(DESCRIPTOR) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
findGroup(ClassDescriptor) - Method in class org.eclipse.persistence.queries.AttributeGroup
 
findMethod(int) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
Find the method corresponding to the event selector.
findObjectChangeSet(ObjectChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: This method can be used find the equivalent changeset within this UnitOfWorkChangeSet Aggregates, and new objects without primaryKeys from serialized ChangeSets will not be found Which may result in duplicates, in the UnitOfWorkChangeSet.
findOrCreateLocalObjectChangeSet(Object, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL" This method is used during the merge process to either find the existing ChangeSet or create a new one.
findOrIntegrateObjectChangeSet(ObjectChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: This method will be used during the merge process to either find an equivalent change set within this UnitOfWorkChangeSet or integrate that changeset into this UOW ChangeSet
findReferenceDescriptor(XPathFragment, UnmarshalRecord, Attributes, Mapping, UnmarshalKeepAsElementPolicy) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyObjectMappingNodeValue
 
findReferenceDescriptor(XPathFragment, UnmarshalRecord, Attributes, Mapping, UnmarshalKeepAsElementPolicy) - Method in class org.eclipse.persistence.internal.oxm.XMLRelationshipMappingNodeValue
 
findReferenceDescriptor(XPathFragment, UnmarshalRecord, Attributes, Mapping, UnmarshalKeepAsElementPolicy) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathMappingNodeValue
 
findUpdatedObjectsClasses() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Returns the set of classes corresponding to updated objects in objectChanges.
fine(String) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
fine(String) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: This method is called when a fine level message needs to be logged.
fine(String, String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
FINE - org.eclipse.persistence.logging.LogLevel
Fine logging level.
FINE - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
FINE_LABEL - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
FINE_PREFIX - Static variable in class org.eclipse.persistence.logging.AbstractSessionLog
Represents prefix to logged fine
finer(String) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
finer(String) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: This method is called when a finer level message needs to be logged.
finer(String, String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
FINER - org.eclipse.persistence.logging.LogLevel
Finer logging level.
FINER - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
FINER_LABEL - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
FINER_PREFIX - Static variable in class org.eclipse.persistence.logging.AbstractSessionLog
Represents prefix to logged finer
finest(String) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
finest(String) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: This method is called when a finest level message needs to be logged.
finest(String, String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
FINEST - org.eclipse.persistence.logging.LogLevel
Finest (the most detailed) logging level.
FINEST - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
FINEST_LABEL - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
FINEST_PREFIX - Static variable in class org.eclipse.persistence.logging.AbstractSessionLog
Represents prefix to logged finest
finishingTime - Variable in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
finishLevel() - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord
 
finishLevel() - Method in class org.eclipse.persistence.oxm.record.JsonGeneratorRecord
 
finishLevel() - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
FirebirdPlatform - Class in org.eclipse.persistence.platform.database
 
FirebirdPlatform() - Constructor for class org.eclipse.persistence.platform.database.FirebirdPlatform
 
first - Variable in class org.eclipse.persistence.internal.identitymaps.CacheIdentityMap
Provide handles on the linked list
first() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
Moves the cursor to the first row in the result set
first() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Moves the cursor to the first row in the result set
FIRST_INDEX_OF_COLLECTION - Static variable in class org.eclipse.persistence.internal.helper.ReadLockManager
 
FIRST_PRIMARY_KEY - Static variable in class org.eclipse.persistence.queries.ReportQuery
 
firstChild - Variable in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
firstElement() - Method in class org.eclipse.persistence.indirection.IndirectList
 
firstElement() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
firstElement() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
firstElement() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Wait until has an element or is complete.
firstResult - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
firstResult - Variable in class org.eclipse.persistence.queries.ReadQuery
Used to start query results at a specific result
FIRSTRESULT_FIELD - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
fixAttributeValue(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: An object has been serialized from the server to the remote client.
fixAttributeValue(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
An object has been serialized from the server to the remote client.
FixedMimeTypePolicy - Class in org.eclipse.persistence.oxm.mappings
 
FixedMimeTypePolicy() - Constructor for class org.eclipse.persistence.oxm.mappings.FixedMimeTypePolicy
 
FixedMimeTypePolicy(String) - Constructor for class org.eclipse.persistence.oxm.mappings.FixedMimeTypePolicy
 
FixedMimeTypePolicy(String, DatabaseMapping) - Constructor for class org.eclipse.persistence.oxm.mappings.FixedMimeTypePolicy
 
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: An object has been serialized from the server to the remote client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
INTERNAL: An object has been serialized from the server to the client.
fixObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
fixObjectReferences(Transporter, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
INTERNAL: An object has been serialized from the server to the remote client.
fixRealObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: We are not using a remote valueholder so we need to replace the reference object(s) with the corresponding object(s) from the remote session.
fixRealObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: At this point, we realize we don't have indirection; so we need to replace the reference object(s) with the corresponding object(s) from the remote session.
fixRealObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: At this point, we realize we don't have indirection; so we need to replace the reference object(s) with the corresponding object(s) from the remote session.
fixRealObjectReferences(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, DistributedSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: We are not using a remote valueholder so we need to replace the reference object(s) with the corresponding object(s) from the remote session.
fixRemoteChangeSet(UnitOfWorkChangeSet, Map, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
INTERNAL: Fix the transient fields in the serialized change set.
flatUnionFetchGroups(FetchGroup, FetchGroup, boolean) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Union two fetch groups as EntityFetchGroups.
FLOAT - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
FLOAT - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
FLOAT_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
FLOAT_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
floor() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
floor(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Floor - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
flush() - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
flush() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
flush() - Method in interface org.eclipse.persistence.oxm.record.JSONWriterRecord.Output
 
flush() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.OutputStreamOutput
 
flush() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
flush() - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
flush() - Method in class org.eclipse.persistence.oxm.record.WriterRecord
 
FLUSH - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.flush"
FLUSH_CLEAR_CACHE - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
Defines EntityManager cache behavior after a call to flush method followed by a call to clear method.
FLUSH_CLEAR_CACHE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.flush-clear.cache" property defines EntityManager cache behavior after a call to flush method followed by a call to clear method.
flushClearCache - Variable in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
The FlashClearCache mode to be used.
FlushClearCache - Class in org.eclipse.persistence.config
FlushClearCache persistence property defines modes of cache handling after em.flush call followed by em.clear call.
FlushClearCache() - Constructor for class org.eclipse.persistence.config.FlushClearCache
 
flushOnExecute - Variable in class org.eclipse.persistence.queries.DatabaseQuery
 
flushSelectCalls(AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Execute any deferred select calls.
flushSelectCalls(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Execute any deferred select calls stored in the LOBValueWriter instance.
flushSelectCalls(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Added as a result of Bug 2804663 - satisfy the Accessor interface implementation.
FORCE_DROP - Static variable in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Allow replacing of table to force the drop, this may require several passes.
FORCE_FIELD_NAMES_TO_UPPERCASE_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
FORCE_WEAK - org.eclipse.persistence.config.ReferenceMode
Same as weak reference except Objects that can not be changed tracked (Deferred Change Detection) will not be prevented from being garbage collected.
forceBatchStatementExecution - Variable in class org.eclipse.persistence.queries.ModifyQuery
 
forceBatchStatementExecution() - Method in class org.eclipse.persistence.queries.ModifyQuery
PUBLIC: Returns if this query has been set to flush on execution.
forceCascade - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
Force cascade merge even if a clone is already registered
forceInitializationOfSelectionCriteria - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
This is a way (after cloning) to force the initialization of the selection criteria
forceUpdate - Variable in class org.eclipse.persistence.descriptors.CMPPolicy
 
forceUpdateToVersionField(Object, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Set optimistic read lock on the object.
forceUpdateToVersionField(Object, boolean) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Set optimistic read lock on the object.
forceValueWrapper() - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
forceValueWrapper() - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
forceValueWrapper() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
forceValueWrapper() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
forDetach - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
forEach(BiConsumer<? super K, ? super V>) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
forEach(Consumer<? super E>) - Method in class org.eclipse.persistence.indirection.IndirectList
 
forEach(Consumer<? super E>) - Method in class org.eclipse.persistence.indirection.IndirectSet
 
forEach(Consumer<? super E>) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
FOREIGN_KEYS_DEFINED_INCORRECTLY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ForeignKeyConstraint - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Define a foreign key from one table to another.
ForeignKeyConstraint() - Constructor for class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
ForeignKeyConstraint(String, String, String, String) - Constructor for class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
foreignKeyConstraints - Variable in class org.eclipse.persistence.internal.helper.DatabaseTable
JPA 2.1 Foreign key specification data
foreignKeyDefinition - Variable in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
foreignKeyFieldName - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
foreignKeyFields - Variable in class org.eclipse.persistence.mappings.ObjectReferenceMapping
Keeps track of which fields are foreign keys on a per field basis (can have mixed foreign key relationships).
foreignKeyGroupingElement - Variable in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
The grouping-element field.
foreignKeyMap - Variable in class org.eclipse.persistence.tools.schemaframework.TableDefinition
 
foreignKeysDefinedIncorrectly(ForeignReferenceMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
foreignKeyValuesForCaching - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
Stores a set of FK fields that will be cached to later retrieve noncacheable mappings
ForeignReferenceMapping - Class in org.eclipse.persistence.mappings
Purpose: Abstract class for relationship mappings
ForeignReferenceMapping() - Constructor for class org.eclipse.persistence.mappings.ForeignReferenceMapping
 
ForeignReferenceQueryKey - Class in org.eclipse.persistence.mappings.querykeys
Purpose: Define an alias to a foreign object.
ForeignReferenceQueryKey() - Constructor for class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
 
forget(ComputableTask<A, V>, A) - Method in class org.eclipse.persistence.internal.cache.Memoizer
Forgets result of the specified task.
forgetAll() - Method in class org.eclipse.persistence.internal.cache.Memoizer
Forgets all cached results.
format(String, Object[]) - Static method in class org.eclipse.persistence.exceptions.i18n.ExceptionMessageGenerator
Return the formatted message for the given exception class and error number.
format(LogRecord) - Method in class org.eclipse.persistence.logging.LogFormatter
Format the given LogRecord.
format(LogRecord) - Method in class org.eclipse.persistence.logging.XMLLogFormatter
Format the given message to XML.
formatMessage(SessionLogEntry) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
Return the formatted message based on the information from the given SessionLogEntry.
FormattedOutputStreamRecord - Class in org.eclipse.persistence.oxm.record
Use this type of MarshalRecord when the marshal target is an OutputStream and the XML should be formatted with carriage returns and indenting.
FormattedOutputStreamRecord() - Constructor for class org.eclipse.persistence.oxm.record.FormattedOutputStreamRecord
 
FormattedWriterRecord - Class in org.eclipse.persistence.oxm.record
Use this type of MarshalRecord when the marshal target is a Writer and the XML should be formatted with carriage returns and indenting.
FormattedWriterRecord() - Constructor for class org.eclipse.persistence.oxm.record.FormattedWriterRecord
 
forUpdateClause - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Used for pessimistic locking ie.
ForUpdateClause - Class in org.eclipse.persistence.internal.expressions
Purpose:Represents The FOR UPDATE pessimistically locking clause.
ForUpdateClause() - Constructor for class org.eclipse.persistence.internal.expressions.ForUpdateClause
 
ForUpdateClause(short) - Constructor for class org.eclipse.persistence.internal.expressions.ForUpdateClause
 
ForUpdateClause(Integer) - Constructor for class org.eclipse.persistence.internal.expressions.ForUpdateClause
 
ForUpdateOfClause - Class in org.eclipse.persistence.internal.expressions
Purpose:Represents The FOR UPDATE OF fine-grained pessimistically locking clause.
ForUpdateOfClause() - Constructor for class org.eclipse.persistence.internal.expressions.ForUpdateOfClause
 
Forward - Static variable in class org.eclipse.persistence.config.ResultSetType
The rows in a result set will be processed in a forward direction; first-to-last.
ForwardOnly - Static variable in class org.eclipse.persistence.config.ResultSetType
The type for a ResultSet object whose cursor may move only forward.
FOUND_SIMPLE_VALUE_FOR_FOR_NON_DATATYPE_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
foundSimpleValueForNonDataTypeProperty(String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when the value should be a dataObject and it's not
fqClassnameToDescriptor - Variable in class org.eclipse.persistence.dynamic.DynamicHelper
 
FragmentCollectionMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​SESSION extends CoreSession,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
FragmentContentHandler - Class in org.eclipse.persistence.internal.oxm
This class is used when marshalling to a ContentHandler when the fragment flag on XMLMarshaller is true It wraps a given ContentHandler and passes the events to that ContentHandler The startDocument and endDocumentevents are not triggered on the reference ContentHandler.
FragmentContentHandler(ContentHandler) - Constructor for class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
FragmentMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​SESSION extends CoreSession,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
FREE_METADATA - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.memory.free-metadata" property configures the JPA internal deployment metadata to be released after deployment.
freeTemporaryObject(Object) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Used by some platforms during reading of ResultSet to free temporary objects.
from(Object, Expression) - Static method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Create an expression node.
from(CompositeData) - Static method in class org.eclipse.persistence.services.ClassSummaryDetailBase
Create an instance of the model specific class out of an associated CompositeData instance
FROM - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
FROM_ID - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
FromAliasExpression - Class in org.eclipse.persistence.internal.expressions
Represents an alias to a item selected by a from clause sub-select.
FromAliasExpression() - Constructor for class org.eclipse.persistence.internal.expressions.FromAliasExpression
 
FromAliasExpression(String, Expression) - Constructor for class org.eclipse.persistence.internal.expressions.FromAliasExpression
 
fromConstant(Object, Expression) - Static method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Create an expression node.
fromLiteral(String, Expression) - Static method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Create an expression node.
FROMSTRING_METHOD_ERROR - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
FromSubSelectExpression - Class in org.eclipse.persistence.internal.expressions
Allow a table expression to be created on a sub-select to define a sub-select in the from clause.
FromSubSelectExpression() - Constructor for class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
 
FromSubSelectExpression(SubSelectExpression) - Constructor for class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
 
fromValue(String) - Static method in enum org.eclipse.persistence.oxm.annotations.XmlMarshalNullRepresentation
 
fromValue(String) - Static method in enum org.eclipse.persistence.oxm.annotations.XmlVirtualAccessMethodsSchema
 
Full - Static variable in class org.eclipse.persistence.config.CacheType
A Soft cache holds all objects read by the application.
Full - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
FULL - org.eclipse.persistence.annotations.CacheType
Provides full caching and guaranteed identity.
FULL_PRIMARY_KEY - Static variable in class org.eclipse.persistence.queries.ReportQuery
Specifies whether to retrieve primary keys, first primary key, or no primary key.
FullIdentityMap - Class in org.eclipse.persistence.internal.identitymaps
Purpose: A FullIdentityMap holds all objects stored within it for the life of the application.
FullIdentityMap() - Constructor for class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Used to allow subclasses to build different map type.
FullIdentityMap(int, ClassDescriptor, AbstractSession, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
 
FullIdentityMap_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
fullyMergeEntity - Variable in class org.eclipse.persistence.descriptors.CachePolicy
This flag controls how the MergeManager should merge an Entity when merging into the shared cache.
FunctionExpression - Class in org.eclipse.persistence.internal.expressions
Used for expressions that have 0 to n children.
FunctionExpression() - Constructor for class org.eclipse.persistence.internal.expressions.FunctionExpression
 
FunctionExpression_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
FunctionField - Class in org.eclipse.persistence.internal.helper
INTERNAL:
FunctionField() - Constructor for class org.eclipse.persistence.internal.helper.FunctionField
 
FunctionField(String) - Constructor for class org.eclipse.persistence.internal.helper.FunctionField
A unique field name should still be given to the function.
functionId - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
Id used to generate unique local functions.
functionName - Variable in class org.eclipse.persistence.eis.interactions.EISInteraction
Name of the function the interaction describes.
functionName() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredFunctionQuery
(Required) The name of the stored function.
functionName() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredFunctionQuery
(Required) The name of the stored procedure.
FunctionOperator - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 

G

G_DAY - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
G_DAY_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
G_MONTH - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
G_MONTH_DAY - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
G_MONTH_DAY_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
G_MONTH_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
G_YEAR - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
G_YEAR_MONTH - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
G_YEAR_MONTH_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
G_YEAR_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
generalParsingException - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
generalParsingException(String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
INTERNAL Create an exception to wrap a general parsing exception
generalParsingException(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
INTERNAL Create an exception to wrap a general parsing exception
generalParsingException2 - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
generate() - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Generate the project class, output the java source code to the stream or file.
generate() - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Generate the project class, output the java source code to the stream or file.
generate(boolean) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Generate the project class, output the java source code to the stream or file.
generate(boolean) - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Generate the creator class, output the java source code to the stream or file.
generateAmendmentClass(Writer, String, String) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
PUBLIC: Generate an amendment class that will set up the descriptors to use these stored procedures.
generateCreatorClass() - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
Return a class definition object representing the code to be generated for the table creator.
generatedAlias(String) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Returns a generated alias based on the column name.
generateDefaultTableCreator() - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Generate a default TableCreator object from the EclipseLink project object.
generateDeleteStoredProcedure(ClassDescriptor) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Generates the delete stored procedure for this descriptor
generatedKeys - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
generateFilteredDefaultTableCreator(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Generate a default TableCreator object from the EclipseLink project object, and perform the table existence check through jdbc table metadata, and filter out tables which are already in the database.
generateFKConstraints - Variable in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
When this flag is 'false' EclipseLink will not attempt to create fk constraints.
generateInsertStoredProcedure(ClassDescriptor) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Generates the insert stored procedure for this descriptor
generateKeysExecuteNoSelect() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Execute a non selecting SQL call, that returns the generated keys This should be overridden by subclasses.
generateKeysExecuteNoSelect() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Execute a non selecting call.
generateMappingStoredProcedures(ClassDescriptor) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Generates the mapping stored procedures for this descriptor.
generateObjectStoredProcedure(DatabaseQuery, List<DatabaseField>, String) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Generates the object level stored procedure based on the passed in query
generateOneToManyMappingDeleteAllProcedure(OneToManyMapping) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Generates the delete all stored procedure for this mapping
generateOneToManyMappingProcedures(OneToManyMapping, DatabaseQuery, Map<DatabaseField, DatabaseField>, String) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Generates all the stored procedures for this mapping
generateOneToManyMappingReadProcedure(OneToManyMapping) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Generates the read all stored procedure for this mapping
generatePrefix() - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
 
generatePrefix(String) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
 
generateProjectClass() - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
Return a class definition object representing the code to be generated for the project and its descriptors.
generateReadAllStoredProcedure(ClassDescriptor) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Generates the read all stored procedure for this descriptor
generateReadStoredProcedure(ClassDescriptor) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Generates the read stored procedure for this descriptor
generateSchemas(List<Descriptor>, SchemaModelGeneratorProperties) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Generates a Map of EclipseLink schema model Schema objects for a given list of XMLDescriptors.
generateSchemas(List<Descriptor>, SchemaModelGeneratorProperties, Map<QName, Type>) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Generates a Map of EclipseLink schema model Schema objects for a given list of XMLDescriptors.
generateSchemas(List<Descriptor>, SchemaModelGeneratorProperties, SchemaModelOutputResolver) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Generates a Map of EclipseLink schema model Schema objects for a given list of XMLDescriptors.
generateSchemas(List<Descriptor>, SchemaModelGeneratorProperties, SchemaModelOutputResolver, Map<QName, Type>) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Generates a Map of EclipseLink schema model Schema objects for a given list of XMLDescriptors.
generateSequenceStoredProcedures(Project) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Generates the select and update stored procedures for this project.
generateStoredProcedure(DatabaseQuery, List<DatabaseField>, String) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Generates the stored procedure for this query.
generateStoredProcedure(DatabaseQuery, List<DatabaseField>, AbstractRecord, String) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Generates the stored procedure for this query using the row passed in for the check prepare.
generateStoredProcedures() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
PUBLIC: Use this method to generate stored procedures based on the dynamic SQL generated for your mappings and descriptors.
generateStoredProcedures() - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
PUBLIC: generates all the stored procedures using the schema manager.
generateStoredProcedures(Writer) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
PUBLIC: Use this method to generate stored procedures based on the dynamic SQL generated for your mappings and descriptors.
generateStoredProcedures(Writer) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
PUBLIC: generates all the stored procedures to the writer using the schema manager outputDDLToWriter(Writer).
generateStoredProceduresAndAmendmentClass(Writer, String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
PUBLIC: Use this method to generate stored procedures based on the dynamic SQL generated for your mappings and descriptors.
generateStoredProceduresAndAmendmentClass(String, String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
PUBLIC: Use this method to generate stored procedures based on the dynamic SQL generated for your mappings and descriptors.
generateUpdateStoredProcedure(ClassDescriptor) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Generates the update stored procedure for this descriptor
get() - Method in annotation type org.eclipse.persistence.annotations.VirtualAccessMethods
(Optional) The name of the getter method to use for the virtual property This method must take a single java.lang.String parameter and return a java.lang.Object.
get(int) - Method in class org.eclipse.persistence.indirection.IndirectList
 
get(int) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
get(int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
get(int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
get(int) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Wait until has the element or is complete.
get(int) - Method in class org.eclipse.persistence.internal.oxm.record.MarshalRecord.CycleDetectionStack
 
get(int, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ListContainerPolicy
INTERNAL: Returns the element at the specified position in this list.
get(FIELD) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractUnmarshalRecord
 
get(Exception) - Method in interface org.eclipse.persistence.internal.security.PrivilegedAccessHelper.CallableExceptionSupplier
 
get(Object) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
get(Object) - Method in class org.eclipse.persistence.internal.helper.ConcurrentFixedCache
Return the pre-parsed query that represents the EJBQL string.
get(Object) - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Returns the value to which the given key is mapped in this IdentityWeakHashMap.
get(Object) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
get(Object) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Return the object cached in the identity map or null if it could not be found.
get(Object) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Return the object cached in the identity map or null if it could not be found.
get(Object) - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Return null as no objects are cached.
get(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Retrieve the value for the field name.
get(Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Return the value for given item name.
get(Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Return the object cached in the identity map or null if it could not be found.
get(String) - Method in interface org.eclipse.persistence.dynamic.DynamicEntity
Return the persistence value for the given property as the specified type.
get(String) - Method in class org.eclipse.persistence.eis.EISMappedRecord
Forward the request to the record.
get(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that wraps the attribute or query key name.
get(String) - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
get(String) - Method in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
This is used by sub-selects in the from clause to define a virtual table, 'get' allows one of the sub-selected attributes to be aliased without using the field name.
get(String) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
This allows for nesting of parameterized expression.
get(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Retrieve the value for the field name.
get(String) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
PUBLIC: Add the field-value pair to the row.
get(String) - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Return the value for given item name.
get(String, boolean) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that wraps the attribute or query key name.
get(String, boolean) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
Return the expression from the attribute dervied from this expression.
get(Throwable) - Method in interface org.eclipse.persistence.internal.security.PrivilegedAccessHelper.CallableThrowableSupplier
 
get(CoreField) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
get(ConcurrencyManager, Map<ConcurrencyManager, CacheKeyToThreadRelationships>) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Helper method to make sure we never get null dto from the mapOfCacheKeyToDtosExplainingThreadExpectationsOnCacheKey.
get(DatabaseField) - Method in class org.eclipse.persistence.eis.EISMappedRecord
Forward the request to the record.
get(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: Retrieve the value for the field.
get(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
INTERNAL: Retrieve the value for the field.
get(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.ResultSetRecord
INTERNAL: Retrieve the value for the field.
get(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
INTERNAL: Retrieve the value for the field.
get(DatabaseField) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
get(DatabaseField) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
get(DatabaseField) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL: Retrieve the value for the field.
get(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.TableAliasLookup
 
GET_METHOD_RETURN_TYPE_NOT_VALID - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
GET_PROPERTY_METHOD_PREFIX - Static variable in class org.eclipse.persistence.internal.helper.Helper
 
getAboutToDeleteSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: bug 251180 - Missing method org.eclipse.persistence.descriptors.DescriptorEventManager#setAboutToDeleteSelector
getAboutToInsertSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL:
getAboutToUpdateSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL:
getAbstractSession() - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
Return the AbstractSession required to log to the non-platform EclipseLink log.
getAccessLevel() - Method in class org.eclipse.persistence.internal.codegen.CodeDefinition
 
getAccessor() - Method in class org.eclipse.persistence.eis.EISMappedRecord
Return the accessor.
getAccessor() - Method in exception org.eclipse.persistence.exceptions.DatabaseException
PUBLIC: Return the accessor.
getAccessor() - Method in class org.eclipse.persistence.internal.databaseaccess.ConnectionCustomizer
INTERNAL:
getAccessor() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: This should normally not be used, most sessions do not have a single accessor.
getAccessor() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The uow does not store a local accessor but shares its parents.
getAccessor() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Return the accessor associated with the cursor.
getAccessor() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the accessor.
getAccessor() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: This should normally not be used, getAccessors() should be used to support partitioning.
getAccessor() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Return the appropriate accessor.
getAccessor(String, AbstractSession, DatabaseQuery, boolean) - Method in class org.eclipse.persistence.descriptors.partitioning.PartitioningPolicy
INTERNAL: Return an accessor from the pool for the session.
getAccessors() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: This should normally not be used, most sessions do not have specific accessors.
getAccessors() - Method in class org.eclipse.persistence.internal.sessions.ExclusiveIsolatedClientSession
INTERNAL: Always use writeConnection.
getAccessors() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The uow does not store a local accessor but shares its parents.
getAccessors() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the accessors.
getAccessors() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Return the write connections if in a transaction.
getAccessors(Call, AbstractRecord, DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the connections to use for the query execution.
getAccessors(Call, AbstractRecord, DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the connections to use for the query execution.
getAccessors(Call, AbstractRecord, DatabaseQuery) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Return the low-level database accessors.
getAccessors(Call, AbstractRecord, DatabaseQuery) - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Return the connections to use for the query execution.
getAccessorTree() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
 
getAcquiredLocks() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
getAcquireWaitTime() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
getActiveBatchWritingMechanism(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
INTERNAL: This method is used internally to return the active batch writing mechanism to batch the statement
getActiveCacheKey() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: PERF: Return the session cache-key, cached during the merge.
getActiveCommandThreads() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL:
getActiveLocks() - Method in class org.eclipse.persistence.internal.helper.DeferredLockManager
Return a set of the active locks from the DLM
getActiveSequencingCallback(DatabaseSession, SequencingCallbackFactory) - Method in interface org.eclipse.persistence.sessions.ExternalTransactionController
INTERNAL: Returns sequencingCallback for the current active external transaction.
getActiveSequencingCallback(DatabaseSession, SequencingCallbackFactory) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Returns sequencingCallback for the current active external transaction.
getActiveSession() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the active session for the current active external (JTS) transaction.
getActiveSession() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the active session for the current active external (JTS) transaction.
getActiveThread() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Return the active thread.
getActiveThread() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Return the active thread.
getActiveThread() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
Return the active thread.
getActiveUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the active unit of work for the current active external (JTS) transaction.
getActiveUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Return the active unit of work for the current active external (JTS) transaction.
getActiveUnitOfWork() - Method in interface org.eclipse.persistence.sessions.ExternalTransactionController
INTERNAL: Return the active unit of work for the current active external transaction.
getActiveUnitOfWork() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the active unit of work for the current active external (JTS) transaction.
getActiveUnitOfWork() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return the active unit of work for the current external transaction.
getActualTypeClassName() - Method in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
 
getAddedElements() - Method in interface org.eclipse.persistence.indirection.IndirectCollection
INTERNAL: Return if the collection has any elements added that have been deferred to instantiation.
getAddedElements() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Return the elements that have been added before instantiation.
getAddedElements() - Method in class org.eclipse.persistence.indirection.IndirectMap
INTERNAL: Return the elements that have been added before instantiation.
getAddedElements() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Return the elements that have been added before instantiation.
getAddedOrRemovedObject() - Method in class org.eclipse.persistence.internal.sessions.OrderedChangeObject
 
getAddIndexes() - Method in class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
ADVANCED: Return the indexes into the new collection of the elements that were added.
getAddIndexes() - Method in interface org.eclipse.persistence.sessions.changesets.EISOrderedCollectionChangeRecord
ADVANCED: Return the indexes into the new collection of the elements that were added.
getAdditional() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Return any additional information about this field to be given when the table is created.
getAdditionalAggregateCollectionKeyFields() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: additionalAggregateCollectionKeyFields are used by aggregate descriptors to hold additional fields needed when they are stored in an AggregatateCollection These fields are generally foreign key fields that are required in addition to the fields in the descriptor's mappings to uniquely identify the Aggregate
getAdditionalExpression() - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
 
getAdditionalFieldExpressions() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Get the list of additional field expressions.
getAdditionalFieldExpressions_() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Get the list of additional field expressions.
getAdditionalFields() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Additional fields can be added to a query.
getAdditionalFieldsBaseExpression(ReadQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Return the base expression to use for adding fields to the query.
getAdditionalFieldsBaseExpression(ReadQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return the base expression to use for adding fields to the query.
getAdditionalFieldsBaseExpression(ReadQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Return the base expression to use for adding fields to the query.
getAdditionalFieldsForJoin(CollectionMapping) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return any additional fields required by the policy for a fetch join.
getAdditionalFieldsForJoin(CollectionMapping) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Return any additional fields required by the policy for a fetch join.
getAdditionalFieldsForJoin(CollectionMapping) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Return any additional fields required by the policy for a fetch join.
getAdditionalJoinExpression() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Returns the join expression that should be appended to all of the descriptors expressions Contains any multiple table or inheritance dependencies
getAdditionalProjects() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.DatabaseSessionConfig
 
getAdditionalSelectionCriteriaForMapKey() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return the selection criteria necessary to select the target object when this mapping is a map key.
getAdditionalSelectionCriteriaForMapKey() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Return the selection criteria necessary to select the target object when this mapping is a map key.
getAdditionalSelectionCriteriaForMapKey() - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Return the selection criteria necessary to select the target object
getAdditionalSelectionCriteriaForMapKey() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return the selection criteria necessary to select the target object when this mapping is a map key.
getAdditionalTablePrimaryKeyFields() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: This is used to map the primary key field names in a multiple table descriptor.
getAdditionalTables() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
Return any tables in addition to the descriptor's tables, such as the mappings join table.
getAdditionalTables() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Return any additional tables that belong to this expression An example of how this method is used is to return any tables that belong to the map key when this expression traverses a mapping that uses a Map
getAdditionalTables() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
getAdditionalTablesForJoinQuery() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return any tables that will be required when this mapping is used as part of a join query.
getAdditionalTablesForJoinQuery() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Return any tables that will be required when this mapping is used as part of a join query.
getAdditionalTablesForJoinQuery() - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Return any tables that will be required when this mapping is used as part of a join query.
getAdditionalTablesForJoinQuery() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return any tables that will be required when this mapping is used as part of a join query
getAdditionalTablesForJoinQuery() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Return any tables that will be required when this mapping is used as part of a join query.
getAdditionalTablesForJoinQuery() - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Return any tables that will be required when this mapping is used as part of a join query
getAdditionalTablesForJoinQuery() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return any tables that will be required when this mapping is used as part of a join query
getAdditionalVersions() - Method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Get additional version numbers.
getAdditionalWritableMapKeyFields() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return a list of fields that are written by map keys Used to determine if there is a multiple writable mappings issue
getAdditonal() - Method in class org.eclipse.persistence.tools.schemaframework.TypeTableDefinition
PUBLIC: The name of the type that this table is of.
getAddObjectList() - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
ADVANCED: This method returns the collection of ChangeSets that were added to the collection.
getAddObjectList() - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
ADVANCED: This method returns the list of added objects.
getAddObjectList() - Method in interface org.eclipse.persistence.sessions.changesets.CollectionChangeRecord
ADVANCED: This method returns the Map that contains the added values to the collection and their corresponding ChangeSets.
getAddObjectList() - Method in interface org.eclipse.persistence.sessions.changesets.DirectCollectionChangeRecord
ADVANCED: This method returns the collection of Primitive Objects that were added to the collection.
getAddObjectMap() - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
This method returns the collection of objects that were added to the collection.
getAddObjects() - Method in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
Returns the added items list.
getAddOverFlow() - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Returns a list of extra adds.
getAdds() - Method in class org.eclipse.persistence.eis.EISCollectionChangeRecord
ADVANCED: Return the added stuff.
getAdds() - Method in class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
ADVANCED: Return the entries for all the elements added to the new collection.
getAdds() - Method in interface org.eclipse.persistence.sessions.changesets.EISCollectionChangeRecord
ADVANCED: Return the objects added to the collection.
getAdds() - Method in interface org.eclipse.persistence.sessions.changesets.EISOrderedCollectionChangeRecord
ADVANCED: Return the entries for all the elements added to the new collection.
getAggregateChangeSets() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Get the Aggregate list.
getAggregateQueries() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the cache of aggregate queries.
getAggregateQuery(DatabaseMapping) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the aggregate query clone for the mapping.
getAggregateRow(ObjectLevelModifyQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: return the aggregate Record with the primary keys from the source table and target table
getAggregateToSourceFieldAssociations() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return a collection of the aggregate to source field associations.
getAggregateToSourceFields() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return the hashtable that stores aggregate field name to source fields.
getAlias() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Get the alias
getAlias() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Get the alias
getAlias(Expression) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression representing a sub-select in the from clause.
getAlias(Expression) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
ADVANCED: Return an expression representing a sub-select in the from clause.
getAlias(Expression) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
getAliasDescriptors() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Returns the alias descriptors Map.
getAliasDescriptors() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Returns the alias descriptors hashtable.
getAliasedField() - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
INTERNAL: Return the field appropriately aliased
getAliasedField() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL: Return the field appropriately aliased
getAliasedField() - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: Return the field appropriately aliased
getAliasedField() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Return the field appropriately aliased
getAliasedFieldsForExpression() - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
getAliasedTable() - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
Return the alias for our table
getAliasedTable() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
Return the alias for our table
getAliasedViewTable() - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL:
getAliasesOfTablesToBeLocked(SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.ForUpdateClause
INTERNAL: Returns collection of aliases of the tables to be locked.
getAliasesOfTablesToBeLocked(SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.ForUpdateOfClause
INTERNAL: Returns collection of aliases of the tables to be locked.
getAliasFor(DatabaseField) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
getAliasTableName(SQLSelectStatement, DatabaseTable, DatasourcePlatform) - Static method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
getAll() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
getAll() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
getAll() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
getAll() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getAllCacheKeysFromIdentityMapWithEntityPK(Object[], ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Using a list of Entity PK this method will attempt to bulk load the entire list from the cache.
getAllCacheKeysFromIdentityMapWithEntityPK(Object[], ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
ADVANCED: Using a list of Entity PK this method will attempt to bulk load the entire list from the cache.
getAllCacheKeysFromIdentityMapWithEntityPK(Object[], ClassDescriptor, AbstractSession) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
ADVANCED: Using a list of Entity PK this method will attempt to bulk load the entire list from the cache.
getAllCacheKeysFromIdentityMapWithEntityPK(Object[], ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
ADVANCED: Using a list of Entity PK this method will attempt to bulk load the entire list from the cache.
getAllCacheKeysFromIdentityMapWithEntityPK(Object[], ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
ADVANCED: Using a list of Entity PK this method will attempt to bulk load the entire list from the cache.
getAllChangeSets() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: This method returns a reference to the collection.
getAllChangeSets() - Method in interface org.eclipse.persistence.sessions.changesets.UnitOfWorkChangeSet
ADVANCED: This method returns a reference to the collection.
getAllChildClassIndicators() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Stores class indicators for all child and children's children.
getAllChildDescriptors() - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL: Returns all the child descriptors, even descriptors for subclasses of subclasses.
getAllChildDescriptors() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Returns all the child descriptors, even descriptors for subclasses of subclasses.
getAllChildDescriptors(List<ClassDescriptor>) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Recursive subroutine of getAllChildDescriptors.
getAllClasses() - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Return all of the objects registered.
getAllColumnNames(String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Get a description of table columns available in a catalog.
getAllColumnNames(String, String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Get a description of table columns available in a catalog.
getAllDataResults() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Return temporary list of rows from parent batch query per batched mapping.
getAllFields() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return all the fields which include all child class fields.
getAllFields() - Method in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
getAllFieldsForMapKey() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Get all the fields for the map key
getAllFieldsForMapKey() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Get all the fields for the map key.
getAllFieldsForMapKey() - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Get all the fields for the map key
getAllFieldsForMapKey() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Get all the fields for the map key
getAllFromIdentityMap(Expression, Class<?>, DataRecord) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Query the cache in-memory.
getAllFromIdentityMap(Expression, Class<?>, DataRecord, int) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Query the cache in-memory.
getAllFromIdentityMap(Expression, Class<?>, DataRecord, int) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Queries the cache in-memory with the passed in criteria and returns matching Objects.
getAllFromIdentityMap(Expression, Class<?>, DataRecord, int, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Query the cache in-memory.
getAllFromIdentityMap(Expression, Class<?>, DataRecord, int, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Query the cache in-memory.
getAllFromIdentityMap(Expression, Class<?>, DataRecord, int, boolean) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
ADVANCED: Query the cache in-memory.
getAllFromIdentityMap(Expression, Class<?>, DataRecord, int, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
INTERNAL: This method overrides the getAllFromIdentityMap method in Session.
getAllFromIdentityMap(Expression, Class<?>, DataRecord, int, boolean) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Queries the cache in-memory with the passed in criteria and returns matching Objects.
getAllFromIdentityMap(Expression, Class<?>, DataRecord, InMemoryQueryIndirectionPolicy) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Query the cache in-memory.
getAllFromIdentityMap(Expression, Class<?>, DataRecord, InMemoryQueryIndirectionPolicy) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Queries the cache in-memory with the passed in criteria and returns matching Objects.
getAllFromIdentityMap(Expression, Class<?>, DataRecord, InMemoryQueryIndirectionPolicy, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Query the cache in-memory.
getAllFromIdentityMap(Expression, Class<?>, DataRecord, InMemoryQueryIndirectionPolicy, boolean) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Queries the cache in-memory with the passed in criteria and returns matching Objects.
getAllFromIdentityMapWithEntityPK(Object[], ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Using a list of Entity PK this method will attempt to bulk load the entire list from the cache.
getAllFromIdentityMapWithEntityPK(Object[], ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
ADVANCED: Using a list of Entity PK this method will attempt to bulk load the entire list from the cache.
getAllFromIdentityMapWithEntityPK(Object[], ClassDescriptor, AbstractSession) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
ADVANCED: Using a list of Entity PK this method will attempt to bulk load the entire list from the cache.
getAllFromIdentityMapWithEntityPK(Object[], ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
ADVANCED: Using a list of Entity PK this method will attempt to bulk load the entire list from the cache.
getAllFromIdentityMapWithEntityPK(Object[], ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
ADVANCED: Using a list of Entity PK this method will attempt to bulk load the entire list from the cache.
getAllFromNewObjects(Expression, Class<?>, AbstractRecord, int) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return any new objects matching the expression.
getAllInternalOperators() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL:
getAllItems() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL:
getAllManagers() - Static method in class org.eclipse.persistence.sessions.factories.SessionManager
ADVANCED: Return all session managers.
getAllMemberTypes() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Union
 
getAllNodeValues() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
getAllNodeValues() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
getAllNonPrimaryKeyFields() - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Returns the fields that should be compared in the where clause.
getAllNonPrimaryKeyFields(DatabaseTable) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: filter the fields based on the passed in table.
getAllObjects() - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Return all of the objects registered.
getAllObjectsForAbstractClass(Class<?>) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Return all of the objects of the class and all of its subclasses.
getAllObjectsForAbstractClass(Class<?>, AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Return all of the objects of the class and all of its subclasses.
getAllObjectsForClass(Class<?>) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Return all of the objects of the class.
getAllOperators() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Return the map of all operators.
getAllowingNull(String) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression that wraps the attribute or query key name.
getAllowingNull(String) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
getAllQueries() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Return the pre-defined queries for the descriptor.
getAllQueries() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the pre-defined queries in this session.
getAllSelectionFields() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return all selection fields which include all child class fields.
getAllSelectionFields() - Method in interface org.eclipse.persistence.descriptors.SerializedObjectPolicy
Lists the database fields that should be read by the query using the policy, in case all inherited objects are read using outer joining.
getAllSelectionFields() - Method in class org.eclipse.persistence.internal.descriptors.SerializedObjectPolicyWrapper
 
getAllSelectionFields(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return all selection fields which include all child class fields.
getAllTableNames() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Get a description of tables available in a catalog.
getAllTableNames(String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Get a description of table columns available in a catalog.
getAllTables() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: all tables for reference class plus childrenTables
getAmendmentClass() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the amendment class.
getAmendmentClassName() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return amendment class name, used by the MW.
getAmendmentMethodName() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the amendment method.
getAndCloneCacheKeyFromParent(Object, Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
 
getAndCloneCacheKeyFromParent(Object, Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
INTERNAL: This method will return the object from the parent and clone it.
getAndPrepareModifyQueryForInsert(ObjectLevelModifyQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: setup the modifyQuery for post insert/update and pre delete
getAnnotation() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
getAnnotation() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
getAnnotation() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
getAnnotation() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
getAnnouncementDelay() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.discovery.DiscoveryConfig
 
getAnnouncementDelay() - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
PUBLIC: Return the amount of time in millis that the service should wait between the time that this Remote Service is available and a session announcement is sent out to other discovery managers.
getAnyAttribute() - Method in class org.eclipse.persistence.internal.oxm.schema.model.AttributeGroup
 
getAnyAttribute() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
getAnyAttribute() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
getAnyAttribute() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getAnyAttributeNode() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getAnyAttributeNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getAnyMapping() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
getAnyMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
getAnyNode() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getAppInfo() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Annotation
 
getApplicationName() - Method in interface org.eclipse.persistence.platform.server.JMXEnabledPlatform
INTERNAL: getApplicationName(): Answer the name of the module (EAR name) that this session is associated with.
getApplicationName() - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
INTERNAL: getApplicationName(): Answer the name of the module (EAR name) that this session is associated with.
getApplicationName() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
getApplicationName(): Answer the name of the module (EAR name) that this session is associated with.
getApplicationName() - Method in class org.eclipse.persistence.services.RuntimeServices
getApplicationName(): Answer the name of the module (EAR name) that this session is associated with.
getApplicationName(boolean) - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
INTERNAL: Lazy initialize the application name by first checking for a persistence.xml property override and then deferring to a default name in the absence of a platform override of this function
getArgumentIndices(int) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
Return the argumentIndices if set, otherwise initialize argumentIndices to the provided size
getArgumentName() - Method in class org.eclipse.persistence.internal.descriptors.InteractionArgument
 
getArgumentName(int) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
getArgumentNames() - Method in class org.eclipse.persistence.eis.interactions.MappedInteraction
The argument names for the input record.
getArgumentNames() - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
getArgumentParameterTypes() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Used to calculate parameter types in JPQL
getArguments() - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
The argument fields or values to the interaction that map into the input record.
getArguments() - Method in class org.eclipse.persistence.eis.interactions.IndexedInteraction
The arguments are the values in order of occurance in the record.
getArguments() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
Return the PLSQL arguments.
getArguments() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the arguments for use with the pre-defined query option
getArguments() - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The arguments are the names of the parameters to the procedure.
getArguments(List<PLSQLargument>, DatasourceCall.ParameterType) - Static method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
INTERNAL
getArgumentTypeNames() - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
getArgumentTypeNames() - Method in class org.eclipse.persistence.internal.codegen.NonreflectiveMethodDefinition
 
getArgumentTypeNames() - Method in class org.eclipse.persistence.internal.codegen.ReflectiveMethodDefinition
 
getArgumentTypeNames() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the argumentTypeNames for use with the pre-defined query option These are used pre-initialization to construct the argumentTypes list.
getArgumentTypes() - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
getArgumentTypes() - Method in class org.eclipse.persistence.internal.codegen.NonreflectiveMethodDefinition
 
getArgumentTypes() - Method in class org.eclipse.persistence.internal.codegen.ReflectiveMethodDefinition
 
getArgumentTypes() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the argumentTypes for use with the pre-defined query option
getArgumentTypes() - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
 
getArgumentValues() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the argumentValues for use with argumented queries.
getAsOfClause() - Method in class org.eclipse.persistence.expressions.Expression
Answers the past time the expression is explicitly as of.
getAsOfClause() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
getAsOfClause() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Answers the past time this session is as of.
getAsOfClause() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
ADVANCED: Answers the past time this query is as of.
getAsOfClause() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
ADVANCED: Answers the past time this session is as of.
getAsOfClause() - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Answers the past time this session is as of.
getAsOfClauseRecursively() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: For Flashback: If this expression is not already as of some timestamp gets the clause from the base expression.
getAssignedFields() - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForTempTable
 
getAssignmentString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for stored function calls.
getAssignmentString() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Used for stored function calls.
getAssignmentString() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL Used for stored function calls.
getAttachmentAsByteArray(String) - Method in interface org.eclipse.persistence.oxm.attachment.XMLAttachmentUnmarshaller
 
getAttachmentAsDataHandler(String) - Method in interface org.eclipse.persistence.oxm.attachment.XMLAttachmentUnmarshaller
 
getAttachmentMarshaller() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
 
getAttachmentMarshaller() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
getAttachmentUnmarshaller() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
 
getAttachmentUnmarshaller() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
getAttribute() - Method in class org.eclipse.persistence.internal.sessions.ChangeRecord
ADVANCED: Returns the name of the attribute this ChangeRecord Represents
getAttribute() - Method in interface org.eclipse.persistence.sessions.changesets.ChangeRecord
ADVANCED: Returns the name of the attribute this ChangeRecord Represents
getAttributeAccessor() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
ADVANCED: Return the attributeAccessor.
getAttributeAccessor() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
 
getAttributeAccessor() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: Return the attributeAccessor.
getAttributeChildNodeValue(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.BinaryDataUnmarshalRecord
 
getAttributeChildNodeValue(String, String) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getAttributeChildNodeValue(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getAttributeChildNodeValue(String, String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getAttributeChildren() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getAttributeChildrenMap() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getAttributeClass() - Method in interface org.eclipse.persistence.core.mappings.CoreAttributeAccessor
Return the class type of the attribute.
getAttributeClass() - Method in class org.eclipse.persistence.internal.descriptors.InstanceVariableAttributeAccessor
Returns the class type of the attribute.
getAttributeClass() - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Return the return type of the method accessor.
getAttributeClass() - Method in class org.eclipse.persistence.internal.dynamic.ValuesAccessor
 
getAttributeClass() - Method in class org.eclipse.persistence.mappings.AttributeAccessor
Return the class type of the attribute.
getAttributeClassification() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
PUBLIC: The classification type for the attribute this mapping represents
getAttributeClassification() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
The classification type for the attribute this mapping represents
getAttributeClassification() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
PUBLIC: The classification type for the attribute this mapping represents
getAttributeClassification() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: The classification type for the attribute this mapping represents
getAttributeClassification() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Some databases do not properly support all of the base data types.
getAttributeClassification() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
PUBLIC: Some databases do not properly support all of the base data types.
getAttributeClassificationName() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return the class name of the attribute type.
getAttributeClassificationName() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Return the class name of the attribute type.
getAttributeConverter() - Method in class org.eclipse.persistence.mappings.converters.ConverterClass
 
getAttributeElementClass() - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
 
getAttributeElementClass() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
Return the class each element in the object's collection should be converted to, before the collection is inserted into the object.
getAttributeElementClass() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
PUBLIC: Return the class each element in the object's collection should be converted to, before the collection is inserted into the object.
getAttributeElementClass() - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
getAttributeExpression() - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
getAttributeExpressions() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Return all attributes specified for batch reading.
getAttributeField() - Method in class org.eclipse.persistence.internal.descriptors.InstanceVariableAttributeAccessor
Returns the value of attributeField.
getAttributeGroup(String) - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
PUBLIC: Returns the attribute group corresponding to the name provided.
getAttributeGroup(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
 
getAttributeGroup(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
 
getAttributeGroup(String, String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getAttributeGroupFromReferencedSchemas(String, String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getAttributeGroups() - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
ADVANCED: Returns the attribute groups for this Descriptor.
getAttributeGroups() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
 
getAttributeGroups() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getAttributeGroups() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED Return all predefined attribute groups
getAttributeGroups() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: List of named AttributesGroups that will be copied to the session at initialization time.
getAttributeMethodName() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Return the attribute transformation method name.
getAttributeName() - Method in interface org.eclipse.persistence.core.mappings.CoreAttributeAccessor
INTERNAL: Return the attribute name.
getAttributeName() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
PUBLIC: Return the name of the attribute set in the mapping.
getAttributeName() - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
getAttributeName() - Method in interface org.eclipse.persistence.descriptors.CMPPolicy.KeyElementAccessor
 
getAttributeName() - Method in class org.eclipse.persistence.descriptors.CMPPolicy.KeyIsElementAccessor
 
getAttributeName() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
Return the name of the attribute set in the mapping.
getAttributeName() - Method in class org.eclipse.persistence.internal.queries.AttributeItem
 
getAttributeName() - Method in class org.eclipse.persistence.mappings.AttributeAccessor
INTERNAL: Return the attribute name.
getAttributeName() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: Return the name of the attribute set in the mapping.
getAttributeName() - Method in interface org.eclipse.persistence.mappings.EmbeddableMapping
 
getAttributeName() - Method in interface org.eclipse.persistence.mappings.structures.ArrayCollectionMapping
Return the mapping's attribute name.
getAttributeName() - Method in class org.eclipse.persistence.queries.FieldResult
 
getAttributeNameFromMethodName(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
INTERNAL: Method to convert a getXyz or isXyz method name to an xyz attribute name.
getAttributeNames() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
getAttributePrefix() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Value that will be used to prefix attributes.
getAttributePrefix() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Value that will be used to prefix attributes.
getAttributePrefix() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Value that will be used to prefix attributes.
getAttributes() - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
getAttributes() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getAttributes() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getAttributes() - Method in class org.eclipse.persistence.internal.oxm.schema.model.AttributeGroup
 
getAttributes() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getAttributes() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getAttributes() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: PERF: Return the cached local (only) batch read attribute names.
getAttributesMap() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
getAttributesMap() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getAttributesMap() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
getAttributesMap() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
getAttributesToAlwaysInclude() - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: Attributes to always consider even if set to null or an excluded value like 0 or false.
getAttributesToChanges() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: stores the change records indexed by the attribute names
getAttributeToFieldValues() - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Get the attribute to field mapping.
getAttributeTransformationMethod() - Method in class org.eclipse.persistence.mappings.transformers.MethodBasedAttributeTransformer
 
getAttributeTransformer() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: The attributeTransformer stores an instance of the class which implements AttributeTransformer.
getAttributeTransformerClass() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Return the attribute transformer's class.
getAttributeTransformerClassName() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Return the attribute transformer class name
getAttributeType() - Method in class org.eclipse.persistence.internal.descriptors.InstanceVariableAttributeAccessor
Returns the declared type of attributeField.
getAttributeValue(Object, ABSTRACT_SESSION, AbstractUnmarshalRecord) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
 
getAttributeValue(Object, Mapping) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalContext
 
getAttributeValue(Object, Mapping) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectMarshalContext
 
getAttributeValue(Object, Mapping) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedMarshalContext
 
getAttributeValue(Object, AbstractSession, AbstractUnmarshalRecord) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
INTERNAL: Allows for subclasses to convert the attribute value.
getAttributeValueFromBackupClone(Object) - Method in class org.eclipse.persistence.mappings.AggregateMapping
Return the appropriate attribute value.
getAttributeValueFromBackupClone(Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
Return the appropriate attribute value.
getAttributeValueFromObject(Object) - Method in interface org.eclipse.persistence.core.mappings.CoreAttributeAccessor
Return the attribute value from the object.
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Return the value of an attribute which this mapping represents for an object.
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.internal.descriptors.InstanceVariableAttributeAccessor
Returns the value of the attribute on the specified object.
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Gets the value of an instance variable in the object.
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.internal.descriptors.MultitenantPrimaryKeyAccessor
 
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.internal.descriptors.PersistenceObjectAttributeAccessor
Returns the value of the attribute on the specified object.
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeAccessor
Gets the value of an instance variable in the object.
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.internal.dynamic.ValuesAccessor
 
getAttributeValueFromObject(Object) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
 
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.IsSetNullPolicyIsSetParametersAttributeAccessor
 
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.IsSetNullPolicyIsSetParameterTypesAttributeAccessor
 
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.NullPolicyAttributeAccessor
 
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.mappings.AttributeAccessor
Return the attribute value from the object.
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return the value of an attribute which this mapping represents for an object.
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return the value of an attribute which this mapping represents for an object.
getAttributeValueFromObject(Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Check for write-only, one-way transformation.
getAttributeValueFromObject(Object, Object[]) - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Gets the value of an instance variable in the object.
getAttributeValueWithClonedValueHolders(Object) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Returns the attribute value from the reference object.
getAvailableConnectionPools() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will return the available Connection pools within this Server Session
getAvailableConnectionPools() - Method in class org.eclipse.persistence.services.RuntimeServices
This method will return the available Connection pools within this Server Session
getBackupClone() - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
INTERNAL: Return the backup clone of the object from the unit of work.
getBackupClone(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the backup clone for the working clone.
getBackupClone(Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the backup clone for the working clone.
getBackupCloneForCommit(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the backup clone for the working clone.
getBackupCloneForCommit(Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the backup clone for the working clone.
getBackupValueHolder() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
getBaseChangeRecordForField(ObjectChangeSet, Object, DatabaseField, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the base ChangeRecord for the given DatabaseField.
getBaseExpression() - Method in class org.eclipse.persistence.internal.expressions.BaseExpression
The base expression is what the parameter was derived from.
getBaseExpressionBuilder() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Returns the base expression builder for this query.
getBaseMappingForField(DatabaseField) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the base mapping for the given DatabaseField.
getBaseQuery() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Returns the base query.
getBaseType() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
getBaseType() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getBaseValue() - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: This is the base value that is older than all other values, it is used in the place of null in some situations.
getBaseValue() - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: This is the base value that is older than all other values, it is used in the place of null in some situations.
getBaseValue() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: This is the base value that is older than all other values, it is used in the place of null in some situations.
getBaseValue() - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: This is the base value that is older than all other values, it is used in the place of null in some situations.
getBaseValueForField(DatabaseField, Object) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the base value that is mapped to for given field.
getBatchBeginString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for batch writing and sp defs.
getBatchBeginString() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Used for batch writing and sp defs.
getBatchBeginString() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
Used for batch writing and sp defs.
getBatchDelimiterString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for batch writing and sp defs.
getBatchDelimiterString() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
Used for batch writing and sp defs.
getBatchDelimiterString() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Used for batch writing and sp defs.
getBatchDelimiterString() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Used for batch writing and sp defs.
getBatchedMappings() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Return any mappings that are always batched.
getBatchEndString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for batch writing and sp defs.
getBatchEndString() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Used for batch writing and sp defs.
getBatchEndString() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
Used for batch writing and sp defs.
getBatchFetchedAttributes() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the mappings that are always batch fetched.
getBatchFetchPolicy() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Return the batch fetch policy for configuring batch fetching.
getBatchFetchType() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Return the type of batch fetching to use for all queries for this class if configured.
getBatchObjects() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Return temporary map of batched objects.
getBatchObjects() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return temporary map of batched objects.
getBatchObjects() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return temporary map of batched objects.
getBatchQueries() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: When in transaction batch read objects must use query local to the unit of work.
getBatchReadAttributeExpressions() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return all attributes specified for batch reading.
getBatchRowCountAssignString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for batch writing for row count return.
getBatchRowCountAssignString() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Used for batch writing for row count return.
getBatchRowCountDeclareString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for batch writing for row count return.
getBatchRowCountDeclareString() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Used for batch writing for row count return.
getBatchRowCountReturnString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for batch writing for row count return.
getBatchRowCountReturnString() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Used for batch writing for row count return.
getBatchWriting() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getBatchWritingMechanism() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return the custom batch writing mechanism.
getBidirectionalTargetAccessor() - Method in class org.eclipse.persistence.oxm.mappings.BidirectionalPolicy
Gets the AttributeAccessor that is used to get and set the value of the container on the target object.
getBidirectionalTargetAttributeName() - Method in class org.eclipse.persistence.oxm.mappings.BidirectionalPolicy
Gets the name of the backpointer attribute on the target object.
getBidirectionalTargetContainerPolicy() - Method in class org.eclipse.persistence.oxm.mappings.BidirectionalPolicy
 
getBidirectionalTargetGetMethodName() - Method in class org.eclipse.persistence.oxm.mappings.BidirectionalPolicy
Gets the name of the method to be used when accessing the value of the back pointer on the target object of this mapping.
getBidirectionalTargetSetMethodName() - Method in class org.eclipse.persistence.oxm.mappings.BidirectionalPolicy
Gets the name of the method to be used when setting the value of the back pointer on the target object of this mapping.
getBigDecimalType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the BigDecimal type representation.
getBigIntegerType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the BigInteger type representation.
getBindAllParameters() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getBooleanClassType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the Boolean class representation.
getBooleanType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the boolean type representation.
getBroker() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Allow the session to be used from a session broker.
getBuildDate() - Static method in class org.eclipse.persistence.Version
 
getBuilder() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Return the expression builder which is the ultimate base of this expression, or null if there isn't one (shouldn't happen if we start from a root)
getBuilder() - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Return the expression builder which is the ultimate base of this expression, or null if there isn't one (shouldn't happen if we start from a root)
getBuilder() - Method in class org.eclipse.persistence.internal.expressions.BaseExpression
Return the expression builder which is the ultimate base of this expression, or null if there isn't one (shouldn't happen if we start from a root).
getBuilder() - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
Return the expression builder which is the ultimate base of this expression, or null if there isn't one (shouldn't happen if we start from a root)
getBuilder() - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
Return the expression builder which is the ultimate base of this expression, or null if there isn't one (shouldn't happen if we start from a root)
getBuilder() - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
Return the expression builder which is the ultimate base of this expression, or null if there isn't one (shouldn't happen if we start from a root)
getBuilder() - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
Return the expression builder which is the ultimate base of this expression, or null if there isn't one (shouldn't happen if we start from a root)
getBuilder() - Method in class org.eclipse.persistence.internal.expressions.SQLStatement
 
getBuilderString() - Method in class org.eclipse.persistence.internal.expressions.ExpressionJavaPrinter
 
getBuildNumber() - Static method in class org.eclipse.persistence.Version
 
getBuildObjectCompleteWaitTime() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
getBuildRevision() - Static method in class org.eclipse.persistence.Version
 
getBuildTime() - Static method in class org.eclipse.persistence.Version
 
getBuildType() - Static method in class org.eclipse.persistence.Version
 
getByIndex(int) - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Return the indexed value from result.
getByteArrayBinding() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getByteClassType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the Byte class representation.
getBytesForBinaryValue(Object, Marshaller, String) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
getBytesForSingleBinaryValue(Object, Marshaller, String) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
getBytesFromByteObjectArray(Byte[], String) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
getBytesFromDataHandler(DataHandler) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
getBytesFromImage(Image, String) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
getBytesFromMultipart(MimeMultipart, Marshaller) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
getBytesFromSource(Source, Marshaller, String) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
getBytesListForBinaryValues(List, Marshaller, String) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
getByteType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the byte type representation.
getCache() - Method in class org.eclipse.persistence.internal.helper.ConcurrentFixedCache
Return the cache.
getCacheAllStatements() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getCachedConnection() - Method in class org.eclipse.persistence.sessions.server.ExternalConnectionPool
INTERNAL: Return the currently cached connection to the external connection pool
getCachedExpressionQuery(DatabaseQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Return the cached SQL call for the expression query.
getCachedPKs() - Method in class org.eclipse.persistence.internal.indirection.CacheBasedValueHolder
 
getCachedUpdateCalls(Vector) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Return the cached update SQL call based on the updated fields.
getCacheIndex(List<DatabaseField>) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Return the cache index for the field names.
getCacheIndexes() - Method in class org.eclipse.persistence.descriptors.CachePolicy
 
getCacheInterceptorClass() - Method in class org.eclipse.persistence.descriptors.CachePolicy
A CacheInterceptor is an adaptor that when overridden and assigned to a Descriptor all interaction between EclipseLink and the internal cache for that class will pass through the Interceptor.
getCacheInterceptorClass() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A CacheInterceptor is an adaptor that when overridden and assigned to a Descriptor all interaction between EclipseLink and the internal cache for that class will pass through the Interceptor.
getCacheInterceptorClassName() - Method in class org.eclipse.persistence.descriptors.CachePolicy
A CacheInterceptor is an adaptor that when overridden and assigned to a Descriptor all interaction between EclipseLink and the internal cache for that class will pass through the Interceptor.
getCacheInterceptorClassName() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A CacheInterceptor is an adaptor that when overridden and assigned to a Descriptor all interaction between EclipseLink and the internal cache for that class will pass through the Interceptor.
getCacheInvalidationPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the CacheInvalidationPolicy for this descriptor For uninitialized cache invalidation policies, this will return a NoExpiryCacheInvalidationPolicy
getCacheInvalidationPolicy() - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Return the query cache invalidation policy.
getCacheIsolation() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Controls how the Entity instances will be cached.
getCacheIsolation() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Controls how the Entity instances will be cached.
getCacheKey(Object, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Get the cache key (with object) for the primary key.
getCacheKey(Object, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.CacheIdentityMap
Access the object within the table for the given primaryKey.
getCacheKey(Object, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Return the cache key matching the primary key of the searchKey.
getCacheKey(Object, boolean) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Get the cache key (with object) for the primary key.
getCacheKey(Object, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Return null as no objects are cached.
getCacheKey(Object, boolean) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Get the cache key (with object) for the primary key.
getCacheKeyBeingDescribed() - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
getCacheKeyByIndex(CacheIndex, CacheId, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Return the cache key for the cache index or null if not found.
getCacheKeyByIndex(CacheIndex, CacheId, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
Return the cache key for the cache index or null if not found.
getCacheKeyByIndex(CacheIndex, CacheId, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
Return the cache key for the cache index or null if not found.
getCacheKeyForLock(Object) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Get the cache key (with object) for the primary key.
getCacheKeyForLock(Object) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Get the cache key (with object) for the primary key in order to acquire a lock.
getCacheKeyForLock(Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Get the cache key (with object) for the primary key.
getCacheKeyForObject(Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Retrieve the cache key for the given object.
getCacheKeyForObject(Object, Class<?>, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Retrieve the cache key for the given identity information.
getCacheKeyForObject(Object, Class<?>, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Retrieve the cache key for the given identity information.
getCacheKeyForObject(Object, Class<?>, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Retrieve the cache key for the given identity information.
getCacheKeyForObject(Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Retrieve the cache key for the given object from the identity maps.
getCacheKeyForObjectForLock(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Retrieve the cache key for the given identity information.
getCacheKeyForObjectForLock(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Retrieve the cache key for the given identity information.
getCacheKeyForObjectForLock(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Retrieve the cache key for the given identity information.
getCacheKeyFromTargetSessionForMerge(Object, ObjectBuilder, ClassDescriptor, MergeManager) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: For use within the merge process this method will get an object from the shared cache using a readlock.
getCacheKeyFromTargetSessionForMerge(Object, ObjectBuilder, ClassDescriptor, MergeManager) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSession
INTERNAL: For use within the merge process this method will get an object from the shared cache using a readlock.
getCacheKeyOwnedByBlockingThread() - Method in class org.eclipse.persistence.internal.helper.type.IsBuildObjectCompleteOutcome
getCacheKeys() - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Return the cache keys.
getCacheKeyThreadWantsToAcquireButCannotGet() - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
getCacheKeyType() - Method in class org.eclipse.persistence.descriptors.CachePolicy
ADVANCED: Return what cache key type to use to store the object in the cache.
getCacheKeyType() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Return what cache key type to use to store the object in the cache.
getCacheKeyWhoseNumberOfReadersThreadIsIncrementing() - Method in class org.eclipse.persistence.internal.helper.type.ReadLockAcquisitionMetadata
getCacheKeyWithReadLock(Object) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Get the cache key (with object) for the primary key with read lock.
getCacheKeyWithReadLock(Object) - Method in class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
Avoid acquiring any lock as uow is single threaded.
getCacheMutex() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Return the cache mutex.
getCachePolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return the cache policy.
getCacheSize() - Method in class org.eclipse.persistence.descriptors.CacheIndex
ADVANCED: Return the cache size.
getCacheSync() - Method in class org.eclipse.persistence.internal.sessions.factories.model.rcm.command.CommandsConfig
 
getCacheSynchronizationType() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Get a value indicating the type of cache synchronization that will be used on objects of this type.
getCacheSynchronizationType() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Get a value indicating the type of cache synchronization that will be used on objects of this type.
getCacheSynchronizationType() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
getCacheTransactionIsolation() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
ADVANCED: By default concurrency is optimized and the cache is not locked more than required during reads or writes, This allows for virtual concurrent reading and writing and should never cause any problems.
getCacheType() - Method in class org.eclipse.persistence.descriptors.CacheIndex
ADVANCED: Return the type of the cache used for the index.
getCacheType() - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Return the type of the cache used for the query results.
getCacheType() - Method in class org.eclipse.persistence.services.ClassSummaryDetailBase
 
getCacheTypeFor(Class<?>) - Method in class org.eclipse.persistence.services.RuntimeServices
INTERNAL: getCacheTypeFor: Give a more UI-friendly version of the cache type
getCacheUsage() - Method in class org.eclipse.persistence.queries.ModifyAllQuery
PUBLIC: Return the cache usage for this query.
getCacheUsage() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Return the cache usage.
getCalendarCache() - Static method in class org.eclipse.persistence.internal.helper.Helper
PERF: Return the calendar cache use to avoid calendar creation for processing java.sql/util.Date/Time/Timestamp objects.
getCall() - Method in exception org.eclipse.persistence.exceptions.DatabaseException
PUBLIC: Return the call that caused the exception.
getCall() - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
Return the call.
getCall() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Return the call.
getCall() - Method in class org.eclipse.persistence.queries.DatabaseQuery
OBSOLETE: Return the call for this query.
getCall() - Method in class org.eclipse.persistence.sessions.SessionEvent
PUBLIC: Some events may have a call associated with them (pre/postExecuteCall).
getCallbackName() - Method in class org.eclipse.persistence.oxm.JSONWithPadding
The callback name that should me marshalled with the object
getCallCount() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return the number of calls currently in progress.
getCallCount() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Used for load balancing and external pooling.
getCallHeader(DatabasePlatform) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredFunctionCall
INTERNAL: Return call header for the call string.
getCallHeader(DatabasePlatform) - Method in class org.eclipse.persistence.queries.StoredFunctionCall
INTERNAL: Return call header for the call string.
getCallHeader(DatabasePlatform) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
INTERNAL: Return call header for the call string.
getCalls() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Normally only a single call is used, however multiple table may require multiple calls on write.
getCallString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Return the SQL string for the call.
getCallString() - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: Return the string for the call
getCascadeDeleteObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return any objects have been deleted through database cascade delete constraints.
getCascadeDepth() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
getCascadeLockingPolicies() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL:
getCascadePolicy() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
getCascadePolicy() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the cascade policy.
getCastClass() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
getCastSizeForVarcharParameter() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
ADVANCED: Get the maximum length allowed by the database for a Varchar Parameter This is used by subclasses when writing SQL for parameters
getCatalog() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Get the current schema.
getCategoryLoggers() - Method in class org.eclipse.persistence.logging.JavaLog
INTERNAL: Return catagoryloggers
getCaughtExceptions() - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: This method returns the vector which adds all the Descriptors Exceptions.
getCCIConnection() - Method in class org.eclipse.persistence.eis.EISAccessor
Return the CCI connection to the EIS resource adapter.
getChangedAttributeNames() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
ADVANCED: This method will return a collection of the attributes changed in the object.
getChangedAttributeNames() - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCED: This method will return a collection of the names of attributes changed in an object.
getChangedIndexes() - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
getChangedMapKeys() - Method in class org.eclipse.persistence.eis.EISCollectionChangeRecord
ADVANCED: Return the stuff whose Map keys have changed.
getChangedMapKeys() - Method in interface org.eclipse.persistence.sessions.changesets.EISCollectionChangeRecord
ADVANCED: Return the objets whose Map keys have changed.
getChangedObject() - Method in class org.eclipse.persistence.internal.sessions.AggregateChangeRecord
ADVANCED: This method is used to return the ObjectChangeSet representing the changed Aggregate.
getChangedObject() - Method in interface org.eclipse.persistence.sessions.changesets.AggregateChangeRecord
ADVANCED: This method is used to return the ObjectChangeSet representing the changed Aggregate.
getChangedValues() - Method in class org.eclipse.persistence.internal.sessions.AggregateCollectionChangeRecord
ADVANCED: Return the values representing the changed AggregateCollection.
getChangedValues() - Method in interface org.eclipse.persistence.sessions.changesets.AggregateCollectionChangeRecord
ADVANCED: Return the values representing the changed AggregateCollection.
getChanges() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: This method returns a reference to the collection of changes within this changeSet.
getChanges() - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCED: This method returns a reference to the collection of changes within this changeSet.
getChangeSet() - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
PUBLIC: Returns the Object changeSet if available
getChangeSet() - Method in class org.eclipse.persistence.internal.sessions.OrderedChangeObject
INTERNAL: Return the ObjectChangeSet representing the change made to the collection
getChangeSet(AbstractSession) - Method in class org.eclipse.persistence.sessions.coordination.MergeChangeSetCommand
INTERNAL: Return the changes to be applied
getChangesForAttributeNamed(String) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: returns the change record for the specified attribute name
getChangesForAttributeNamed(String) - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCED: Returns the change record for the specified attribute name.
getChangeTrackedHardList() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the list of object with changes.
getChangeType() - Method in class org.eclipse.persistence.descriptors.changetracking.CollectionChangeEvent
INTERNAL: Return the change type
getChangeType() - Method in class org.eclipse.persistence.internal.sessions.OrderedChangeObject
INTERNAL: Return the type of collection change operation (CollectionChangeEvent.REMOVE or CollectionChangeEvent.ADD)
getChangeValuesFrom(Map) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Used to create an iterator on a the Map object passed to CollectionChangeRecord.addRemoveChange() to access the values to be removed.
getChangeValuesFrom(Map) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Used to create an iterator on a the Map object passed to CollectionChangeRecord.addRemoveChange() to access the values to be removed.
getChannel() - Method in class org.eclipse.persistence.internal.sessions.factories.model.rcm.RemoteCommandManagerConfig
 
getChannel() - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
PUBLIC: Return the service channel for this command manager.
getChannel() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
PUBLIC: Return the service channel for this command manager.
getChannel() - Method in class org.eclipse.persistence.sessions.coordination.ServiceId
INTERNAL: Return the logical channel that this service subscribes to
getCharacterClassType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the Character class representation.
getCharacterEscapeHandler() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
Return this Marshaller's CharacterEscapeHandler.
getCharacterEscapeHandler() - Method in class org.eclipse.persistence.oxm.XMLMarshaller
Return this Marshaller's CharacterEscapeHandler.
getCharacters() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getCharacters() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getCharacters() - Method in class org.eclipse.persistence.internal.oxm.XMLInlineBinaryHandler
 
getCharacters() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getCharType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the char type representation.
getCheckCacheFirst() - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL:
getCheckDatabaseIfInvalid() - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL:
getChildDescriptors() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return all the immediate child descriptors.
getChildDescriptors() - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Return all the child descriptors.
getChildRecord() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getChildRecord() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getChildRecord() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
INTERNAL
getChildren() - Method in class org.eclipse.persistence.internal.codegen.HierarchyNode
 
getChildren() - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
getChildren() - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
getChildrenCollisionSet(boolean) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
INTERNAL: Gets auxiliary set for determining collisions during case insensitive unmarshalling.
getChildrenJoinExpression() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: all expressions from childrenTablesJoinExpressions ANDed together
getChildrenLookupTable(boolean) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getChildrenTables() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: if reads subclasses, all tables for all read subclasses (indirect included).
getChildrenTablesJoinExpressions() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: join expression for each child table, keyed by the table
getChildUnmarshalRecord(OBJECT_BUILDER) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getChildUnmarshalRecord(ObjectBuilder) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getChildUnmarshalRecord(TreeObjectBuilder) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
INTERNAL
getChoice() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
getChoice() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
getChoice() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
getChoice() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getChoiceElementMappings() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
getChoiceElementMappings() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
getChoiceElementMappings() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
getChoiceElementMappings() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
getChoiceElementMappingsByClass() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
getChoiceElementMappingsByClass() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
getChoiceElementMappingsByClass() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
getChoiceElementMappingsByClass() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
getChoiceElementMarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
getChoiceElementNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
getChoiceFieldToClassAssociations() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
getChoiceFieldToClassAssociations() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
getChoiceFieldToClassAssociations() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
getChoiceFieldToClassAssociations() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
getCID() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryAttachmentHandler
 
getClassDescriptor() - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
PUBLIC: The source descriptor of the event.
getClassDescriptor(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Return the descriptor specified for the class.
getClassDescriptor(Class<?>) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return the descriptor specified for the class.
getClassDescriptor(Class<?>) - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Return the descriptor specified for the class.
getClassDescriptor(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Return the descriptor specified for the object's class.
getClassDescriptor(Object) - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Return the descriptor specified for the object's class.
getClassDescriptorForAlias(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the descriptor for the alias.
getClassDescriptorForAlias(String) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the descriptor for the alias.
getClassDescriptors(CharSequence, AbstractSession) - Method in class org.eclipse.persistence.internal.jpa.jpql.JPQLQueryHelper
Retrieves the list of descriptors corresponding to the entities used throughout the given JPQL query.
getClassesInSession() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to return those Class Names that have identity Maps in the Session.
getClassesInSession() - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to return those Class Names that have identity Maps in the Session.
getClassesRegistered() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
This method is used to get a list of those classes with IdentityMaps in the Session.
getClassesRegistered() - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: This method is used to get a list of those classes with IdentityMaps in the Session.
getClassesRegistered() - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: This method is used to get a list of those classes with IdentityMaps in the Session.
getClassesToBeInvalidated() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Return classes that should be invalidated in the shared cache on commit.
getClassExtractionMethod() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return all the classExtractionMethod
getClassExtractionMethod() - Method in class org.eclipse.persistence.descriptors.MethodClassExtractor
INTERNAL: Return all the classExtractionMethod
getClassExtractionMethodName() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: A class extraction method can be registered with the descriptor to override the default inheritance mechanism.
getClassExtractionMethodName() - Method in class org.eclipse.persistence.descriptors.MethodClassExtractor
PUBLIC: A class extraction method can be registered with the descriptor to override the default inheritance mechanism.
getClassExtractor() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: A class extractor can be registered with the descriptor to override the default inheritance mechanism.
getClassForCode(int) - Static method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
getClassForName(String) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Execute a java Class.forName().
getClassForName(String, boolean, ClassLoader) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Execute a java Class.forName() wrap the call in a doPrivileged block if necessary.
getClassForQName(QName, ConversionManager) - Method in class org.eclipse.persistence.internal.oxm.XMLRelationshipMappingNodeValue
 
getClassFromClasseName(String, ClassLoader) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
getClassIndicatorAssociations() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return the class indicator associations for XML.
getClassIndicatorAssociations() - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Return the class indicator associations for XML.
getClassIndicatorField() - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL: Returns field that the class type indicator is store when using inheritance.
getClassIndicatorField() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Returns field that the class type indicator is store when using inheritance.
getClassIndicatorFieldName() - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
PUBLIC: Return the class indicator field name.
getClassIndicatorFieldName() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Return the class indicator field name.
getClassIndicatorMapping() - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL: Return the association of indicators and classes using specified ConversionManager
getClassIndicatorMapping() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return the association of indicators and classes using specified ConversionManager
getClassIndicatorValue() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Returns value of the abstract class indicator for the Java class.
getClassIndicatorValue(Class<?>) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Returns the indicator field value for the given class If no abstract indicator mapping is specified, use the class name.
getClassInstance(Class<?>) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: Return a new instance of the class provided.
getClassLoader() - Method in class org.eclipse.persistence.internal.helper.JPAClassLoaderHolder
INTERNAL:
getClassLoader() - Method in class org.eclipse.persistence.sessions.factories.SessionFactory
The class-loader returned form this call will be used when loading the EclipseLink configuration.
getClassLoader() - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: Return the class loader that should be used to find the resource.
getClassLoaderForClass(Class<?>) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Gets the class loader for a given class.
getClassName() - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader.EnumInfo
 
getClassName() - Method in interface org.eclipse.persistence.dynamic.DynamicType
 
getClassName() - Method in class org.eclipse.persistence.internal.codegen.HierarchyNode
 
getClassName() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getClassName() - Method in class org.eclipse.persistence.internal.jpa.jpql.ConstructorQueryMappings
Returns the class name used to define the constructor expression.
getClassName() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceFieldToClassAssociation
 
getClassName() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
ADVANCE: This method returns the class type that this changeSet Represents.
getClassName() - Method in class org.eclipse.persistence.services.ClassSummaryDetailBase
 
getClassName() - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCE: This method returns the class Name that this changeSet Represents.
getClassName() - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Return the name of class to be generated.
getClassName() - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Return the name of class to be generated.
getClassNameIndicatorMapping() - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL: Return the mapping from class name to indicator, used by MW.
getClassNameIndicatorMapping() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return the mapping from class name to indicator, used by MW.
getClassNamesForWeaving() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Returns all classes in this project that are needed for weaving.
getClassNameToFieldMappings() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
getClassNameToFieldMappings() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
getClassNameToFieldMappings() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
getClassNameToFieldMappings() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
getClassSummaryDetails() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Provide an instance of 2 Dimensional Array simulating tabular format information about all classes in the session.
getClassSummaryDetails() - Method in class org.eclipse.persistence.services.RuntimeServices
PUBLIC: Provide an instance of 2 Dimensional Array simulating tabular format information about all classes in the session.
getClassSummaryDetailsArray() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Provide a list of instance of ClassSummaryDetail containing information about all classes in the session.
getClassSummaryDetailsArray() - Method in class org.eclipse.persistence.services.RuntimeServices
Provide a list of instance of ClassSummaryDetail containing information about all classes in the session.
getClassSummaryDetailsUsingFilter(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Provide an instance of 2 Dimensional Array simulating tabular format information about all classes in the session whose class names match the provided filter.
getClassSummaryDetailsUsingFilter(String) - Method in class org.eclipse.persistence.services.RuntimeServices
Provide an instance of 2 Dimensional Array simulating tabular format information about all classes in the session whose class names match the provided filter.
getClassSummaryDetailsUsingFilterArray(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Provide a list of instance of ClassSummaryDetail containing information about the classes in the session whose class names match the provided filter.
getClassSummaryDetailsUsingFilterArray(String) - Method in class org.eclipse.persistence.services.RuntimeServices
Provide a list of instance of ClassSummaryDetail containing information about the classes in the session whose class names match the provided filter.
getClassToConvertTo() - Method in exception org.eclipse.persistence.exceptions.ConversionException
PUBLIC: Return the class to convert to.
getClassToFieldMappings() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
getClassToFieldMappings() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
getClassToFieldMappings() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
getClassToFieldMappings() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
getClassToSourceFieldsMappings() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
getClassToSourceFieldsMappings() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
getClassToSourceFieldsMappings() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
getClassToSourceFieldsMappings() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
getClassType() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: This method returns the class type that this changeSet represents.
getClassType(Session) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
ADVANCE: This method returns the class type that this changeSet Represents.
getClassType(Session) - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCE: This method returns the class type that this changeSet Represents.
getClassTypes() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return the class type to database type mapping for the schema framework.
getClassWriter(String) - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
 
getClassWriters() - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
 
getClearStatementCacheMethod() - Method in class org.eclipse.persistence.platform.server.wls.WebLogicPlatform
Return the method for the WebLogic connection clearStatementCache method.
getCloneDataFromChangeSet(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Used when objects are added or removed during an update.
getCloneDataFromChangeSet(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Used when objects are added or removed during an update.
getClonedExpressions() - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
 
getClonedField() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: If there are any fields associated with this expression, return them
getClonedField() - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: If there are any fields associated with this expression, return them
getClonedFields() - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: If there are any fields associated with this expression, return them
getCloneMapping() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the clone mapping.
getCloneMethod() - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Return the 'clone()' Method for the container class.
getCloneMethod(Class<?>) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Return the 'clone()' Method for the specified class.
getCloneOfObject() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkTransformerValueHolder
 
getCloneToObjectChangeSet() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Get the clone to object change hash table.
getCloneToOriginals() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Map used to avoid garbage collection in weak caches.
getCloningMappings() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Return all mappings that require cloning.
getCMPPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Return the cmp descriptor that holds cmp specific information.
getCollectionContentType() - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
getCollectionMapping() - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Reduce casting clutter....
getColumn() - Method in class org.eclipse.persistence.queries.ColumnResult
 
getColumn() - Method in class org.eclipse.persistence.queries.FieldResult
 
getColumnDefinition() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Get the SQL fragment that is used when generating the DDL for the column.
getColumnInfo(String, String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
getColumnInfo(String, String, String, String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Get a description of table columns available in a catalog.
getColumnInfo(String, String, String, String, AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return the column metadata for the specified selection criteria.
getColumnInfo(String, String, String, String, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Get a description of table columns available in a catalog.
getColumnInfo(String, String, String, String, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return column information for the specified database objects.
getColumnInfo(String, String, AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return the column metadata for the specified selection criteria limited to the context of the current Accessor.
getColumnInfo(String, String, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
 
getColumnInfo(String, String, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
 
getColumnNames(ResultSet, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return the column names from a result sets meta data as a vector of DatabaseFields.
getColumnNumber() - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.LocatorImpl
 
getColumnResults() - Method in class org.eclipse.persistence.queries.ConstructorResult
Return the columns result of this constructor result.
getCommand() - Method in class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
INTERNAL: Returns the command to be sent
getCommandConverter() - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
PUBLIC: Return the converter instance used to convert between TopLink Command objects and an application command format.
getCommandConverter() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
PUBLIC: Return the converter instance used to convert between EclipseLink Command objects and an application command format.
getCommandManager() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the CommandManager that allows this session to act as a CommandProcessor and receive or propagate commands from/to the EclipseLink cluster.
getCommandManager() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
INTERNAL: This method returns the command manager policy for this remote connection
getCommandManager() - Method in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
PUBLIC: Return the CommandManager that will invoke this CommandProcessor to process a command, and can be used to send remote commands out to other CommandProcessors in the cluster.
getCommandManager() - Method in interface org.eclipse.persistence.sessions.DatabaseSession
ADVANCED: Return the CommandManager that allows this session to act as a CommandProcessor and receive or propagate commands from/to the EclipseLink cluster.
getCommandManager() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Return the manager that allows this processor to receive or propagate commands from/to TopLink cluster
getCommandProcessor() - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
PUBLIC: Return the command processor that processes commands received from the cluster.
getCommandProcessor() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
getCommandsConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.rcm.RemoteCommandManagerConfig
 
getComment() - Method in class org.eclipse.persistence.internal.codegen.CodeDefinition
 
getCommitAddMap() - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
This method returns the collection of objects that were added to the collection.
getCommitManager() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: The commit manager is used to resolve referential integrity on commits of multiple objects.
getCommitManager() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The commit manager is used to resolve referential integrity on commits of multiple objects.
getCommitOrder() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Return the order in which objects should be committed to the database.
getCommitOrder() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Return the commit order.
getCommitOrder() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Return the commit order.
getCommitState() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Return the map of states of the objects being committed.
getCommunicationSocket() - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
INTERNAL: Return the socket that will be used for the multicast.
getComparator() - Method in class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
INTERNAL: Return the stored comparator
getComparatorClass() - Method in class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
INTERNAL: Return the stored comparator class
getComparatorClassName() - Method in class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
INTERNAL: return stored comparator class name
getCompatibleType() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
getCompatibleType() - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
Oracle ARRAY types don't have a compatible type like PL/SQL types do, so we will use the type name
getCompatibleType() - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
Oracle STRUCT types don't have a compatible type like PL/SQL types do, so we will use the type name
getComplexContent() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
getComplexType() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getComponentTypeNameFromArrayString(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
getConcreteSubclassCalls() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the cache of concrete subclass calls.
getConcreteSubclassJoinedMappingIndexes() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the cache of concrete subclass joined mapping indexes.
getConcreteSubclassQueries() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the cache of concrete subclass queries.
getConcurrencyManagerCreationDate() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
getConcurrencyManagerId() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
getConcurrencySemaphoreLogTimeout() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
getConcurrencySemaphoreMaxTimePermit() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
getConfiguredSize() - Method in class org.eclipse.persistence.services.ClassSummaryDetailBase
 
getConnectByExpression() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Return the CONNECT BY expression
getConnectByExpression() - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC:
getConnectedTime() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Answer the time that this session got connected.
getConnection() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return the JDBC connection for relational accessors.
getConnection() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return the receiver's connection to its data source.
getConnection() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Helper method to return the JDBC connection for DatabaseAccessor.
getConnection() - Method in class org.eclipse.persistence.internal.sessions.coordination.rmi.RMIRemoteConnection
INTERNAL Return the RemoteCommandConnection associated with this RemoteConnection
getConnection() - Method in class org.eclipse.persistence.logging.EclipseLinkLogRecord
 
getConnection() - Method in class org.eclipse.persistence.logging.SessionLogEntry
Return the connection that generated the log entry.
getConnection(AbstractSession, Connection) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: This method is used to unwrap the oracle connection wrapped by the application server.
getConnection(AbstractSession, Connection) - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
INTERNAL: This method is used to unwrap the oracle connection wrapped by the application server.
getConnectionDetails() - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Provide the details of my connection information.
getConnectionDetails() - Method in interface org.eclipse.persistence.sessions.Connector
INTERNAL: Provide the details of my connection information.
getConnectionDetails() - Method in class org.eclipse.persistence.sessions.DefaultConnector
PUBLIC: Provide the details of my connection information.
getConnectionDetails() - Method in class org.eclipse.persistence.sessions.JNDIConnector
PUBLIC: Provide the details of my connection information.
getConnectionFactory() - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Return the jakarta.resource.cci.ConnectionFactory.
getConnectionFactoryURL() - Method in class org.eclipse.persistence.eis.EISLogin
PUBLIC: Return the JNDI URL for the managed connection factory for the JCA adapter connecting to.
getConnectionFactoryURL() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.EISLoginConfig
 
getConnectionMetaData() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
return the cached metaData
getConnectionPolicy() - Method in class org.eclipse.persistence.sessions.server.ClientSession
ADVANCED: This method will return the connection policy that was used during the acquisition of this client session.
getConnectionPolicyConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.ServerSessionConfig
 
getConnectionPool() - Method in class org.eclipse.persistence.descriptors.partitioning.PinnedPartitioningPolicy
PUBLIC: Return the connection pool to pin queries to.
getConnectionPool() - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartition
PUBLIC: Return the connection pool to use for this partition.
getConnectionPool() - Method in interface org.eclipse.persistence.internal.sequencing.SequencingServer
 
getConnectionPool() - Method in interface org.eclipse.persistence.sequencing.SequencingControl
ADVANCED: Return the connection pool to use for sequencing.
getConnectionPool(String) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Return the pool by name.
getConnectionPool(String) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return the pool by name.
getConnectionPoolConfigs() - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.PoolsConfig
 
getConnectionPools() - Method in class org.eclipse.persistence.descriptors.partitioning.HashPartitioningPolicy
PUBLIC: Return the list of connection pool names to replicate queries to.
getConnectionPools() - Method in class org.eclipse.persistence.descriptors.partitioning.ReplicationPartitioningPolicy
PUBLIC: Return the list of connection pool names to replicate queries to.
getConnectionPools() - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Connection are pooled to share and restrict the number of database connections.
getConnectionPoolType() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Return connection pool type.
getConnectionPoolType() - Method in class org.eclipse.persistence.services.RuntimeServices
Return connection pool type.
getConnectionsAvailable() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: returns the connections currently available for use in the pool
getConnectionsForQuery(AbstractSession, DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.partitioning.CustomPartitioningPolicy
INTERNAL: Forward to custom policy
getConnectionsForQuery(AbstractSession, DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.partitioning.HashPartitioningPolicy
INTERNAL: Get a connection from one of the pools in a round robin rotation fashion.
getConnectionsForQuery(AbstractSession, DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.partitioning.PartitioningPolicy
 
getConnectionsForQuery(AbstractSession, DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.partitioning.PinnedPartitioningPolicy
INTERNAL: Get a connection from each pool.
getConnectionsForQuery(AbstractSession, DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartitioningPolicy
INTERNAL: Get a connection from one of the pools in a round robin rotation fashion.
getConnectionsForQuery(AbstractSession, DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.partitioning.ReplicationPartitioningPolicy
INTERNAL: Get a connection from each pool.
getConnectionsForQuery(AbstractSession, DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.partitioning.RoundRobinPartitioningPolicy
INTERNAL: Get a connection from one of the pools in a round robin rotation fashion.
getConnectionsForQuery(AbstractSession, DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.partitioning.UnionPartitioningPolicy
INTERNAL: Get a connection from one of the pools in a round robin rotation fashion.
getConnectionsForQuery(AbstractSession, DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
INTERNAL: Get a connection from one of the pools in a round robin rotation fashion.
getConnectionSpec() - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Return the jakarta.resource.cci.ConnectionSpec.
getConnectionSpec() - Method in class org.eclipse.persistence.eis.EISLogin
Return the connector.
getConnectionSpecClass() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.EISLoginConfig
 
getConnectionsToExternalServices() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL:
getConnectionsToExternalServicesForCommandPropagation() - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
INTERNAL: In case there's no external connection attempts to create one.
getConnectionsToExternalServicesForCommandPropagation() - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSTopicTransportManager
INTERNAL: In case there's no external connection attempts to create one, if that's successful then (in case there is no local connection, too) attempts to create local connection in a separate thread.
getConnectionsToExternalServicesForCommandPropagation() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Returns clone of the original map.
getConnectionString() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return the JDBC connection string.
getConnectionString() - Method in class org.eclipse.persistence.sessions.DefaultConnector
PUBLIC: Return the JDBC connection string.
getConnectionString(Accessor) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
Return the specified connection information.
getConnectionsUsed() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
Return a list of the connections that are being used.
getConnectionToLocalHost() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Return a remote connection to this service
getConnectionURL() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getConnectionUserName() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Returns user name retrieved from JDBC connection.
getConnector() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
ADVANCED: Return the connector that will instantiate the connection.
getConstantTransformerForProjectVersionMapping() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
getConstantTransformerForProjectVersionMapping() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
INTERNAL:
getConstantTransformerForProjectVersionMapping() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
INTERNAL:
getConstraint() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Return any constraint of this field.
getConstraintDeletionString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for constraint deletion.
getConstraintDeletionString() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Used for constraint deletion.
getConstraintDependencies() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: automatically orders database access through the foreign key information provided in 1:1 and 1:m mappings.
getConstructor() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the size constructor if available.
getConstructor() - Method in class org.eclipse.persistence.queries.ConstructorReportItem
INTERNAL: Return the constructor.
getConstructorArgTypes() - Method in class org.eclipse.persistence.queries.ConstructorReportItem
 
getConstructorFor(Class<T>, Class<?>[], boolean) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get the public constructor for the given class and given arguments and wrap it in doPrivileged if necessary.
getConstructorMappings() - Method in class org.eclipse.persistence.queries.ConstructorReportItem
INTERNAL: Return the mappings for the items.
getConstructorQueryMappings(AbstractSession) - Method in class org.eclipse.persistence.internal.jpa.jpql.JPQLQueryHelper
Retrieves the class names and the attribute names mapped to their types that are used in the constructor expressions defined in the SELECT clause.
getConstructorQueryMappings(AbstractSession, DatabaseQuery) - Method in class org.eclipse.persistence.internal.jpa.jpql.JPQLQueryHelper
Retrieves the class names and the attribute names mapped to their types that are used in the constructor expressions defined in the SELECT clause.
getContainer() - Method in class org.eclipse.persistence.internal.oxm.Reference
Get the container this reference should be added to if it was from a collection mapping
getContainerAccessor() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
Deprecated.
Replaced by getInverseReferenceMapping().getAttributeAccessor()
getContainerAccessor() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
Deprecated.
Replaced by getInverseReferenceMapping().getAttributeAccessor()
getContainerAttributeName() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
Deprecated.
Replaced by getInverseReferenceMapping().getAttributeName()
getContainerAttributeName() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
Deprecated.
Replaced by getInverseReferenceMapping().getAttributeName()
getContainerBeans() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This is only used for EJB entity beans to manage beans accessed in a transaction context.
getContainerClass() - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
Returns the Container class which implements IndirectContainer.
getContainerClass() - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the container class for the mapping.
getContainerClass() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the class used for the container.
getContainerClass() - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Returns the container class to be used with this policy.
getContainerClassName() - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Used by MW.
getContainerClassName() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Used by the MW
getContainerClassName() - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
 
getContainerConstructor() - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
 
getContainerGetMethodName() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
Deprecated.
Replaced by getInverseReferenceMapping().getGetMethodName()
getContainerGetMethodName() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
Deprecated.
Replaced by getInverseReferenceMapping().getGetMethodName()
getContainerInstance() - Method in interface org.eclipse.persistence.internal.oxm.ContainerValue
 
getContainerInstance() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
 
getContainerInstance() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
getContainerInstance() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
getContainerInstance() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
getContainerInstance() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
getContainerInstance() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
 
getContainerInstance() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
 
getContainerInstance() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
getContainerInstance() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
getContainerInstance() - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
 
getContainerInstance() - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
getContainerInstance(ContainerValue) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getContainerInstance(ContainerValue) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getContainerInstance(ContainerValue) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getContainerInstance(ContainerValue, boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getContainerInstance(ContainerValue, boolean) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getContainerInstance(ContainerValue, boolean) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getContainerPolicy() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Return the mapping's containerPolicy.
getContainerPolicy() - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the container policy for the mapping.
getContainerPolicy() - Method in interface org.eclipse.persistence.internal.oxm.ContainerValue
 
getContainerPolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
 
getContainerPolicy() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
 
getContainerPolicy() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
getContainerPolicy() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
getContainerPolicy() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
getContainerPolicy() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
getContainerPolicy() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
 
getContainerPolicy() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
 
getContainerPolicy() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
getContainerPolicy() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
getContainerPolicy() - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
 
getContainerPolicy() - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
getContainerPolicy() - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Returns the receiver's containerPolicy.
getContainerPolicy() - Method in interface org.eclipse.persistence.mappings.ContainerMapping
PUBLIC: Return the mapping's container policy.
getContainerPolicy() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return the mapping's containerPolicy.
getContainerPolicy() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Return the mapping's containerPolicy.
getContainerPolicy() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Return the mapping's containerPolicy.
getContainerPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL: Return the mapping's containerPolicy.
getContainerPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL: Return the mapping's containerPolicy.
getContainerPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
getContainerPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
INTERNAL: Return the mapping's containerPolicy.
getContainerPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
getContainerPolicy() - Method in class org.eclipse.persistence.queries.DataReadQuery
PUBLIC: Return the query's ContainerPolicy.
getContainerPolicy() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Return the query's container policy.
getContainerSetMethodName() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
Deprecated.
Replaced by getInverseReferenceMapping().getSetMethodName()
getContainerSetMethodName() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
Deprecated.
Replaced by getInverseReferenceMapping().getSetMethodName()
getContainerUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This is only used for EJB entity beans to manage beans accessed in a transaction context.
getContainerValues() - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
getContainerValues() - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
getContainerValues() - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
getContainingDescriptor() - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
INTERNAL: Like QueryKeyExpression, return the descriptor for the class type used, null if one can't be determined yet.
getContainingDescriptor() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL: Return the descriptor which contains this query key.
getContainingDescriptor() - Method in class org.eclipse.persistence.internal.expressions.FromAliasExpression
INTERNAL: If the alias is for a query key item, then return its descriptor.
getContainingDescriptor(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
INTERNAL: Return the descriptor for the base expression.
getContentHandler() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
getContentHandler() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
getContentHandler() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
getContentHandler() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
getContentHandler() - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
Return the ContentHandler that the object will be marshalled to.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.BeanValidationExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.CommunicationExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.ConcurrencyExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.ConversionExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.DatabaseExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.DBWSExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.DescriptorExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.DiscoveryExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.EISExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.EntityManagerSetupExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.ExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.JAXBExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.JMSProcessingExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.JPARSExceptionResource
 
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.JPQLExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.JSONExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.OptimisticLockExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.PersistenceUnitLoadingExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.QueryExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.RemoteCommandManagerExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.SDOExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.ServerPlatformExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.SessionLoaderExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.StaticWeaveExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.TransactionExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.ValidationExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.XMLConversionExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.XMLMarshalExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.XMLParseExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.exceptions.i18n.XMLPlatformExceptionResource
Return the lookup table.
getContents() - Method in class org.eclipse.persistence.internal.helper.linkedlist.LinkedNode
 
getContentType() - Method in class org.eclipse.persistence.internal.oxm.ByteArrayDataSource
 
getContext() - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Return the JNDI Context that can supplied the named ConnectionFactory.
getContext() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
Return the instance of Context that was used to create this instance of Marshaller.
getContext() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Return the instance of XMLContext that was used to create this instance of Unmarshaller.
getContext() - Method in class org.eclipse.persistence.sessions.JNDIConnector
PUBLIC: Return the JNDI Context that can supplied the named DataSource.
getContext(Hashtable) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Helper method to get a naming context.
getContextClassLoader(Thread) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get the context ClassLoader for a thread.
getContextProperty() - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL: Return the context property for this table per tenant policy.
getContexts() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Return the contexts (for LOB)
getContextualNamespaceDecls() - Method in class org.eclipse.persistence.internal.oxm.NamespacePrefixMapper
Returns a string array of prefixes and namespace uris that are already available in this context.
getContextualNamespaceDecls() - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.NamespacePrefixMapperWrapper
 
getController() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Return the controller.
getConversionCode() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
getConversionCode() - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
getConversionCode() - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
getConversionCode() - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
getConversionManager() - Method in class org.eclipse.persistence.eis.EISPlatform
The platform holds its own instance of conversion manager to allow customization.
getConversionManager() - Method in interface org.eclipse.persistence.internal.core.databaseaccess.CorePlatform
The platform hold its own instance of conversion manager to allow customization.
getConversionManager() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
The platform hold its own instance of conversion manager to allow customization.
getConversionManager() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
The platform hold its own instance of conversion manager to allow customization.
getConversionManager() - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
getConversionManager() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getConversionManager() - Method in interface org.eclipse.persistence.internal.oxm.record.XMLRecord
 
getConversionManager() - Method in class org.eclipse.persistence.oxm.platform.XMLPlatform
 
getConversionManager() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL
getConverter() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
getConverter() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
getConverter() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
Return the converter on the mapping.
getConverter() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceFieldToClassAssociation
 
getConverter() - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
PUBLIC: Return the converter on the mapping.
getConverter() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
PUBLIC: Return the converter on the mapping.
getConverter() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
PUBLIC: Return the converter on the mapping.
getConverter() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
getConverter() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
getConverter() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
Return the converter on the mapping.
getConverter() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
Return the converter on the mapping.
getConverter(XMLField) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
getConverter(XMLField) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
getConverter(XML_FIELD) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
getConverter(XML_FIELD) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
getCopies() - Method in class org.eclipse.persistence.sessions.CopyGroup
INTERNAL: Get the session.
getCopyPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Returns the copy policy.
getCopyPolicyClassName() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Returns the name of a Class that implements CopyPolicy Will be instantiated as a copy policy at initialization times using the no-args constructor
getCount() - Static method in class org.eclipse.persistence.internal.helper.QueryCounter
 
getCounterField() - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.TableSequenceConfig
 
getCounterField() - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.UnaryTableSequenceConfig
 
getCounterFieldName() - Method in class org.eclipse.persistence.sequencing.TableSequence
 
getCounterFieldName() - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
getCreateDatabaseSchemaString(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return the create schema SQL syntax.
getCreateTempTableSqlBodyForTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: May override this method if the platform supports temporary tables.
getCreateTempTableSqlBodyForTable(DatabaseTable) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 allows LIKE to be used to create temp tables, which avoids having to know the types.
getCreateTempTableSqlBodyForTable(DatabaseTable) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL:
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Override this method if the platform supports temporary tables.
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 temp table syntax.
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.platform.database.H2Platform
 
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
 
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.platform.database.Informix11Platform
Returns CREATE TEMP TABLE when invoked, per the Informix 11.70 Information Center documentation.
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL temp table syntax, used for update-all, delete-all queries.
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
INTERNAL:
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL:
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL:
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL:
getCreateTempTableSqlPrefix() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the beginning of the SQL string to create a temporary table.
getCreateTempTableSqlSuffix() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: May override this method if the platform support temporary tables.
getCreateTempTableSqlSuffix() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 temp table syntax.
getCreateTempTableSqlSuffix() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL:
getCreateTempTableSqlSuffix() - Method in class org.eclipse.persistence.platform.database.Informix11Platform
Returns WITH NO LOG when invoked, per the Informix 11.70 Information Center documentation, since transactions are not needed on temp tables for the purposes for which EclipseLink uses them.
getCreateTempTableSqlSuffix() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL:
getCreateTempTableSqlSuffix() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the ending of the SQL string to create a temporary table.
Symfoware V10 requires table space name and number of concurrent users.
Maybe this will be implemented in the future, for now it invokes the super class's method.
getCreateViewString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
/** Used for view creation.
getCreateViewString() - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
INTERNAL: Used for view creation.
getCreationHeader() - Method in class org.eclipse.persistence.tools.schemaframework.StoredFunctionDefinition
 
getCreationHeader() - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
 
getCreationInOutputProcedureToken() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This method is used to print the required output parameter token for the specific platform.
getCreationInOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
This method is used to print the required output parameter token for the specific platform.
getCreationInOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
getCreationOutputProcedureToken() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This method is used to print the required output parameter token for the specific platform.
getCreationOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
getCreationOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
This method is used to print the required output parameter token for the specific platform.
getCreationOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
getCreationPrefix() - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Return the beginning of the sql create statement - the part before the name.
getCreationSuffix() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
returns the suffix applied to the CREATE table statement on this field for DDL generation.
getCreationSuffix() - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Return the end of the sql create statement - the part after the field list.
getCumulativeUOWChangeSet() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Get the final UnitOfWorkChangeSet for merge into the shared cache.
getCurrentAliasNumber() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Gets a unique id that will be used to alias the next table.
getCurrentAttributeGroup() - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
getCurrentAttributeGroup() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
getCurrentChanges() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: This method Will Calculate the changes for the UnitOfWork.
getCurrentChanges() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: This method will calculate the changes for the UnitOfWork.
getCurrentClass() - Method in class org.eclipse.persistence.internal.codegen.CodeGenerator
 
getCurrentDescriptor() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
getCurrentEclipseLinkLogLevel() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Answer the EclipseLink log level that is changeable.
getCurrentEclipseLinkLogLevel() - Method in class org.eclipse.persistence.services.RuntimeServices
PUBLIC: Answer the EclipseLink log level that is changeable.
getCurrentGroup() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
getCurrentIndexesOfOriginalObjects(List) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
The same size as original list, at the i-th position holds the index of the i-th original object in the current list (-1 if the object was removed): for example: {0, -1, 1, -1, 3} means that: previous(0) == current(0); previous(1) was removed; previous(2) == current(1); previous(3) was removed; previous(4) == current(3);
getCurrentItem() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
getCurrentKey() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy.MapContainerPolicyIterator
 
getCurrentMapping() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
getCurrentObject() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getCurrentObject() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getCurrentObject() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getCurrentObject() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL:
getCurrentObject() - Method in class org.eclipse.persistence.oxm.record.XMLRootRecord
Return a populated XMLRoot object.
getCurrentObject(CoreAbstractSession, Mapping) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
getCurrentObject(CoreAbstractSession, Mapping) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
getCurrentSize() - Method in class org.eclipse.persistence.services.ClassSummaryDetailBase
 
getCurrentThreadStackTraceInformation() - Method in class org.eclipse.persistence.internal.helper.type.ReadLockAcquisitionMetadata
getCurrentThreadStackTraceInformationCpuTimeCostMs() - Method in class org.eclipse.persistence.internal.helper.type.ReadLockAcquisitionMetadata
getCurrentTime(AbstractSession) - Method in class org.eclipse.persistence.history.HistoryPolicy
PUBLIC: Whenever a historical record is logically deleted (updated) or inserted, the end and start fields respectively will be set to this value.
getCurrentValue() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy.MapContainerPolicyIterator
 
getCursorCode() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
ADVANCED: Return the code for preparing cursored output parameters in a stored procedure
getCursorCode() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
ADVANCED: Return the code for preparing cursored output parameters in a stored procedure
getCursorOutIndex() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Return 1-based index of out cursor parameter, or -1.
getCursorSize() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteCursoredStream
INTERNAL: Retreive the size of the wrapped cursored stream.
getCursorSize() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
INTERNAL: Retreive the size of the wrapped cursored stream.
getCursorSize() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Retrieve the size of the open cursor by executing a count on the same query as the cursor.
getCursorSize() - Method in class org.eclipse.persistence.queries.CursoredStream
INTERNAL: Retrieve the size of the open cursor by executing a count on the same query as the cursor.
getCursorSize() - Method in class org.eclipse.persistence.queries.ScrollableCursor
INTERNAL: Retrieve the size of the open cursor by executing a count on the same query as the cursor.
getCustomModifyValueForCall(Call, Object, DatabaseField, boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This method determines if any special processing needs to occur prior to writing a field.
getCustomModifyValueForCall(Call, Object, DatabaseField, boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Allow for the platform to handle the representation of parameters specially.
getCustomModifyValueForCall(Call, Object, DatabaseField, boolean) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Allow for the platform to handle the representation of parameters specially.
getCustomModifyValueForCall(Call, Object, DatabaseField, boolean) - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
INTERNAL Used by SQLCall.translate(..) Typically there is no field translation (and this is default implementation).
getCycleDetectionStack() - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
getCycleDetectionStack() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
INTERNAL
getCycleString() - Method in class org.eclipse.persistence.internal.oxm.record.MarshalRecord.CycleDetectionStack
 
getData() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper.EncodedData
 
getData() - Method in class org.eclipse.persistence.queries.ComplexQueryResult
PUBLIC: Return the database rows for the query result.
getDatabaseCall() - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Return the call.
getDatabaseChangeNotificationType() - Method in class org.eclipse.persistence.descriptors.CachePolicy
Returns what type of database change notification an entity/descriptor should use.
getDatabaseErrorCode() - Method in exception org.eclipse.persistence.exceptions.DatabaseException
PUBLIC: This is the database error number.
getDatabaseEventListener() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
Return the database event listener, this allows database events to invalidate the cache.
getDatabaseEventListener() - Method in interface org.eclipse.persistence.sessions.DatabaseSession
Return the database event listener, this allows database events to invalidate the cache.
getDatabaseField() - Method in interface org.eclipse.persistence.descriptors.CMPPolicy.KeyElementAccessor
 
getDatabaseField() - Method in class org.eclipse.persistence.descriptors.CMPPolicy.KeyIsElementAccessor
 
getDatabaseField() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
INTERNAL: Return the databasefield.
getDatabaseFieldsToTableAliases() - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
getDatabaseMapping() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMappingHelper
INTERNAL: Return the mapping, casted a bit more generally.
getDatabaseMapping() - Method in class org.eclipse.persistence.mappings.structures.ArrayCollectionMappingHelper
INTERNAL: Return the mapping, casted a bit more generally.
getDatabaseName() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The database name is required when connecting to databases that support multiple databases within a single server instance (e.g.
getDatabasePlatform() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Return the database platform used by the DatabaseSession.
getDatabasePlatform() - Method in class org.eclipse.persistence.services.RuntimeServices
Return the database platform used by the DatabaseSession.
getDatabaseSchema() - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
PUBLIC: Return the database schema associated with this database object.
getDatabaseSchema() - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Return the schema associated with this table.
getDatabaseSchema() - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
PUBLIC: Return the schema associated with this table sequence.
getDatabaseSession() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: getDatabaseSession(): Answer the instance of DatabaseSession the receiver is helping.
getDatabaseSession() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: getDatabaseSession(): Answer the instance of DatabaseSession the receiver is helping.
getDatabaseStrings() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL:
getDatabaseStrings() - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
Deprecated.
getDatabaseStrings(int) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL:
getDatabaseStrings(int) - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
Returns an array of Strings that expects a query argument between each String in the array to form the Expression.
getDatabaseTypeForCode(int) - Static method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
getDatabaseTypeForCode(String) - Static method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
getDatabaseURL() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The database URL is the JDBC URL for the database server.
getDatabaseURL() - Method in class org.eclipse.persistence.sessions.DefaultConnector
PUBLIC: The database URL is the JDBC URL for the database server.
getDataClass() - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
PUBLIC: Returns the class type of the data value.
getDataClassName() - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
INTERNAL: Return the name of the data type for the MW usage.
getDataFormat() - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Return the data format that the descriptor maps to.
getDataHandlerForObjectValue(Object, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
getDataHandlerForObjectValue(Object, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
getDataModifications() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Used to store data queries to be performed at the end of the commit.
getDataResults() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Return temporary list of rows from parent batch query per batched mapping.
getDataResults() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Return all of the rows fetched by the query, used for 1-m joining.
getDataResults(DatabaseMapping) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Return the remaining data results for the mapping.
getDataResults_() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return all of the rows fetched by the query, used for 1-m joining.
getDataResultsByPrimaryKey() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return all of the rows fetched by the query by cache-key, used for 1-m joining.
getDatasource() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getDataSource() - Method in class org.eclipse.persistence.sessions.JNDIConnector
PUBLIC: Return the javax.sql.DataSource.
getDatasourceCall() - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: Return the call for this query.
getDatasourceCalls() - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: Return the calls for this query.
getDatasourceConnection() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return the driver level connection, this will need to be cast to the implementation class for the data access type being used.
getDatasourceConnection() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return the driver level connection.
getDatasourceLogin() - Method in class org.eclipse.persistence.core.sessions.CoreProject
PUBLIC: Return the login, the login holds any database connection information given.
getDatasourceLogin() - Method in interface org.eclipse.persistence.core.sessions.CoreSession
PUBLIC: Return the login, the login holds any database connection information given.
getDatasourceLogin() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the login, the login holds any database connection information given.
getDatasourceLogin() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return the login, the login holds any database connection information given.
getDatasourceLogin() - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
PUBLIC: Return the login.
getDatasourceLogin() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the login, the login holds any database connection information given.
getDataSourceName() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The data source name is required if connecting through ODBC (JDBC-ODBC, etc.).
getDatasourcePlatform() - Method in interface org.eclipse.persistence.core.sessions.CoreLogin
 
getDatasourcePlatform() - Method in interface org.eclipse.persistence.core.sessions.CoreSession
PUBLIC: Return the database platform currently connected to.
getDatasourcePlatform() - Method in class org.eclipse.persistence.internal.core.sessions.CoreAbstractSession
INTERNAL: Return the database platform currently connected to.
getDatasourcePlatform() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return the platform.
getDatasourcePlatform() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the database platform currently connected to.
getDatasourcePlatform() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Return the database platform currently connected to.
getDatasourcePlatform() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
INTERNAL: Return the database platform currently connected to.
getDatasourcePlatform() - Method in class org.eclipse.persistence.sequencing.Sequence
 
getDatasourcePlatform() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return the datasource platform specific information.
getDatasourcePlatform() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Return the datasource platform specific information.
getDatasourcePlatform() - Method in interface org.eclipse.persistence.sessions.Login
PUBLIC: Return the datasource platform specific information.
getDatasourcePlatform() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the database platform currently connected to.
getDatatypeFactory() - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
INTERNAL: Return the DatatypeFactory instance.
getDataTypeName() - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Specify the data type name for the class of objects the descriptor maps.
getDataTypesConvertedFrom(Class<?>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
PUBLIC: Return the list of Classes that can be converted to from the passed in javaClass.
getDataTypesConvertedFrom(Class<?>) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
PUBLIC: Return the list of Classes that can be converted to from the passed in javaClass.
getDataTypesConvertedTo(Class<?>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
PUBLIC: Return the list of Classes that can be converted from to the passed in javaClass.
getDataTypesConvertedTo(Class<?>) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
PUBLIC: Return the list of Classes that can be converted from to the passed in javaClass.
getDate() - Method in class org.eclipse.persistence.logging.SessionLogEntry
Return the date of the log entry.
getDateFormat() - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC: Return the date format to be used when printing a log entry date.
getDateOfReadLockAcquisition() - Method in class org.eclipse.persistence.internal.helper.type.ReadLockAcquisitionMetadata
getDateString(Date) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
Return the specified date and/or time information in string.
getDateType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the java.util.Date type representation.
getDBPlatform(String, String, String, SessionLog) - Static method in class org.eclipse.persistence.internal.helper.DBPlatformHelper
Get Database Platform from vendor name.
getDeclareBeginString() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: DECLARE stanza header for Anonymous PL/SQL block
getDeclaredConstructorFor(Class<T>, Class<?>[], boolean) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get the constructor for the given class and given arguments (regardless of whether it is public or private))and wrap it in doPrivileged if necessary.
getDeclaredField(Class<?>, String, boolean) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get a field actually declared in a class and wrap the call in doPrivileged if necessary.
getDeclaredFields(Class<?>) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get the list of fields in a class.
getDeclaredMethod(Class<?>, String) - Static method in class org.eclipse.persistence.internal.helper.Helper
INTERNAL: Returns a Method for the specified Class, method name, and that has no parameters.
getDeclaredMethod(Class<?>, String, Class<?>[]) - Static method in class org.eclipse.persistence.internal.helper.Helper
INTERNAL: Returns a Method for the specified Class, method name, and formal parameter types.
getDeclaredMethod(Class<?>, String, Class<?>[]) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Return a method on a given class with the given method name and parameter types.
getDeclaredMethods(Class<?>) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get the list of methods in a class.
getDeclaredType() - Method in class org.eclipse.persistence.internal.oxm.Root
Gets the declared type.
getDefault(DatabaseMapping) - Static method in enum org.eclipse.persistence.queries.ReadAllQuery.Direction
PUBLIC: Returns the default hierarchy traversal direction for the specified mapping.
For OneToOne mappings, source in parent object goes to target in child object, collections are the opposite way.
getDefaultAttributeValue() - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
PUBLIC: The default value can be used if the database can possibly store additional values then those that have been mapped.
getDefaultCacheIsolation() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return the project level default for class cache isolation;
getDefaultConnectionPolicy() - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: The default connection policy is used by default by the acquireClientConnection() protocol.
getDefaultConnectionPolicy() - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: The default connection policy is used by default by the acquireClientConnection() protocol.
getDefaultConnectionPool() - Method in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
PUBLIC: Return the default connection pool used for any unmapped values.
getDefaultConnectionPool() - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Return the default connection pool.
getDefaultConnectionPool() - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return the default connection pool.
getDefaultConnector() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
INTERNAL: Return the connector that will instantiate the java.sql.Connection.
getDefaultConstructor() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Return the default (zero-argument) constructor for the descriptor class.
getDefaultContainerClass() - Static method in class org.eclipse.persistence.internal.queries.ContainerPolicy
ADVANCED: Return the default collection class.
getDefaultContainerSize() - Static method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the the size to of container to create.
getDefaultDateTimeFormatter() - Static method in class org.eclipse.persistence.internal.helper.Helper
 
getDefaultDeleteObjectQueryRedirector() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default DeleteObjectQuery Redirector will be applied to any executing DeleteObjectQuery or DeleteAllQuery that does not have a redirector set directly on the query.
getDefaultEmptyContainerValues() - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
getDefaultEmptyContainerValues() - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
getDefaultEmptyContainerValues() - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
getDefaultEndDatabaseDelimiter() - Static method in class org.eclipse.persistence.internal.helper.Helper
 
getDefaultEntityFetchGroup() - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Returns EntityFetchGroup corresponding to default FetchGroup.
getDefaultEventListeners() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: EJB 3.0 support.
getDefaultFetchGroup() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return the default fetch group on the descriptor.
getDefaultFetchGroup() - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
Return the descriptor-level default fetch group.
getDefaultIdentityMapClass() - Static method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Returns the class which should be used as an identity map in a descriptor by default.
getDefaultIdentityMapClass() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return default value for descriptor cache type.
getDefaultIdentityMapSize() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return default value descriptor cache size.
getDefaultIdValidation() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return default value for descriptor primary key validation.
getDefaultInsertObjectQueryRedirector() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default InsertObjectQuery Redirector will be applied to any executing InsertObjectQuery that does not have a redirector set directly on the query.
getDefaultJavaTypes() - Static method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
getDefaultLoader() - Static method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Get the default class loader to use if no instance-level loader is set
getDefaultLocalUrl() - Method in class org.eclipse.persistence.sessions.coordination.rmi.RMITransportManager
INTERNAL: Return the default local URL for JNDI lookups
getDefaultLockingFieldType() - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: Return the default timestamp locking filed java type, default is Timestamp.
getDefaultLockingFieldType() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Return the default version locking filed java type, default is BigDecimal
getDefaultLoggingLevel() - Static method in class org.eclipse.persistence.logging.AbstractSessionLog
Return the system default log level.
getDefaultManager() - Static method in class org.eclipse.persistence.internal.helper.ConversionManager
A singleton conversion manager is used to handle generic conversions.
getDefaultManager() - Static method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Lazy initialize the default instance.
getDefaultNamespace() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getDefaultNamespaceURI() - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
 
getDefaultNativeSequenceToTable() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Return if the native sequence type is not supported, if table sequencing should be used.
getDefaultNullValue(Class<T>) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Allow for the null values for classes to be defaulted in one place.
getDefaultNullValue(Class<T>) - Method in class org.eclipse.persistence.internal.helper.JPAConversionManager
INTERNAL:
getDefaultNullValues() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Allow for the null values for classes to be defaulted in one place.
getDefaultPropertiesFileName() - Static method in class org.eclipse.persistence.tools.PackageRenamer
 
getDefaultPropertyValue(String) - Static method in class org.eclipse.persistence.internal.sessions.PropertiesHandler
INTERNAL: Returns the default property value that should be applied.
getDefaultPropertyValueLogDebug(String, AbstractSession) - Static method in class org.eclipse.persistence.internal.sessions.PropertiesHandler
 
getDefaultQueryRedirector() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default Query Redirector will be applied to any executing object query that does not have a more precise default (like the default ReadObjectQuery Redirector) or a redirector set directly on the query.
getDefaultQueryResultsCachePolicy() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return the default values for query caching options for all named queries.
getDefaultReadAllQueryRedirector() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default ReadAllQuery Redirector will be applied to any executing ReadAllQuery that does not have a redirector set directly on the query.
getDefaultReadObjectQueryRedirector() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default ReadObjectQuery Redirector will be applied to any executing ReadObjectQuery that does not have a redirector set directly on the query.
getDefaultReadOnlyClasses() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Returns the set of read-only classes that gets assigned to each newly created UnitOfWork.
getDefaultReadOnlyClasses() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
INTERNAL: Get the read-only classes
getDefaultReadOnlyClasses() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
return the read-only classes
getDefaultReadOnlyClasses() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Returns the set of read-only classes that gets assigned to each newly created UnitOfWork.
getDefaultReadOnlyClasses() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Returns the default set of read-only classes.
getDefaultReadOnlyClasses() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: CR#2751 Returns the set of read-only classes for the receiver.
getDefaultReadOnlyClasses() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL Return the read-only classes
getDefaultReadOnlyClasses() - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
To get the default read-only classes from the server side.
getDefaultReadOnlyClasses() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Get the default read-only classes
getDefaultRedirector() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Returns the specific default redirector for this query type.
getDefaultRedirector() - Method in class org.eclipse.persistence.queries.DeleteAllQuery
INTERNAL: Returns the specific default redirector for this query type.
getDefaultRedirector() - Method in class org.eclipse.persistence.queries.DeleteObjectQuery
INTERNAL: Returns the specific default redirector for this query type.
getDefaultRedirector() - Method in class org.eclipse.persistence.queries.InsertObjectQuery
INTERNAL: Returns the specific default redirector for this query type.
getDefaultRedirector() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Returns the specific default redirector for this query type.
getDefaultRedirector() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Returns the specific default redirector for this query type.
getDefaultRedirector() - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Returns the specific default redirector for this query type.
getDefaultRedirector() - Method in class org.eclipse.persistence.queries.UpdateAllQuery
INTERNAL: Returns the specific default redirector for this query type.
getDefaultRedirector() - Method in class org.eclipse.persistence.queries.UpdateObjectQuery
INTERNAL: Returns the specific default redirector for this query type.
getDefaultRedirector() - Method in class org.eclipse.persistence.queries.WriteObjectQuery
INTERNAL: Returns the specific default redirector for this query type.
getDefaultReferenceMode() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
Stores the default Session wide reference mode that a UnitOfWork will use when referencing managed objects.
getDefaultReferenceMode() - Method in interface org.eclipse.persistence.sessions.Session
Stores the default Session wide reference mode that a UnitOfWork will use when referencing managed objects.
getDefaultReportQueryRedirector() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default ReportQuery Redirector will be applied to any executing ReportQuery that does not have a redirector set directly on the query.
getDefaultRootElement() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Return the default root element name for the ClassDescriptor This value is stored in place of a table name This value is mandatory for all root objects
getDefaultRootElement() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: Return the default root element name for the ClassDescriptor This value is stored in place of a table name This value is mandatory for all root objects
getDefaultRootElementAsQName(Descriptor, String) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Return a QName representation of a qualified table name (aka default root element).
getDefaultRootElementField() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
 
getDefaultRootElementField() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
getDefaultRootElementType() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
 
getDefaultRootElementType() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
getDefaultSeqenceAtNextValue() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Return if the sequence generation should start at next value.
getDefaultSequence() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Get default sequence
getDefaultSequence() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Get default sequence.
getDefaultSequence() - Method in class org.eclipse.persistence.sequencing.DefaultSequence
INTERNAL: Return the platform's default sequence.
getDefaultSequence() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
Get default sequence
getDefaultSequenceConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
getDefaultSequenceTableName() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Returns the table name used by TableSequence by default.
getDefaultSequenceTableName() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the table name used by TableSequence by default.
getDefaultSequenceToWrite() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Used only for writing into XML or Java.
getDefaultSequenceToWrite() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
INTERNAL: Used only for writing into XML or Java.
getDefaultSequenceToWrite() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Used only for writing the login into XML or Java.
getDefaultSession() - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return the default session.
getDefaultSize() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Return the default size for this type.
getDefaultStartDatabaseDelimiter() - Static method in class org.eclipse.persistence.internal.helper.Helper
 
getDefaultSubSize() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Return the default sub-size for this type.
getDefaultTable() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: The first table in the tables is always treated as default.
getDefaultTableCreator(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Construct the default TableCreator.
getDefaultTemporalMutable() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return the default setting for configuring if dates and calendars are mutable.
getDefaultTimeZone() - Static method in class org.eclipse.persistence.internal.helper.Helper
PERF: Return the cached default platform.
getDefaultTransactionManager() - Static method in class org.eclipse.persistence.transaction.JTATransactionController
 
getDefaultTransactionSynchronizationRegistry() - Static method in class org.eclipse.persistence.transaction.JTA11TransactionController
PUBLIC: Get the default JTA 1.1 synchronization objects registry being used.
getDefaultUpdateObjectQueryRedirector() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default UpdateObjectQuery Redirector will be applied to any executing UpdateObjectQuery or UpdateAllQuery that does not have a redirector set directly on the query.
getDefaultValue() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
getDefaultWriter() - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader
 
getDefaultXMLManager() - Static method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
getDefaultXMLTypes() - Static method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
getDeferModificationsUntilCommit() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
ADVANCED: This can be used to control when changes to objects are submitted to the database This is only applicable to TopLink's CMP implementation and not available within the core.
getDeferredCalls() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Used to store calls to be performed at the end of the commit.
getDeferredLockManager(Thread) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Return the deferred lock manager from the thread
getDeferredLockManagerMapClone() - Method in class org.eclipse.persistence.internal.helper.type.ConcurrencyManagerState
getDeferredLockManagers() - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Return the deferred lock manager hashtable (thread - DeferredLockManager).
getDeferredLocks() - Method in class org.eclipse.persistence.internal.helper.DeferredLockManager
Return a set of the deferred locks
getDeferredSet() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
This set contains the list of attributes that must be calculated at commit time.
getDelayBetweenConnectionAttempts() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getDelayBetweenConnectionAttempts() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Returns the number of milliseconds that EclipseLink will wait between attempts to reconnect a DatabaseConnection in the case EclipseLink is attempting to retry a query, the default is 5000.
getDelegate() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Check whether the contents have been read from the database.
getDelegate() - Method in class org.eclipse.persistence.indirection.IndirectMap
INTERNAL: Check whether the contents have been read from the database.
getDelegate() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Check whether the contents have been read from the database.
getDelegateObject() - Method in interface org.eclipse.persistence.indirection.IndirectCollection
INTERNAL: Return the real collection object.
getDelegateObject() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Return the real collection object.
getDelegateObject() - Method in class org.eclipse.persistence.indirection.IndirectMap
INTERNAL: Return the real collection object.
getDelegateObject() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Return the real collection object.
getDelegateSequence() - Method in class org.eclipse.persistence.sequencing.NativeSequence
Return the sequence delegate.
getDeleteAllCriteria(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Delete all criteria is created with target foreign keys and source keys.
getDeleteAllQuery() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
 
getDeleteAllQuery() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Overrides CollectionMappig because this mapping requires a DeleteAllQuery instead of a ModifyQuery.
getDeleteAllQuery() - Method in class org.eclipse.persistence.mappings.CollectionMapping
 
getDeleteAllQuery() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
Overrides CollectionMappig because this mapping requires a DeleteAllQuery instead of a ModifyQuery.
getDeleteAtIndexQuery() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
getDeleteCall() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's delete call.
getDeletedObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: This method returns the reference to the deleted objects from the changeSet.
getDeletedObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The deleted objects stores any objects removed during the unit of work.
getDeletedObjects() - Method in interface org.eclipse.persistence.sessions.changesets.UnitOfWorkChangeSet
ADVANCED: This method returns the reference to the deleted objects from the changeSet
getDeleteNullQuery() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
getDeleteQuery() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's delete query.
getDeleteQuery() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
getDeleteQuery() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
 
getDeleteQuery() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
 
getDeleteSQLString() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's delete SQL string.
getDeletionDependencies() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return deleted objects that have reference to other deleted objects.
getDeletionDependencies(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return references to other deleted objects for this deleted object.
getDeletionHeader() - Method in class org.eclipse.persistence.tools.schemaframework.StoredFunctionDefinition
 
getDeletionHeader() - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
 
getDeployedEclipseLinkLogLevel() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Answer the EclipseLink log level at deployment time.
getDeployedEclipseLinkLogLevel() - Method in class org.eclipse.persistence.services.RuntimeServices
PUBLIC: Answer the EclipseLink log level at deployment time.
getDeployedSessionLog() - Method in class org.eclipse.persistence.services.RuntimeServices
 
getDeployedSessionProfileWeight() - Method in class org.eclipse.persistence.services.RuntimeServices
 
getDepth() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Return the current depth of the active thread.
getDepth() - Method in class org.eclipse.persistence.sessions.CopyGroup
INTERNAL: Return the cascade depth.
getDerivedIdMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: Set the maps id value
getDerivesIdMappinps() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Return the derives id mappings.
getDescribesNonPersistentSubclasses() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: Determines whether the descriptors using this inheritance policy should be used as descriptors for subclasses of the classes they describe if those subclasses do not have their own descriptor e.g.
getDescriptor() - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL: Returns the descriptor which the policy belongs to.
getDescriptor() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Return the descriptor to which this mapping belongs
getDescriptor() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL:
getDescriptor() - Method in class org.eclipse.persistence.descriptors.copying.AbstractCopyPolicy
Return the descriptor.
getDescriptor() - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
PUBLIC: The source descriptor of the event.
getDescriptor() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL:
getDescriptor() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Return the descriptor associated with this descriptor query manager
getDescriptor() - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
PUBLIC: Return the referenced descriptor.
getDescriptor() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Returns the descriptor which the policy belongs to.
getDescriptor() - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
 
getDescriptor() - Method in class org.eclipse.persistence.descriptors.MethodClassExtractor
INTERNAL: Return the descriptor.
getDescriptor() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
PUBLIC: Return the owner of the policy.
getDescriptor() - Method in interface org.eclipse.persistence.descriptors.SerializedObjectPolicy
get owning descriptor
getDescriptor() - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL:
getDescriptor() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL:
getDescriptor() - Method in interface org.eclipse.persistence.dynamic.DynamicType
 
getDescriptor() - Method in exception org.eclipse.persistence.exceptions.DescriptorException
PUBLIC: Return the descriptor that the problem was detected in.
getDescriptor() - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Only usable after the session and class have been set.
getDescriptor() - Method in class org.eclipse.persistence.history.HistoryPolicy
PUBLIC: Return the descriptor of the policy.
getDescriptor() - Method in class org.eclipse.persistence.internal.descriptors.AbstractSerializedObjectPolicy
 
getDescriptor() - Method in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
INTERNAL: Return the descriptor associated with this listener
getDescriptor() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
getDescriptor() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the descriptor
getDescriptor() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getDescriptor() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
getDescriptor() - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
 
getDescriptor() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
getDescriptor() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
getDescriptor() - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Return the class that this is the map for.
getDescriptor() - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Return the descriptor that this is the map for.
getDescriptor() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
Return the descriptor to which this mapping belongs
getDescriptor() - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
getDescriptor() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getDescriptor() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getDescriptor() - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
getDescriptor() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Convenience method
getDescriptor() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
 
getDescriptor() - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
getDescriptor() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
getDescriptor() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
getDescriptor() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return the descriptor to which this mapping belongs
getDescriptor() - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
INTERNAL: Return the descriptor.
getDescriptor() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getDescriptor() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the descriptor assigned with the reference class
getDescriptor() - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Return the descriptor that this is the map for.
getDescriptor(Class<?>) - Method in class org.eclipse.persistence.core.sessions.CoreProject
PUBLIC: Return the descriptor specified for the class.
getDescriptor(Class<?>) - Method in interface org.eclipse.persistence.core.sessions.CoreSession
ADVANCED: Return the descriptor specified for the class.
getDescriptor(Class<?>) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Returns descriptor corresponding to the class owning the policy or its subclass - otherwise null.
getDescriptor(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Return the descriptor specified for the class.
getDescriptor(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Get descriptor
getDescriptor(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
Return the table descriptor specified for the class.
getDescriptor(Class<?>) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return the descriptor specified for the class.
getDescriptor(Class<?>) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Return the table descriptor specified for the class.
getDescriptor(Class<?>) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Return the table descriptor specified for the class.
getDescriptor(Class<?>) - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Return the descriptor specified for the class.
getDescriptor(Class<?>, ABSTRACT_SESSION) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
INTERNAL: Return the descriptor for the root object.
getDescriptor(Object) - Method in interface org.eclipse.persistence.core.sessions.CoreSession
ADVANCED: Return the descriptor specified for the object's class.
getDescriptor(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
INTERNAL: Return the descriptor for the root object.
getDescriptor(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Return the descriptor specified for the object's class.
getDescriptor(Object) - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Return the descriptor specified for the object's class.
getDescriptor(Object, boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
getDescriptor(Object, ABSTRACT_SESSION) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
INTERNAL: Return the descriptor for the root object.
getDescriptor(Object, AbstractSession, boolean) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
 
getDescriptor(QName) - Method in class org.eclipse.persistence.internal.oxm.Context
INTERNAL: Return the Descriptor with the default root mapping matching the QName parameter.
getDescriptor(QName) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Return the XMLDescriptor with the default root mapping matching the QName parameter.
getDescriptor(Root) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
getDescriptor(Root, ABSTRACT_SESSION) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
getDescriptor(XPathQName) - Method in class org.eclipse.persistence.internal.oxm.Context
INTERNAL: Return the Descriptor with the default root mapping matching the XPathQName parameter.
getDescriptor(XPathQName) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Return the XMLDescriptor with the default root mapping matching the QName parameter.
getDescriptor(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Extract descriptor from the session
getDescriptor(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
To get descriptor from the server side
getDescriptor(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Extract descriptor from the session
getDescriptor(XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
getDescriptor(XMLRecord, AbstractSession, QName) - Method in class org.eclipse.persistence.oxm.mappings.XMLAbstractAnyMapping
 
getDescriptor(XMLRecord, AbstractSession, QName) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
getDescriptor(XMLRecord, AbstractSession, QName) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
getDescriptorByClass(Class<?>, List<Descriptor>) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Return the descriptor from the list whose java class matches javaClass.
getDescriptorByGlobalType(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.Context
INTERNAL: Return the Descriptor mapped to the global type matching the XPathFragment parameter.
getDescriptorByGlobalType(XPathFragment) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Return the XMLDescriptor mapped to the global type matching the XPathFragment parameter.
getDescriptorByName(String, List<Descriptor>) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Return the descriptor from the list whose java class name matches javaClassName.
getDescriptorClass() - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Return the class that this is the map for.
getDescriptorClass() - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Return the class that this is the map for.
getDescriptorClass() - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Return the class that this is the map for.
getDescriptorCorrespondingTo(ClassDescriptor) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Return the descriptor.
getDescriptorCustomizerClassName() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: DescriptorCustomizer is the JPA equivalent of an amendment method.
getDescriptorEventHolders() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: used by JPA project caching to store DescriptorEventListener representations that can build the underlying DescriptorEventListener and add it to the EventManager.
getDescriptorEventManager() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Get the event manager for the descriptor.
getDescriptorFor(Object) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Fetch and return the descriptor for the specified object.
getDescriptorForAlias(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the descriptor for the alias.
getDescriptorForAlias(String) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Get descriptor
getDescriptorForAlias(String) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
Return the table descriptor specified for the class.
getDescriptorForAlias(String) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return the descriptor for the alias
getDescriptorForAlias(String) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Return the table descriptor specified for the class.
getDescriptorForAlias(String) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Return the table descriptor specified for the alias.
getDescriptorForAlias(String) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the descriptor for the alias.
getDescriptorForAlias(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Extract descriptor from the session
getDescriptorForAlias(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
To get descriptor from the server side
getDescriptorForAlias(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Extract descriptor from the session
getDescriptorForMapKey() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the reference descriptor for the map key if it exists
getDescriptorForMapKey() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Return the reference descriptor for the map key if it exists.
getDescriptorForObject(Object) - Method in class org.eclipse.persistence.oxm.XMLContext
Returns descriptor for given object.
getDescriptorForTarget(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Return a descriptor for the target of this mapping
getDescriptorForTarget(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Return a descriptor for the target of this mapping For normal ObjectReferenceMappings, we return the reference descriptor.
getDescriptorInheritancePolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: The inheritance policy is used to define how a descriptor takes part in inheritance.
getDescriptorMethodNames() - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
getDescriptorQueryManager() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the queryManager.
getDescriptors() - Method in interface org.eclipse.persistence.core.sessions.CoreSession
ADVANCED: Return all registered descriptors.
getDescriptors() - Method in class org.eclipse.persistence.internal.core.sessions.CoreAbstractSession
ADVANCED: Return all registered descriptors.
getDescriptors() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Return all registered descriptors.
getDescriptors() - Method in class org.eclipse.persistence.oxm.XMLContext
Returns descriptors from all sessions.
getDescriptors() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: This is here only for JPA queries and currently only populated for JPA queries.
getDescriptors() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return the descriptors in a ClassDescriptors Map keyed on the Java class.
getDescriptors() - Method in class org.eclipse.persistence.sessions.server.ClientSession
ADVANCED: Return all registered descriptors.
getDescriptors() - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Return all registered descriptors.
getDescriptorType() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: return the descriptor type (NORMAL by default, others include INTERFACE, AGGREGATE, AGGREGATE COLLECTION)
getDescriptorTypeValue() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: This method is explicitly used by the XML reader.
getDirectField() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return the direct field.
getDirectFieldName() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Returns the name of the field name in the reference table.
getDirection() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL:
getDirection() - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC:
getDirectKeyField() - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL:
getDirectKeyField(CollectionMapping) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Return the DatabaseField that represents the key in a DirectMapMapping.
getDirectKeyField(CollectionMapping) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return the DatabaseField that represents the key in a DirectMapMapping.
getDirectKeyField(CollectionMapping) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Return the DatabaseField that represents the key in a DirectMapMapping.
getDiscoveryConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.RMITransportManagerConfig
 
getDiscoveryManager() - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
PUBLIC: Return the discovery manager that manages membership in the EclipseLink cluster.
getDiscoveryManager() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
PUBLIC: Return the discovery manager that detects the arrival of new cluster members
getDiscriminatorColumn() - Method in class org.eclipse.persistence.queries.EntityResult
Returns the column name for the column that will store the value used to determine the subclass type if applicable.
getDistinctState() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
ADVANCED: If a distinct has been set the DISTINCT clause will be printed.
getDocPresPolicy() - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
getDocPresPolicy() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
getDocument() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getDocument() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
PUBLIC: Return the document.
getDocument() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
getDocument() - Method in class org.eclipse.persistence.oxm.record.NodeRecord
 
getDocument() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getDocument() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
getDocument() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
PUBLIC: Return the document.
getDocument() - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
getDocumentation() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Annotation
 
getDocumentLocator() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getDocumentPreservationPolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Login
 
getDocumentPreservationPolicy() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.XMLLoginConfig
 
getDocumentPreservationPolicy() - Method in class org.eclipse.persistence.oxm.XMLBinder
Gets this XMLBinder's document preservation policy.
getDocumentPreservationPolicy() - Method in class org.eclipse.persistence.oxm.XMLLogin
 
getDocumentPreservationPolicy(AbstractSession) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Return the DocumentPreservationPolicy associated with this session
getDoesExistCall() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's does-exist call.
getDoesExistField() - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Return the write lock field or the first primary key field if not using locking.
getDoesExistQuery() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's does exist query.
getDoesExistSQLString() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's does exist SQL string.
getDOM() - Method in interface org.eclipse.persistence.eis.DOMRecord
 
getDOM() - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
getDOM() - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
getDOM() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
PUBLIC: Return the DOM.
getDOM() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
getDOM() - Method in class org.eclipse.persistence.oxm.record.NodeRecord
Return the Node that the object will be marshalled to.
getDOM() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getDOM() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
getDOM() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
PUBLIC: Return the DOM.
getDomainClass() - Method in class org.eclipse.persistence.tools.profiler.Profile
 
getDomainClassNounName(String) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: TopLink_sessionName_domainClass.
getDomainObject() - Method in class org.eclipse.persistence.internal.oxm.WeakObjectWrapper
 
getDoNotRedirect() - Method in class org.eclipse.persistence.queries.DatabaseQuery
This method is used in combination with redirected queries.
getDoubleClassType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the type representation of class Double.
getDoubleType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the double type representation.
getDriver() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Return db driver class name.
getDriver() - Method in class org.eclipse.persistence.services.RuntimeServices
Return db driver class name.
getDriverClass() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getDriverClassName() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The driver class is the name of the Java class for the JDBC driver being used (e.g.
getDriverClassName() - Method in class org.eclipse.persistence.sessions.DefaultConnector
PUBLIC: The driver class is the name of the Java class for the JDBC driver being used (e.g.
getDriverSupportsNVarChar() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
getDriverURLHeader() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The driver URL header is the string predetermined by the JDBC driver to be part of the URL connection string, (e.g.
getDriverURLHeader() - Method in class org.eclipse.persistence.sessions.DefaultConnector
PUBLIC: The driver URL header is the string predetermined by the JDBC driver to be part of the URL connection string, (e.g.
getDropCascadeString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allows DROP TABLE to cascade dropping of any dependent constraints if the database supports this option.
getDropCascadeString() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Allows DROP TABLE to cascade dropping of any dependent constraints if the database supports this option.
getDropCascadeString() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
Allows DROP TABLE to cascade dropping of any dependent constraints if the database supports this option.
getDropDatabaseSchemaString(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return the drop schema SQL syntax.
getDropDatabaseSchemaString(String) - Method in class org.eclipse.persistence.platform.database.MariaDBPlatform
Return the drop schema definition.
getDropDatabaseSchemaString(String) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
Return the drop schema definition.
getDropDatabaseSchemaString(String) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Return the drop schema definition.
getDropSchemaWriter() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
getDtdFileName(String) - Method in class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
INTERNAL:
getDTDHandler() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
getDTDHandler() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
getDumpTime() - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
Return the number of milliseconds after which the monitor results should be logged.
getDynamicClassLoader() - Method in class org.eclipse.persistence.dynamic.DynamicHelper
 
getDynamicPropertiesManager() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getDynamicSQLMechanism() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Lazy init the dynamic SQL mechanism.
getEagerMappings() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Return all mappings that are eager loaded (but use indirection).
getEISPlatform() - Method in class org.eclipse.persistence.eis.EISAccessor
Return and cast the platform.
getEjbqlString() - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: Return the EJBQL string for this call
getEJBQLString() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return the EJBQL string of the query.
getElementClass() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Returns the element class which defines the map key.
getElementClassName() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Returns the element class name which defines the map key.
getElementDataTypeName() - Method in class org.eclipse.persistence.mappings.structures.ArrayMapping
PUBLIC: Return the "data type" associated with each element in the nested collection.
getElementDescriptor() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Used for wrapping and unwrapping with the wrapper policy.
getElements() - Method in class org.eclipse.persistence.internal.oxm.schema.model.TypeDefParticle
 
getEmptyRecord() - Static method in class org.eclipse.persistence.internal.sessions.EmptyRecord
Return the singleton empty record.
getEnableJTA() - Method in class org.eclipse.persistence.internal.sessions.factories.model.platform.ServerPlatformConfig
 
getEnableRuntimeServices() - Method in class org.eclipse.persistence.internal.sessions.factories.model.platform.ServerPlatformConfig
 
getEncoding() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
Get the encoding set on this Marshaller.
getEncoding() - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.LocatorImpl
 
getEncoding() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
Gets the encoding for this document.
getEncoding() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
PUBLIC: Gets the encoding for this document.
getEncoding() - Method in class org.eclipse.persistence.internal.oxm.Root
Gets the encoding which will be set on the XMLRoot during unmarshal.
getEncoding() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
Gets the encoding for this document.
getEncoding() - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
getEncryptedPassword() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
Assume the password has been encrypted and return it.
getEncryptedPassword() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
Assume the password has been encrypted and return it.
getEncryptedPassword() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
PUBLIC: Return the encrypted (assumed) password used as the value to the SECURITY_CREDENTIALS key in the cached context properties.
getEncryptionClass() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
getEncryptionClass() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
 
getEncryptionClassName() - Method in class org.eclipse.persistence.internal.security.SecurableObjectHolder
 
getEnd() - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
getEnd(int) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
getEndDelimiter() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Delimiter to use for fields and tables using spaces or other special values.
getEndDelimiter() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Delimiter to use for fields and tables using spaces or other special values.
getEndFieldName() - Method in class org.eclipse.persistence.history.HistoryPolicy
PUBLIC:
getEndFields() - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
getEndValue() - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartition
PUBLIC: Return the range end value.
getEntityEventListener() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: EJB 3.0 support.
getEntityFetchGroup(Set<String>) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Returns entity fetch group corresponding to the passed set of attributes.
getEntityFetchGroup(FetchGroupManager) - Method in class org.eclipse.persistence.queries.FetchGroup
INTERNAL: Used to retrieve the EntityFetchGroup for this FetchGroup
getEntityFetchGroup(FetchGroup) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Returns entity fetch group corresponding to the passed fetch group.
getEntityListenerEventListeners() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: EJB 3.0 support.
getEntityResolver() - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
getEntityResolver() - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
getEntityResolver() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
getEntityResolver() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
getEntityResolver() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
getEntityResolver() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Get the EntityResolver set on this XMLUnmarshaller
getEntityResolver() - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
getEnum() - Method in class org.eclipse.persistence.dynamic.DynamicEnumBuilder
 
getEnumClass() - Method in class org.eclipse.persistence.mappings.converters.EnumTypeConverter
 
getEnumClassName() - Method in class org.eclipse.persistence.mappings.converters.EnumTypeConverter
 
getEnumerationFacets() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getEqualNamespaceResolvers() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.XMLLoginConfig
 
getErrorCode() - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
PUBLIC: Return the exception error code.
getErrorHandler() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
 
getErrorHandler() - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
getErrorHandler() - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
getErrorHandler() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
getErrorHandler() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
getErrorHandler() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
getErrorHandler() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Get the ErrorHandler set on this Unmarshaller
getErrorHandler() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Get the ErrorHandler set on this XMLUnmarshaller
getErrorHandler() - Method in class org.eclipse.persistence.oxm.XMLBinder
 
getErrorHandler() - Method in class org.eclipse.persistence.oxm.XMLValidator
Get the error handler to be used during validation
getErrorHandler() - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
getEventCode() - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
PUBLIC: The code of the descriptor event being raised.
getEventCode() - Method in class org.eclipse.persistence.sessions.SessionEvent
PUBLIC: The code of the session event being raised.
getEventListeners() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: Returns the Listener objects that have been added.
getEventManager() - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
PUBLIC: Get the event manager for the descriptor.
getEventManager() - Method in interface org.eclipse.persistence.core.sessions.CoreSession
PUBLIC: Return the event manager.
getEventManager() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Get the event manager for the descriptor.
getEventManager() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the event manager.
getEventManager() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the event manager.
getEventMethods() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
getEventSelectors() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
getExampleObject() - Method in class org.eclipse.persistence.internal.queries.QueryByExampleMechanism
PUBLIC: This method returns the current example object.
getExampleObject() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: This method returns the current example object.
getException() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Return any exception that was throw from concurrent population thread.
getException() - Method in class org.eclipse.persistence.internal.sessions.remote.Transporter
Return the exception which this Transporter is holding.
getException() - Method in class org.eclipse.persistence.logging.SessionLogEntry
Return the exception that caused the log entry.
getExceptionHandler() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the ExceptionHandler.Exception handler can catch errors that occur on queries or during database access.
getExceptionHandler() - Method in interface org.eclipse.persistence.sessions.ExternalTransactionController
Return the exception handler used to handle or wrap exceptions thrown in before/after completion.
getExceptionHandler() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the ExceptionHandler.Exception handler can catch errors that occur on queries or during database access.
getExceptionHandler() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
Return the exception handler used to handle or wrap exceptions thrown in before/after completion.
getExceptionHandlerClass() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return a string which represents my ExceptionHandler's class Added for F2104: Properties.xml - gn
getExceptionHandlerClass() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
getExceptionList() - Method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
getExceptions() - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
getExceptionStore() - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
INTERNAL:
getExclusive() - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ReadConnectionPoolConfig
 
getExclusiveMode() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Returns exclusive mode.
getExecuteReturnValue() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
After an execute call the return value can be retrieved here.
getExecutionFetchGroup() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Returns FetchGroup that will be applied to the query.
getExecutionFetchGroup() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Returns FetchGroup that will be applied to the query.
getExecutionFetchGroup(ClassDescriptor) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Returns FetchGroup that will be applied to the query.
getExecutionFetchGroup(ClassDescriptor) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Returns FetchGroup that will be applied to the query.
getExecutionSession() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Convenience method
getExecutionSession() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Return the correct session for the transaction context.
getExecutionSession() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Returns the session the underlying call was executed on.
getExecutionSession() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the execution session.
getExecutionSession(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Gets the session which this query will be executed on.
getExecutionSession(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSession
INTERNAL: Gets the session which this query will be executed on.
getExecutionSession(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Gets the session which this query will be executed on.
getExecutionSession(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Gets the session which this query will be executed on.
getExecutionSession(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Gets the session which this query will be executed on.
getExecutionSession(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Gets the session which this query will be executed on.
getExecutionTime() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Return the time this query actually went to the database
getExistenceCheck() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: This method is explicitly used by the Builder only.
getExistencePolicy() - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Return the existence policy for this existence Query
getExpiryTime() - Method in class org.eclipse.persistence.descriptors.invalidation.DailyCacheInvalidationPolicy
INTERNAL: Get the expiry time as a Calendar.
getExpiryTimeInMillis(CacheKey) - Method in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
INTERNAL: Get the next time when this object will become invalid
getExpiryTimeInMillis(CacheKey) - Method in class org.eclipse.persistence.descriptors.invalidation.DailyCacheInvalidationPolicy
INTERNAL: Return the next expiry time.
getExpiryTimeInMillis(CacheKey) - Method in class org.eclipse.persistence.descriptors.invalidation.NoExpiryCacheInvalidationPolicy
INTERNAL: Since this policy implements no expiry, this will always return NO_EXPIRY
getExpiryTimeInMillis(CacheKey) - Method in class org.eclipse.persistence.descriptors.invalidation.TimeToLiveCacheInvalidationPolicy
INTERNAL: Return the next expiry time.
getExpression() - Method in class org.eclipse.persistence.internal.helper.FunctionField
 
getExpressionBuilder() - Method in class org.eclipse.persistence.internal.expressions.SQLStatement
 
getExpressionBuilder() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return an expression builder which is valid for us
getExpressionBuilder() - Method in class org.eclipse.persistence.queries.ModifyAllQuery
PUBLIC: Get the expression builder which should be used for this query.
getExpressionBuilder() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
REQUIRED: Get the expression builder which should be used for this query.
getExpressionQueryCacheMaxSize() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the max size of the expression query cache for avoiding regenerated dynamic query SQL.
getExtendPessimisticLockScopeDedicatedQuery(AbstractSession, short) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Should be overridden by subclass that allows setting extendPessimisticLockScope to DEDICATED_QUERY.
getExtendPessimisticLockScopeDedicatedQuery(AbstractSession, short) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Should be overridden by subclass that allows setting extendPessimisticLockScope to DEDICATED_QUERY.
getExtendPessimisticLockScopeDedicatedQuery(AbstractSession, short) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Should be overridden by subclass that allows setting extendPessimisticLockScope to DEDICATED_QUERY.
getExtension() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Content
 
getExternalConnectionPooling() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
getExternalTransactionController() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Used for JTS integration.
getExternalTransactionController() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
getExternalTransactionController() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Used for JTS integration.
getExternalTransactionControllerClass() - Method in class org.eclipse.persistence.internal.sessions.factories.model.platform.CustomServerPlatformConfig
 
getExternalTransactionControllerClass() - Method in class org.eclipse.persistence.platform.server.CustomServerPlatform
INTERNAL: getExternalTransactionControllerClass(): Answer the class of external transaction controller to use in the DatabaseSession This is defined by the user via the 904 sessions.xml.
getExternalTransactionControllerClass() - Method in class org.eclipse.persistence.platform.server.glassfish.GlassfishPlatform
INTERNAL: getExternalTransactionControllerClass(): Answer the class of external transaction controller to use for SUN AS9.
getExternalTransactionControllerClass() - Method in class org.eclipse.persistence.platform.server.NoServerPlatform
INTERNAL: getExternalTransactionControllerClass(): Answer null because this does not apply.
getExternalTransactionControllerClass() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: getExternalTransactionControllerClass(): Answer the class of external transaction controller to use For this server platform.
getExternalTransactionControllerClass() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: getExternalTransactionControllerClass(): Answer the class of external transaction controller to use For this server platform.
getExternalTransactionControllerClass() - Method in class org.eclipse.persistence.platform.server.was.WebSphere_EJBEmbeddable_Platform
INTERNAL: getExternalTransactionControllerClass(): Answer the class of external transaction controller to use for WebSphere EJBEmbeddable.
getExternalTransactionControllerClass() - Method in class org.eclipse.persistence.platform.server.was.WebSphere_Liberty_Platform
INTERNAL: getExternalTransactionControllerClass(): Answer the class of external transaction controller to use for WebSphere Liberty.
getExternalTransactionControllerClass() - Method in class org.eclipse.persistence.platform.server.was.WebSpherePlatform
INTERNAL: getExternalTransactionControllerClass(): Answer the class of external transaction controller to use for WebSphere.
getExternalTransactionControllerClass() - Method in class org.eclipse.persistence.platform.server.wls.WebLogic_10_Platform
INTERNAL: getExternalTransactionControllerClass(): Answer the class of external transaction controller to use for WebLogic.
getExternalTransactionControllerClass() - Method in class org.eclipse.persistence.platform.server.wls.WebLogicPlatform
INTERNAL: getExternalTransactionControllerClass(): Answer the class of external transaction controller to use for WebLogic.
getFactory() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
getFactoryClass() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
getFactoryClassName() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
getFactoryMethodName() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
getFailoverConnectionPools() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Return the list of connection pools to used if this pool database goes down.
getFeature(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
getFeature(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
getFetchGroup() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Return the fetch group set in the query.
getFetchGroup(String) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
Return a pre-defined named fetch group.
getFetchGroup(String, boolean) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
Lookup the FetchGroup to use given a name and a flag taking into consideration descriptor inheritance to ensure parent descriptors are searched for named and default FetchGroup.
getFetchGroupManager() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Get the fetch group manager for the descriptor.
getFetchGroupName() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Return the fetch group name set in the query.
getFetchGroupNonNestedFieldsSet() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the set of fields required in the select clause, for fetch group reading.
getFetchGroupNonNestedFieldsSet(DatabaseMapping) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the set of fields required in the select clause, for fetch group reading.
getFetchGroups() - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
Return the fetch group map: keyed by the group name, valued by the fetch group object.
getFetchGroupSelectionFields() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the fields required in the select clause, for fetch group reading.
getFetchGroupSelectionFields(DatabaseMapping) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the fields required in the select clause, for fetch group reading.
getFetchSize() - Method in class org.eclipse.persistence.queries.ReadQuery
PUBLIC: Return the fetchSize setting that this query will set on the JDBC Statement NB - a value of zero means that no call to statement.setFetchSize() will be made.
getField() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Return the field associated with this mapping if there is exactly one.
getField() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
getField() - Method in interface org.eclipse.persistence.descriptors.SerializedObjectPolicy
get the field that stores sopObject in the database (sopField)
getField() - Method in class org.eclipse.persistence.internal.descriptors.AbstractSerializedObjectPolicy
 
getField() - Method in class org.eclipse.persistence.internal.descriptors.FieldTransformation
 
getField() - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
INTERNAL:
getField() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL:
getField() - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL:
getField() - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
INTERNAL:
getField() - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
 
getField() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL:
getField() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
 
getField() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return the field associated with this mapping if there is exactly one.
getField() - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL: Returns the field which this mapping represents.
getField() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Return the field mapped by this mapping.
getField() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Return the field that holds the nested collection.
getField() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: The aggregate object is held in a single field.
getField() - Method in class org.eclipse.persistence.mappings.querykeys.DirectQueryKey
INTERNAL: Return the field for the query key.
getField() - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: Returns the field which this mapping represents.
getField() - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Returns the field which this mapping represents.
getField() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
getField() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
getField() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
getField() - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
 
getField(Class<?>, String) - Static method in class org.eclipse.persistence.internal.helper.Helper
INTERNAL: Returns a Field for the specified Class and field name.
getField(Class<?>, String, boolean) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get a field in a class or its superclasses and wrap the call in doPrivileged if necessary.
getField(String) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression representing a field in a data-level query.
getField(String) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
getField(String) - Method in class org.eclipse.persistence.internal.expressions.TableExpression
INTERNAL: Fully-qualify the databaseField if the table is known.
getField(String) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Return the field the corresponds to the name.
getField(DatabaseField) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL: Returns an equal field held by ReturningPolicy, or null.
getField(DatabaseField) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression representing a field in a data-level query.
getField(DatabaseField) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
getField(DatabaseField) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
This allows for nesting of parametrized expression.
getField(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: Returns the row's field with the same name.
getField(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
INTERNAL: Returns the row's field with the same name.
getFieldClassification() - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Get the type of the field value to allow conversion from the database.
getFieldClassification() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
ADVANCED: Return the class type of the field value.
getFieldClassification(DatabaseField) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: Return the classifiction for the field contained in the mapping.
getFieldClassification(DatabaseField) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Return the classification for the field contained in the mapping.
getFieldClassification(DatabaseField) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return the classification for the field contained in the mapping.
getFieldClassification(DatabaseField) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Return the classifiction for the field contained in the mapping.
getFieldClassification(DatabaseField) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return the classification for the field contained in the mapping.
getFieldClassification(DatabaseField) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Return the classifiction for the field contained in the mapping.
getFieldClassification(DatabaseField) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Return the classification for the field contained in the mapping.
getFieldClassification(DatabaseField) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return the classification for the field contained in the mapping.
getFieldClassification(DatabaseField) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Return the classification for the field contained in the mapping.
getFieldClassificationClassName() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Get fieldClassificationClassName.
getFieldClassificationName() - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
getFieldDefFromDBField(DatabaseField) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Build a field definition object from a database field.
getFieldElementClass() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
PUBLIC: Return the class each element in the database row's collection should be converted to, before the collection is inserted into the database.
getFieldForQueryKeyName(String) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the field used for the query key name.
getFieldInfos() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
getFieldName() - Method in class org.eclipse.persistence.eis.mappings.EISCompositeCollectionMapping
PUBLIC: Return the name of the field mapped by the mapping.
getFieldName() - Method in class org.eclipse.persistence.eis.mappings.EISCompositeDirectCollectionMapping
PUBLIC: Return the name of the field that holds the nested collection.
getFieldName() - Method in class org.eclipse.persistence.eis.mappings.EISCompositeObjectMapping
PUBLIC: Return the name of the field mapped by the mapping.
getFieldName() - Method in class org.eclipse.persistence.internal.descriptors.FieldTransformation
 
getFieldName() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
PUBLIC: Return the name of the field that holds the nested collection.
getFieldName() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
PUBLIC: Name of the field this mapping represents.
getFieldName() - Method in class org.eclipse.persistence.mappings.querykeys.DirectQueryKey
PUBLIC: Return the field name for the query key.
getFieldName() - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
PUBLIC: Return the name of the field this mapping represents.
getFieldName() - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
PUBLIC: Return the name of the field this mapping represents.
getFieldName(String) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: return the original field name based on the argument name.
getFieldNameToMethodNameAssociations() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Needed for backwards compatibility
getFieldNameToMethodNames() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Required for reverse compatibility and test cases:
getFieldResults() - Method in class org.eclipse.persistence.queries.EntityResult
Accessor for the internally stored list of FieldResult.
getFieldResults() - Method in class org.eclipse.persistence.queries.FieldResult
INTERNAL:
getFields() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Returns a vector of all the fields this mapping represents.
getFields() - Method in class org.eclipse.persistence.descriptors.CacheIndex
 
getFields() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return all the fields
getFields() - Method in class org.eclipse.persistence.eis.EISMappedRecord
INTERNAL: getFields() is sued internally in a few places, so try to make that work for mapped records.
getFields() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
getFields() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
The fields expected by the calls result set.
getFields() - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
INTERNAL: Return all the fields
getFields() - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: Return all the fields
getFields() - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Not to be confused with the public getField(String) This returns a collection of all fields associated with this object.
getFields() - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
INTERNAL: Return all the fields
getFields() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL: Not to be confused with the public getField(String) This returns a collection of all fields associated with this object.
getFields() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Return all the fields
getFields() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Return all the fields
getFields() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
getFields() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
getFields() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ObjectReferenceMapping
 
getFields() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL:
getFields() - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
INTERNAL:
getFields() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Returns a vector of all the fields this mapping represents.
getFields() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
getFields() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
getFields() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
getFields() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
getFields() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
getFields() - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
INTERNAL: Return a list of XMLFields based on the source XPath values in the source-target key field associations list.
getFields() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
getFields() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
getFields() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: This should not be used, but added some support for it as is called from some places such as sdk call used in the descriptor to define operation not supported, may also be called from toplin in some places.
getFields() - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
getFields() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
Return the record's fields defined as PLSQLargument.
getFields() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Return the fields for the stream.
getFields() - Method in class org.eclipse.persistence.tools.schemaframework.IndexDefinition
 
getFields() - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC:
getFields() - Method in class org.eclipse.persistence.tools.schemaframework.TypeDefinition
 
getFields(Class<?>) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get the list of public fields in a class.
getFieldsArray() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: The array of fields returned by the call.
getFieldsForTranslationInAggregate() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return source key fields for translation by an AggregateObjectMapping
getFieldsForTranslationInAggregate() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return source key fields for translation by an AggregateObjectMapping By default, return an empty NonSynchronizedVector
getFieldsForTranslationInAggregate() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Return source key fields for translation by an AggregateObjectMapping
getFieldsForTranslationInAggregate() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Return source key fields for translation by an AggregateObjectMapping
getFieldsForTranslationInAggregate() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return source key fields for translation by an AggregateObjectMapping
getFieldsMap() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the fields map.
getFieldsToCompare(DatabaseTable, AbstractRecord, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.AllFieldsLockingPolicy
INTERNAL: Returns the fields that should be compared in the where clause.
getFieldsToCompare(DatabaseTable, AbstractRecord, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.ChangedFieldsLockingPolicy
INTERNAL: Returns the fields that should be compared in the where clause.
getFieldsToCompare(DatabaseTable, AbstractRecord, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Returns the fields that should be compared in the where clause.
getFieldsToCompare(DatabaseTable, AbstractRecord, AbstractRecord) - Method in class org.eclipse.persistence.descriptors.SelectedFieldsLockingPolicy
INTERNAL: returns the lock fields to compare based on the passed in table.
getFieldsToGenerateInsert(DatabaseTable) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
getFieldsToGenerateUpdate(DatabaseTable) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
getFieldsToMergeInsert() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
getFieldsToMergeUpdate() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
getFieldToAttributeValueAssociations() - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Return a collection of the field to attribute value associations.
getFieldToAttributeValues() - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Get the field to attribute mapping.
getFieldToClassMappings() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
getFieldToClassMappings() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
getFieldToClassMappings() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
getFieldToClassMappings() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
getFieldToTransformers() - Method in interface org.eclipse.persistence.internal.oxm.mappings.TransformationMapping
INTERNAL:
getFieldToTransformers() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL:
getFieldTransformations() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Returns a Vector which stores fieldnames and the respective method/transformer names.
getFieldTransformer() - Method in class org.eclipse.persistence.internal.oxm.FieldTransformerNodeValue
 
getFieldType() - Method in class org.eclipse.persistence.mappings.transformers.MethodBasedFieldTransformer
Return the Java class type of the field value.
getFieldType(Object) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: return the class corresponding to the passed in JDBC type.
getFieldType(Field) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get the return type for a given method.
getFieldTypeDefinition(Class<?>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return the field type object describing this databases platform specific representation of the Java primitive class name.
getFieldTypeDefinition(DatabasePlatform, Class<?>, String) - Static method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Retrieve database platform specific field definition from database specific platform handler for existing type or build a new one when type is null and type for type name could not be found.
getFieldTypeDefinition(AbstractSession, Class<?>, String) - Static method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Retrieve a database platform specific definition from session for existing type instance or build a new one when type is null.
getFieldTypes() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return the class type to database type mappings for the schema framework.
getFieldValue(Object, CoreAbstractSession, AbstractMarshalRecord) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
getFieldValue(Object, CoreAbstractSession, AbstractMarshalRecord) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
 
getFieldValue(Object, CoreAbstractSession, AbstractMarshalRecord) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
INTERNAL:
getFieldValue(Object, CoreAbstractSession, AbstractMarshalRecord) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
INTERNAL: Convert the attribute value to a field value.
getFieldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Transform the object-level value into a database-level value
getFieldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
INTERNAL: Transform the object-level value into a database-level value objectValue is a Class or collection of Class objects and the returned value is the database representation Example: ObjectValue=LargeProject returns "L".
getFieldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: Provide for conversion of the passed object's value, based on the referenced field value.
getFieldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Transform the object-level value into a database-level value
getFieldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
getFieldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Convert the attribute value to a field value.
getFieldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL: Convert the object (attribute or property) value to a field value.
getFieldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Convert the attribute value to a field value.
getFieldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL:
getFieldWithTypeFromDescriptor(DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Unfortunately can't avoid referencing query and descriptor: the call should be performed after the translateCustomSQL (in SQLCall) in the middle of prepare method (no parameter available earlier).
getFile() - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaFileReference
 
getFilename() - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.DefaultSessionLogConfig
 
getFileName() - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaFileReference
 
getFinishingTime() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
getFirst() - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
Returns the first contents in this list.
getFirstArgumentIndex() - Method in class org.eclipse.persistence.tools.schemaframework.StoredFunctionDefinition
 
getFirstArgumentIndex() - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
 
getFirstChild() - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
getFirstNonAggregateExpressionAfterExpressionBuilder(List) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL: Parses an expression to return the first non-AggregateObjectMapping expression after the base ExpressionBuilder.
getFirstParameterIndexForCallString() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredFunctionCall
INTERNAL: Return the first index of parameter to be placed inside brackets in the call string.
getFirstParameterIndexForCallString() - Method in class org.eclipse.persistence.queries.StoredFunctionCall
INTERNAL: Return the first index of parameter to be placed inside brackets in the call string.
getFirstParameterIndexForCallString() - Method in class org.eclipse.persistence.queries.StoredProcedureCall
INTERNAL: Return the first index of parameter to be placed inside brackets in the call string
getFirstResult() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
get first result
getFirstResult() - Method in class org.eclipse.persistence.queries.ReadQuery
PUBLIC: Return the value that will be set for the firstResult in the returned result set
getFixed() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
getFloatClassType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the type representation of class Float.
getFloatType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the float type representation.
getFlushClearCache() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
Return the FlashClearCache mode to be used.
getFlushOnExecute() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: If executed against a RepeatableWriteUnitOfWork if this attribute is true EclipseLink will write changes to the database before executing the query.
getForceFieldNamesToUppercase() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getForceUpdate() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
ADVANCED: Return true if descriptor is set to always update all registered objects of this type
getForeignKeyConstraint(String) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
getForeignKeyConstraints() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
getForeignKeyDefinition() - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
getForeignKeyFieldName() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
getForeignKeyFieldNames() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Return the foreign key field names associated with the mapping.
getForeignKeyFieldNames() - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
PUBLIC: Return the foreign key field names associated with the mapping.
getForeignKeyFields() - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Returns the foreign key names associated with the mapping.
getForeignKeyFieldsForMapKey() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Return a Map of any foreign keys defined within the the MapKey.
getForeignKeyFieldsForMapKey() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return a Map of any foreign keys defined within the the MapKey
getForeignKeyFieldsForMapKey() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Return a Map of any foreign keys defined within the the MapKey.
getForeignKeyFieldsForMapKey() - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Return a Map of any foreign keys defined within the the MapKey
getForeignKeyFieldsForMapKey() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return a Map of any foreign keys defined within the the MapKey
getForeignKeyGroupingElement() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
Get the grouping element field on the mapping.
getForeignKeyMap() - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL:
getForeignKeyRows(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL:
getForeignKeys() - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Returns the ForeignKeyConstraint list.
getForeignKeysToPrimaryKeys() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
Return the appropriate map that maps the "foreign keys" to the "primary keys".
getForeignKeyValuesForCaching() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL:
getForeignReferenceMapping() - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Reduce casting clutter....
getForm() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
getForUpdateClause() - Method in class org.eclipse.persistence.internal.expressions.OuterJoinExpressionHolder
 
getForUpdateClause() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
getForUpdateOfFields() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL: Returns the first field from each of the owned tables, used for fine-grained pessimistic locking.
getFractionDigits() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getFractionDigits() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getFragmentBuilder() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getFragmentBuilder() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getFragmentBuilder() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getFromIdentityMap(Object) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Get the object from the identity map which has the same identity information as the given object.
getFromIdentityMap(Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Return the object from the identity with primary and class of the given object.
getFromIdentityMap(Object) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Returns the Object from the identity map with the same primary key and Class type of the given domainObject.
getFromIdentityMap(Object, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Return the object from the identity with the primary and class.
getFromIdentityMap(Object, Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Returns the Object from the identity map with the same primary key and Class type as those specified.
getFromIdentityMap(Object, Class<?>, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Return the object from the identity with the primary and class.
getFromIdentityMap(Object, Class<?>, boolean) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Returns the Object from the identity map with the same primary key and Class type as specified.
getFromIdentityMap(Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Get the object from the identity map which has the given primary key and class.
getFromIdentityMap(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Get the object from the identity map which has the given primary key and class.
getFromIdentityMap(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Return the object from the identity with the primary and class.
getFromIdentityMap(Object, Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Return the object from the identity with the primary and class.
getFromIdentityMap(Object, Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
ADVANCED: Return the object from the identity with the primary and class.
getFromIdentityMap(Object, Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
INTERNAL: Return the object from the identity map with the primary key and class.
getFromIdentityMap(Expression, Class<?>, DataRecord) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Query the cache in-memory.
getFromIdentityMap(Expression, Class<?>, DataRecord) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Queries the cache in-memory and returns an Object from this identity map.
getFromIdentityMap(Expression, Class<?>, DataRecord, int) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Query the cache in-memory.
getFromIdentityMap(Expression, Class<?>, DataRecord, int) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Queries the cache in-memory and returns an Object from this identity map.
getFromIdentityMap(Expression, Class<?>, DataRecord, int, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Query the cache in-memory.
getFromIdentityMap(Expression, Class<?>, DataRecord, int, boolean, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Query the cache in-memory.
getFromIdentityMap(Expression, Class<?>, DataRecord, int, boolean, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
 
getFromIdentityMap(Expression, Class<?>, DataRecord, int, boolean, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Query the cache in-memory.
getFromIdentityMap(Expression, Class<?>, DataRecord, int, boolean, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Query the cache in-memory.
getFromIdentityMap(Expression, Class<?>, DataRecord, InMemoryQueryIndirectionPolicy) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Query the cache in-memory.
getFromIdentityMap(Expression, Class<?>, DataRecord, InMemoryQueryIndirectionPolicy) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Queries the cache in-memory and returns an Object from this identity map.
getFromIdentityMap(DataRecord, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Return the object from the identity with the primary and class.
getFromIdentityMap(DataRecord, Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Returns the Object from the identity map with the same primary key of the specified row (i.e.
getFromIdentityMap(DataRecord, Class<?>, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Return the object from the identity with the primary and class.
getFromIdentityMap(DataRecord, Class<?>, boolean) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Returns the Object from the identity map with the same primary key of the specified row and Class type.
getFromIdentityMapWithDeferredLock(Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Get the object from the cache with the given primary key and class.
getFromIdentityMapWithDeferredLock(Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Return the object from the identity with the primary and class.
getFromIdentityMapWithDeferredLock(Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Return the object from the identity with the primary and class.
getFromIdentityMapWithDeferredLock(Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
INTERNAL: Override the getFromIdentityMapWithDeferredLock method on the session to ensure that invalidated objects are always returned since this is a UnitOfWork
getFromIdentityMapWithDeferredLock(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Return the object from the identity with the primary and class.
getFromLocalIdentityMap(Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Return the object from the local identity map with the primary and class.
getFromLocalIdentityMap(Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Return the object from the local identity map with the primary and class.
getFromLocalIdentityMapWithDeferredLock(Object, Class<?>, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Return the object from the local identity map with the primary and class.
getFullName() - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Most major databases support a creator name scope.
getFullName() - Method in class org.eclipse.persistence.tools.schemaframework.SequenceObjectDefinition
INTERNAL: Most major databases support a creator name scope.
getFullyMergeEntity() - Method in class org.eclipse.persistence.descriptors.CachePolicy
 
getFullyMergeEntity() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
 
getFunction(int) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: This can be used for accessing user defined functions.
getFunction(int, List) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: This can be used for accessing user defined functions that have arguments.
getFunction(String) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return a user defined function accepting the argument.
getFunction(String, Object) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return a user defined function accepting the argument.
getFunctionCallHeader() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for stored function calls.
getFunctionCallHeader() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
Used for stored function calls.
getFunctionName() - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: Return the function name of the interaction.
getFunctionWithArguments(String, List) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return a user defined function accepting all of the arguments.
getGeneratedKeys() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
The result set that stores the generated keys from the Statement
getGeneratedValue(Accessor, AbstractSession) - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: Return the newly-generated sequencing value.
getGeneratedValue(Accessor, AbstractSession, String) - Method in class org.eclipse.persistence.sequencing.DefaultSequence
INTERNAL: Return the newly-generated sequencing value.
getGeneratedValue(Accessor, AbstractSession, String) - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: Return the newly-generated sequencing value.
getGeneratedValue(Accessor, AbstractSession, String) - Method in class org.eclipse.persistence.sequencing.StandardSequence
 
getGeneratedValue(Accessor, AbstractSession, String) - Method in class org.eclipse.persistence.sequencing.UUIDSequence
 
getGeneratedVector(Accessor, AbstractSession) - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: Return a Vector of newly-generated sequencing values.
getGeneratedVector(Accessor, AbstractSession, String, int) - Method in class org.eclipse.persistence.sequencing.DefaultSequence
INTERNAL: Return a Vector of newly-generated sequencing values.
getGeneratedVector(Accessor, AbstractSession, String, int) - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: Return a Vector of newly-generated sequencing values.
getGeneratedVector(Accessor, AbstractSession, String, int) - Method in class org.eclipse.persistence.sequencing.StandardSequence
 
getGeneratedVector(Accessor, AbstractSession, String, int) - Method in class org.eclipse.persistence.sequencing.UUIDSequence
 
getGetMethod() - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Return the accessor method for the attribute accessor.
getGetMethodName() - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Return the name of the accessor method for the attribute accessor.
getGetMethodName() - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeMethodInfo
 
getGetMethodName() - Method in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
 
getGetMethodName() - Method in interface org.eclipse.persistence.internal.oxm.mappings.InverseReferenceMapping
This method is invoked reflectively on the reference object to return the value of the attribute in the object.
getGetMethodName() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: This method is invoked reflectively on the reference object to return the value of the attribute in the object.
getGetMethodReturnType() - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
INTERNAL: Return the GetMethod return type for this MethodAttributeAccessor.
getGetMethodReturnType() - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeAccessor
Return the method return type.
getGetSettingsMethod() - Method in class org.eclipse.persistence.internal.oxm.XMLSequencedDescriptor
INTERNAL: Return the actual method to be invoked to obtain an ordered list of TopLinkSetting objects Only used with Sequenced Objects.
getGetSettingsMethodName() - Method in class org.eclipse.persistence.internal.oxm.XMLSequencedDescriptor
INTERNAL: Get the method that will be used to obtain an ordered list of TopLinkSetting objects at runtime.
getGrammar() - Method in class org.eclipse.persistence.internal.jpa.jpql.JPQLQueryHelper
Returns the JPQL grammar that will be used to define how to parse a JPQL query.
getGroup() - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
getGroup() - Method in class org.eclipse.persistence.internal.queries.AttributeItem
 
getGroup(Class<?>) - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
getGroup(String) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Returns AttributeGroup corresponding to the passed (possibly nested) attribute.
getGroup(String) - Method in class org.eclipse.persistence.queries.AttributeGroup
Returns AttributeGroup corresponding to the passed (possibly nested) attribute.
getGroup(String) - Method in class org.eclipse.persistence.queries.FetchGroup
Returns FetchGroup corresponding to the passed (possibly nested) attribute.
getGroup(String) - Method in class org.eclipse.persistence.queries.LoadGroup
Returns LoadGroup corresponding to the passed (possibly nested) attribute.
getGroup(String) - Method in class org.eclipse.persistence.sessions.CopyGroup
Returns CopyGroup corresponding to the passed (possibly nested) attribute.
getGroup(String, String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getGroupByExpressions() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Return the group bys.
getGroupByExpressions() - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Return the group bys.
getGroupFromReferencedSchemas(String, String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getGroupingElements() - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
getGroupingElements() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
INTERNAL: Returns the list of grouping elements currently stored on the MarshalRecord
getGroups() - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
getGroups() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getHandler() - Method in class org.eclipse.persistence.internal.oxm.record.CharacterEscapeHandlerWrapper
 
getHasText() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getHavingExpression() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Return the having expression.
getHavingExpression() - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Return the Having expression.
getHeader(String) - Static method in class org.eclipse.persistence.exceptions.i18n.ExceptionMessageGenerator
Get one of the generic headers used for the exception's toString().
getHighestDescriptorMappingTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pass to this method a table mapped by query's descriptor.
getHintString() - Method in class org.eclipse.persistence.internal.expressions.SQLStatement
INTERNAL: Return the Hint String for the statement
getHintString() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return the current database hint string of the query.
getHistoricalTables() - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
getHistoryPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return this descriptor's HistoryPolicy.
getHistoryPolicy() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Allow history support on the reference table.
getHistoryPolicy() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Allows history tracking on the m-m join table.
getHistoryTableNames() - Method in class org.eclipse.persistence.history.HistoryPolicy
PUBLIC:
getId() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Include
 
getId() - Method in class org.eclipse.persistence.internal.sessions.AggregateObjectChangeSet
 
getId() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
ADVANCED: This method returns the primary key for the object that this change set represents.
getId() - Method in enum org.eclipse.persistence.logging.LogCategory
Get logging category ID.
getId() - Method in enum org.eclipse.persistence.logging.LogLevel
Get logging level ID.
getId() - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Return the Id for the result or null if not requested.
getId() - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCED: This method returns the primary key for the object that this change set represents.
getId() - Method in class org.eclipse.persistence.sessions.coordination.ServiceId
INTERNAL: Get the unique identifier for the service
getId(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Extract and return the primary key from the object.
getId(Object) - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Extract and return the Id from the object.
getID() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteCursoredStream
INTERNAL: Retrieve the OID of the wrapped cursored stream.
getID() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
INTERNAL: Retreive the OID of the wrapped cursored stream.
getID() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Return the unique id.
getIdEntityFetchGroup() - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Returns EntityFetchGroup corresponding to primary key attribute(s).
getIdentityFieldsForMapKey() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the fields that make up the identity of the key if this mapping is a list This method will be overridden by subclasses.
getIdentityFieldsForMapKey() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Return the fields that make up the identity of the mapped object.
getIdentityFieldsForMapKey() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return the fields that make up the identity of the mapped object.
getIdentityFieldsForMapKey() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Return the fields that make up the identity of the mapped object.
getIdentityFieldsForMapKey() - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Return the fields that make up the identity of the mapped object.
getIdentityFieldsForMapKey() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return the fields that make up the identity of the mapped object.
getIdentityMap(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: (public to allow test cases to check) Return the identity map for the class, if missing create a new one.
getIdentityMap(ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
INTERNAL: Return the identity map for the class, if missing create a new one.
getIdentityMap(ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Get the identity map for the given class from the IdentityMapManager
getIdentityMap(ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
INTERNAL: Return the identity map for the class.
getIdentityMap(ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Get the identity map for the given class from the IdentityMapManager
getIdentityMap(ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Get the identity map for the given class from the IdentityMapManager
getIdentityMapAccessor() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: The IdentityMapAccessor is the preferred way of accessing IdentityMap funcitons This will return an object which implements an interface which exposes all public IdentityMap functions.
getIdentityMapAccessor() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: The IdentityMapAccessor is the preferred way of accessing IdentityMap functions This will return an object which implements an interface which exposes all public IdentityMap functions.
getIdentityMapAccessorInstance() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the internally available IdentityMapAccessor instance.
getIdentityMapClass() - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Return the class of identity map to be used by this descriptor.
getIdentityMapClass() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return the class of identity map to be used by this descriptor.
getIdentityMapClasses() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Return an iterator of the classes in the identity map.
getIdentityMapManager() - Method in class org.eclipse.persistence.internal.sessions.ClientSessionIdentityMapAccessor
INTERNAL: Return the IdentityMapManager for the client session.
getIdentityMapManager() - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Get the IdentityMapManager for this IdentityMapAccessor This method should be used for all IdentityMapManager access since it may be overridden in sub classes.
getIdentityMapManager() - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Get the IdentityMapManager for this IdentityMapAccessor This method should be used for all IdentityMapManager access since it may be overridden in sub classes.
getIdentityMaps() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
 
getIdentityMapSize() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Return the size of the identity map.
getIdentityMapSize() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the size of the identity map.
getIDResolver() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Return this Unmarshaller's custom IDResolver.
getIDResolver() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Return this Unmarshaller's custom IDResolver.
getIDResolver() - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
Return this Unmarshaller's custom IDResolver.
getIdValidation() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Return what types are allowed as a primary key (id).
getImplementorDescriptor() - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Returns the implementor descriptor class.
getImplementorDescriptorClassName() - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Returns the implementor descriptor class name.
getImplementorForType(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Return the implementor for a specified type
getImports() - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
getImports() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getINClauseLimit() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Some database platforms have a limit for the number of parameters in an IN clause.
getINClauseLimit() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
 
getIncludes() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getIndentationString() - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL: Used to print things nicely in the testing tool.
getIndentString() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
Return the String that will be used to perform indenting in marshalled documents.
getIndex() - Method in class org.eclipse.persistence.descriptors.changetracking.CollectionChangeEvent
INTERNAL: Return the index of the change in the collection
getIndex() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Return the expected index that this field will occur in the result set row.
getIndex() - Method in class org.eclipse.persistence.internal.helper.IndexedObject
 
getIndex() - Method in interface org.eclipse.persistence.internal.oxm.ContainerValue
INTERNAL: Used to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord
getIndex() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
INTERNAL: Set to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord Set during TreeObjectBuilder initialization
getIndex() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
INTERNAL: Set to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord Set during TreeObjectBuilder initialization
getIndex() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
INTERNAL: Set to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord Set during TreeObjectBuilder initialization
getIndex() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
INTERNAL: Set to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord Set during TreeObjectBuilder initialization
getIndex() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
INTERNAL: Set to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord Set during TreeObjectBuilder initialization
getIndex() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
INTERNAL: Set to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord Set during TreeObjectBuilder initialization
getIndex() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
INTERNAL: Set to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord Set during TreeObjectBuilder initialization
getIndex() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
INTERNAL: Set to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord Set during TreeObjectBuilder initialization
getIndex() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
INTERNAL: Set to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord Set during TreeObjectBuilder initialization
getIndex() - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
INTERNAL: Set to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord Set during TreeObjectBuilder initialization
getIndex() - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
getIndex() - Method in class org.eclipse.persistence.internal.sessions.OrderedChangeObject
INTERNAL: Return the index the change was made to the collection.
getIndex(String) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
getIndex(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
getIndex(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
getIndex(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
getIndexes() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Return a list of index definitions.
getIndexes() - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC:
getIndexNamePrefix(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used to allow platforms to define their own index prefixes
getIndexNamePrefix(boolean) - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Used to allow platforms to define their own index prefixes
getIndexValue() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getIndicatingNoEntry(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Retrieve the value for the field name.
getIndicatingNoEntry(String) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL: Retrieve the value for the field name.
getIndicatingNoEntry(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: Retrieve the value for the field.
getIndicatingNoEntry(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
INTERNAL: Retrieve the value for the field.
getIndicatingNoEntry(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.ResultSetRecord
INTERNAL: Retrieve the value for the field.
getIndicatingNoEntry(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
INTERNAL: Retrieve the value for the field.
getIndicatingNoEntry(DatabaseField) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Given a DatabaseField return the corresponding value from the document
getIndicatingNoEntry(DatabaseField, boolean) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
getIndicatingNoEntry(DatabaseField, boolean, boolean) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
getIndirectionPolicy() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return the mapping's indirection policy.
getIndirectionPolicy() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Return the mapping's indirection policy.
getInfo() - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL:
getInfoExt() - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL:
getInheritanceExpression() - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
getInheritancePolicy() - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
PUBLIC: The inheritance policy is used to define how a descriptor takes part in inheritance.
getInheritancePolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: The inheritance policy is used to define how a descriptor takes part in inheritance.
getInheritancePolicy() - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: The inheritance policy is used to define how a descriptor takes part in inheritance.
getInheritancePolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
The inheritance policy is used to define how a descriptor takes part in inheritance.
getInheritancePolicy() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: The inheritance policy is used to define how a descriptor takes part in inheritance.
getInheritancePolicyOrNull() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return the inheritance policy.
getInheritancePolicyOrNull() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: Return the inheritance policy.
getInitialContextFactoryName() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
 
getInitialContextFactoryName() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
PUBLIC: Return the context factory name used as the value to the INITIAL_CONTEXT_FACTORY key in the cached context properties.
getInitializatonPolicy() - Method in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
 
getInitializedDocument() - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
getInitiallyConformingIndex() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Conforming instances found in memory when building the result.
getInitialNumberOfConnections() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Return the initial number of connections allowed.
getInitialReadSize() - Method in class org.eclipse.persistence.queries.CursoredStream
INTERNAL: Return the threshold for the stream.
getInitialReadSize() - Method in class org.eclipse.persistence.queries.CursoredStreamPolicy
Specifies the number of elements to be read initially into a cursored stream.
getInitialValue() - Method in class org.eclipse.persistence.internal.codegen.AttributeDefinition
 
getInitialValue() - Method in class org.eclipse.persistence.sequencing.DefaultSequence
 
getInitialValue() - Method in class org.eclipse.persistence.sequencing.Sequence
 
getInitialWriteLockValue() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: This method is used to return the initial lock value of the object this changeSet represents.
getInitialWriteValue(AbstractSession) - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: returns the initial locking value
getInitialWriteValue(AbstractSession) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: returns the initial locking value
getInjectionManager() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
 
getInlineMapping() - Method in interface org.eclipse.persistence.internal.oxm.mappings.InverseReferenceMapping
 
getInlineMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
getInMemoryQueryIndirectionPolicy() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Returns the InMemoryQueryIndirectionPolicy for this query
getInMemoryQueryIndirectionPolicyState() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Returns the InMemoryQueryIndirectionPolicy for this query
getInnerClasses() - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
getInOutputProcedureToken() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This method is used to print the output parameter token when stored procedures are called
getInOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
This method is used to print the output parameter token when stored procedures are called
getInOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL uses the INOUT keyword for this.
getInOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Pervasive uses the INOUT keyword, as opposed to "IN OUT".
getInOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
This method is used to print the output parameter token when stored procedures are called
getInOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
getInOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
This method is used to print the output parameter token when stored procedures are called
getInOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
getInOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
This method is used to print the output parameter token when stored procedures are called.
getInputProcedureToken() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for stored procedure creation: Prefix for INPUT parameters.
getInputProcedureToken() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
Used for stored procedure creation: Prefix for INPUT parameters.
getInputProcedureToken() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Pervasive uses IN prefix for INPUT parameters.
getInputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
Used for stored procedure creation: Prefix for INPUT parameters.
getInputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Used for stored procedure creation: Prefix for INPUT parameters.
getInputRecordName() - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: Return the input record name.
getInputResultPath() - Method in class org.eclipse.persistence.eis.interactions.MappedInteraction
PUBLIC: The input result path defines the root key for the MappedRecord that the interaction argument is nested into.
getInputRootElementName() - Method in class org.eclipse.persistence.eis.interactions.XMLInteraction
PUBLIC: Return the root element name to use for the input DOM.
getInputRow() - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
INTERNAL: Return the input database row.
getInputStream() - Method in class org.eclipse.persistence.internal.oxm.ByteArrayDataSource
 
getInputStream() - Method in class org.eclipse.persistence.internal.oxm.ByteArraySource
 
getInsertCall() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's insert call.
getInsertObjectQuery(AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Returns a clone of InsertObjectQuery from the ClassDescriptor's DescriptorQueryManager or a new one
getInsertObjectQuery(AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Returns a clone of InsertObjectQuery from the ClassDescriptor's DescriptorQueryManager or a new one
getInsertQuery() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's insert query.
getInsertQuery() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
getInsertQuery() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
 
getInsertQuery() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
 
getInsertSQLString() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's insert SQL string.
getInstance() - Static method in class org.eclipse.persistence.internal.databaseaccess.JsonPlatformManager
Get DatabaseJsonPlatform implementations manager instance.
getInstance() - Static method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Gets instance of this class
getInstance() - Static method in class org.eclipse.persistence.internal.oxm.record.ObjectMarshalContext
 
getInstance() - Static method in class org.eclipse.persistence.internal.oxm.record.ObjectUnmarshalContext
 
getInstance() - Static method in class org.eclipse.persistence.internal.oxm.UnmarshalXPathEngine
Return the XPathEngine singleton.
getInstance() - Static method in class org.eclipse.persistence.internal.oxm.XPathEngine
Return the XPathEngine singleton.
getInstance() - Static method in class org.eclipse.persistence.internal.sessions.factories.DirectToXMLTypeMappingHelper
 
getInstance() - Static method in class org.eclipse.persistence.platform.xml.DefaultErrorHandler
 
getInstance() - Static method in class org.eclipse.persistence.platform.xml.XMLPlatformFactory
INTERNAL: Return the singleton instance of XMLPlatformContext.
getInstanceFromClass(Class<?>) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return the class instance from the class
getInstantiationPolicy() - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
INTERNAL: Returns the instantiation policy.
getInstantiationPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Returns the instantiation policy.
getInstantiationPolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: Returns the instantiation policy.
getIntegerClassType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the Inter class representation.
getIntegrityChecker() - Method in exception org.eclipse.persistence.exceptions.IntegrityException
PUBLIC: Return Integrity Checker.
getIntegrityChecker() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Returns the integrityChecker.IntegrityChecker holds all the ClassDescriptor Exceptions.
getIntegrityChecker() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Returns the integrityChecker,the integrityChecker holds all the ClassDescriptor Exceptions.
getInteractionSpec() - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: Return the JCA InteractionSpec that defines this EIS interaction.
getInterfacePolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Returns the InterfacePolicy.
getInterfacePolicyOrNull() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Returns the InterfacePolicy.
getInterfaces() - Method in class org.eclipse.persistence.dynamic.DynamicClassWriter
Interfaces the dynamic entity class implements.
getInterfaces() - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
getInterfaceType() - Method in class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
 
getInterfaceType() - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
 
getInterfaceType() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL:
getInternalException() - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
PUBLIC: Return the internal native exception.
getInternalExceptions() - Method in exception org.eclipse.persistence.exceptions.JPQLException
INTERNAL Return the collection of internal Exceptions.
getInternalMax() - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: returns the JPA max results that may have been set on a NamedQuery
getInternalMWConfigObjects(String, ClassLoader) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
INTERNAL: This method is to be used to load config objects for the Mapping Workbench only.
getInternalMWConfigObjects(String, ClassLoader, boolean) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
INTERNAL: This method is to be used to load config objects for the Mapping Workbench only.
getInternalOperator(Integer) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Lookup the internal operator with the given id.
getIntStatus(Object) - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Convenience method to return the int value of the transaction status.
getIntType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the int type representation.
getInvalidateOnChange() - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Return if any change to any object of the query class should cause the query results to be invalidated.
getInvalidationClasses() - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
ADVANCED: Return the set of classes that should trigger the query cached results to be invalidated.
getInvalidationState() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
INTERNAL: Return the value of the invalidationState Variable The return value will be a constant CHECK_INVALIDATION_POLICY - The Invalidation policy is must be checked for this cache key's sate CACHE_KEY_INVALID - This cache key has been labeled invalid.
getInvalidationState() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
getInverseReferenceMapping() - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
 
getInverseReferenceMapping() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ObjectReferenceMapping
 
getInverseReferenceMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
getInverseReferenceMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
getInverseReferenceMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
 
getIsConcurrent() - Method in class org.eclipse.persistence.queries.LoadGroup
INTERNAL: Return if the load group should load its relationships concurrently.
getIsSetMethodName() - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
 
getIsSetParameters() - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
 
getIsSetParameterTypes() - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
 
getIsSetPerformedForAbsentNode() - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
 
getItem() - Method in class org.eclipse.persistence.internal.expressions.FromAliasExpression
INTERNAL: Return the report item that this is an alias for.
getItem(String) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL: Lookup the AttributeItem for the provided attribute name or path.
getItem(String) - Method in class org.eclipse.persistence.queries.AttributeGroup
INTERNAL: Lookup the AttributeItemfor the provided attribute name or path.
getItem(String) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL:
getItem(String[], boolean) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Locate the AttributeGroup where the leaf attribute in the path should be applied to.
getItems() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL:
getItems() - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL:
getItemType() - Method in class org.eclipse.persistence.internal.oxm.schema.model.List
 
getJavaClass() - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
PUBLIC: Return the java class.
getJavaClass() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the java class.
getJavaClass() - Method in interface org.eclipse.persistence.dynamic.DynamicType
 
getJavaClass() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getJavaClass() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Return the java class.
getJavaClass(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the class object of the specified type.
getJavaClass(QName) - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL Return the class for a given qualified XML Schema type
getJavaClass(QName) - Method in class org.eclipse.persistence.oxm.XMLUnionField
Return the class for a given qualified XML Schema type.
getJavaClass(QName, ConversionManager) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Return the class for a given qualified XML Schema type
getJavaClass(QName, ConversionManager) - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL
getJavaClass(QName, ConversionManager) - Method in class org.eclipse.persistence.oxm.XMLUnionField
INTERNAL
getJavaClassName() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return the class name, used by the MW.
getJavaClassName() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Return the class name, used by the MW.
getJavaLevel(int) - Method in class org.eclipse.persistence.logging.JavaLog
INTERNAL: Return the corresponding java.util.logging.Level for a given TopLink level.
getJavaStrings() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL:
getJavaType() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
Return the Java class that the complex type maps to.
getJavaType() - Method in class org.eclipse.persistence.internal.oxm.XMLConversionPair
 
getJavaType() - Method in interface org.eclipse.persistence.platform.database.converters.StructConverter
PUBLIC:
getJavaTypeName() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
getJdbcBatchWriting() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getJdbcConnectionDetails() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Return JDBCConnection detail information.
getJdbcConnectionDetails() - Method in class org.eclipse.persistence.services.RuntimeServices
Return JDBCConnection detail information.
getJDBCOuterJoinString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Returns the JDBC outer join operator for SELECT statements.
getJdbcType() - Method in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
getJDBCType(Class<?>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return the JDBC type for the Java type.
getJDBCType(Class<?>) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
 
getJDBCType(Class<?>) - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
Return the JDBC type for the Java type.
getJDBCType(Class<?>) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Sybase and SQL Anywhere do not support BLOB/CLOB but require LONGVARBINARY/LONGVARCHAR.
getJDBCType(DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return the JDBC type for the given database field.
getJDBCTypeForSetNull(DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return the JDBC type for the given database field to be passed to Statement.setNull
getJdbcTypeName(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Returns the type name corresponding to the jdbc type
getJdbcTypeName(int) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Returns the type name corresponding to the jdbc type
getJNDIConnectorLookupType() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: Get JNDIConnector lookupType value for this platform.
getJNDIConnectorLookupType() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
 
getJNDIConnectorLookupType() - Method in class org.eclipse.persistence.platform.server.was.WebSpherePlatform
 
getJNDINamingServiceConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.JMSPublishingTransportManagerConfig
 
getJNDINamingServiceConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.RMITransportManagerConfig
 
getJoinCriteria() - Method in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
PUBLIC: Return the join expression for the relationship defined by the query key.
getJoinCriteria(ObjectExpression, Expression) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Returns the join criteria stored in the mapping selection query.
getJoinCriteria(ObjectExpression, Expression) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Returns the join criteria stored in the mapping selection query.
getJoinCriteria(ObjectExpression, Expression) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Returns the join criteria stored in the mapping selection query.
getJoinCriteria(ObjectExpression, Expression) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Returns the join criteria stored in the mapping selection query.
getJoinCriteria(ObjectExpression, Expression) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: Join criteria is created to read target records (nested table) from the table.
getJoinCriteria(ObjectExpression, Expression) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Join criteria is created to read target records (nested table) from the table.
getJoinedAggregateMappings() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return the attributes that must be joined.
getJoinedAttributeExpressions() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return the attributes that must be joined.
getJoinedAttributeExpressions() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Convenience method for project mapping.
getJoinedAttributeManager() - Method in class org.eclipse.persistence.internal.queries.ReportItem
INTERNAL: Set the list of expressions that represent elements that are joined because of their mapping for this query.
getJoinedAttributeManager() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return join manager responsible for managing all aspects of joining for the query.
getJoinedAttributeManagerInternal() - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
getJoinedAttributeMappings() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return the attributes that must be joined.
getJoinedAttributes() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Answers the attributes which are always joined to the original query on reads.
getJoinedAttributes() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return the attributes that must be joined.
getJoinedMappingExpressions() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Get the list of expressions that represent elements that are joined because of their mapping for this query.
getJoinedMappingIndexes_() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return the joined mapping indexes, used to compute mapping row partitions.
getJoinedMappingQueries_() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return the joined mapping queries, used optimize joining, only compute the nested queries once.
getJoinedMappingQueryClones() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
 
getJoinFetch() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Return if this relationship should always be join fetched.
getJoinSource() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
getJPAQueries() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Return all pre-defined not yet parsed JPQL queries.
getJPAQueries() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return all pre-defined not yet parsed JPQL queries.
getJPAQueries() - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Return all pre-defined not yet parsed EJBQL queries.
getJPATablePerTenantQueries() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Return all pre-defined not yet parsed JPQL queries.
getJPATablePerTenantQueries() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return all pre-defined not yet parsed JPQL queries to table per tenant entities.
getJPQLCall() - Method in class org.eclipse.persistence.internal.queries.JPQLCallQueryMechanism
 
getJPQLParseCache() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return the JPQL parse cache.
getJPQLParseCacheMaxSize() - Method in class org.eclipse.persistence.sessions.Project
ADVANCED: Return the JPQL parse cache max size.
getJPQLString() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return the JPQL string of the query.
getJPQLString() - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: Return the EJBQL string for this call
getJsonArrayBuilder() - Method in class org.eclipse.persistence.oxm.json.JsonArrayBuilderResult
 
getJsonArrayBuilder() - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord.Level
 
getJsonDataFromResultSet(ResultSet, int, Class<T>) - Method in interface org.eclipse.persistence.internal.databaseaccess.DatabaseJsonPlatform
Retrieve JSON data from JDBC ResultSet.
getJsonObjectBuilder() - Method in class org.eclipse.persistence.oxm.json.JsonObjectBuilderResult
 
getJsonObjectBuilder() - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord.Level
 
getJsonPlatform() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Get JSON support extension instance.
getJsonStructure() - Method in class org.eclipse.persistence.oxm.json.JsonStructureSource
 
getJsonTypeAttributeName() - Method in class org.eclipse.persistence.internal.oxm.JsonTypeConfiguration
Getter for type property name for JSON as MOXy type discriminator.
getJsonTypeConfiguration() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
Returns json type configuration.
getJsonTypeConfiguration() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Returns json type configuration.
getJsonTypeConfiguration() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Returns json type configuration.
getJsonTypeConfiguration() - Method in class org.eclipse.persistence.oxm.XMLMarshaller
Returns json type configuration.
getKeepAsElementPolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyCollectionMapping
 
getKeepAsElementPolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyObjectMapping
 
getKeepAsElementPolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
 
getKeepAsElementPolicy() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
getKeepAsElementPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLAbstractAnyMapping
 
getKeepAsElementPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
getKeepAsElementPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
getKey() - Method in class org.eclipse.persistence.descriptors.changetracking.MapChangeEvent
INTERNAL: Return the change type
getKey() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
getKey() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordEntry
 
getKey() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.ObjectTypeFieldAssociation
 
getKey() - Method in class org.eclipse.persistence.internal.sessions.remote.ObjectDescriptor
Return primary key values of an associated object
getKey() - Method in class org.eclipse.persistence.mappings.Association
PUBLIC: Return the key.
getKey() - Method in class org.eclipse.persistence.queries.ReportQueryResult.RecordEntry
 
getKey() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
getKeyClass() - Method in class org.eclipse.persistence.mappings.DirectMapMapping
PUBLIC: This is a helper method to get the object class from the key converter if it is a TypeConversionConverter.
getKeyClassFields() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL:
getKeyConverter() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Get the Converter for the key of this mapping if one exists.
getKeyConverter() - Method in class org.eclipse.persistence.mappings.DirectMapMapping
PUBLIC: Return the converter on the mapping.
getKeyGroup() - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
getKeyGroup(Class<?>) - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
getKeyGroups() - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
getKeyMapping() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
 
getKeyMappingDataForWriteQuery(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Add any non-Foreign-key data from an Object describe by a MapKeyMapping to a database row This is typically used in write queries to ensure all the data stored in the collection table is included in the query.
getKeyMappingDataForWriteQuery(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Add any non-Foreign-key data from an Object describe by a MapKeyMapping to a database row This is typically used in write queries to ensure all the data stored in the collection table is included in the query.
getKeyName() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Returns the key name which will return the value of the key to be used in the container.
getKeyName() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
getKeyName(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
getKeyQuery() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Some map keys must be obtained from the database.
getKeySelectionCriteria() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Get the selection criteria for the map key This will be overridden by container policies that allow maps
getKeySelectionCriteria() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Get the selection criteria for the map key.
getKeyType() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the type of the map key, this will be overridden by container policies that allow maps.
getKeyType() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return the type of the map key, this will be overridden by container policies that allow maps.
getKeyType() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Return the type of the map key, this will be overridden by container policies that allow maps.
getKeyType() - Method in class org.eclipse.persistence.mappings.TypedAssociation
PUBLIC: Return the class of the key.
getKnownCursorSize() - Method in class org.eclipse.persistence.queries.ScrollableCursor
 
getLast() - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
Returns the last contents in this list.
getLastCallAppended() - Method in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
 
getLastFieldIndex() - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
getLastUpdatedQueryId() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
INTERNAL: This method returns the system time in millis seconds at which this object was last refreshed CR #4365 CR #2698903 ...
getLastUpdatedQueryId() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
getLastXPathFragment() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
INTERNAL: Return the last XPathFragment.
getLastXPathFragment() - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL: Return the last XPathFragment.
getLatestCollection() - Method in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
Used for change tracking when user sets entire collection.
getLazy() - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPolicyConfig
 
getLeafDescriptor(DatabaseQuery, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Lookup the descriptor for this item by traversing its expression recursively.
getLeafDescriptor(DatabaseQuery, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Lookup the descriptor for this item by traversing its expression recursively.
getLeafDescriptor(DatabaseQuery, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Lookup the descriptor for this item by traversing its expression recursively.
getLeafDescriptor(DatabaseQuery, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
getLeafElementType() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
 
getLeafElementType() - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
getLeafElementType() - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
getLeafElementType() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getLeafElementType() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getLeafElementType() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getLeafElementType() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL:
getLeafElementType() - Method in class org.eclipse.persistence.oxm.XMLField
 
getLeafMapping(DatabaseQuery, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Lookup the mapping for this item by traversing its expression recursively.
getLeafMapping(DatabaseQuery, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Lookup the mapping for this item by traversing its expression recursively.
getLeafMapping(DatabaseQuery, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Lookup the mapping for this item by traversing its expression recursively.
getLeafMapping(DatabaseQuery, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
getLeafQueryKeyFor(DatabaseQuery, Expression, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Lookup the query key for this item.
getLength() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Used to specify the column length when generating DDL.
getLength() - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
getLength() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
getLength() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getLength() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getLength() - Method in class org.eclipse.persistence.platform.xml.XMLNodeList
 
getLevel() - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
getLevel() - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
getLevel() - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Return the log level.
getLevel() - Method in class org.eclipse.persistence.logging.SessionLogEntry
Return the request level of the log entry.
getLevel(String) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
getLevel(String) - Method in class org.eclipse.persistence.logging.DefaultSessionLog
 
getLevel(String) - Method in class org.eclipse.persistence.logging.JavaLog
PUBLIC:
getLevel(String) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Return the log level; category is only needed where name space is available.
getLevelIndex() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getLevelIndex() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getLevelIndex() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getLevelString() - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
getLevelString() - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC:
getLexicalHandler() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
getLexicalHandler() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
getLifecycle() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The life cycle tracks if the unit of work is active and is used for JTS.
getLineNumber() - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.LocatorImpl
 
getLines() - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
getLineSeparator() - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
INTERNAL: Get the line separator character.
getList() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
getListClass() - Method in interface org.eclipse.persistence.indirection.IndirectCollectionsFactory.IndirectCollectionsProvider
Class implementing IndirectList.
getListenerFactory() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Get the factory used to generate synchronization listeners.
getListeners() - Method in class org.eclipse.persistence.sessions.SessionEventManager
PUBLIC: The event listeners will receive all events raised by this session.
getListOrderField() - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
 
getListOrderField() - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Field holds the order of elements in the list in the db, requires collection of type List; may be not null only in case isListOrderFieldSupported==true.
getLiteralLabels() - Method in class org.eclipse.persistence.dynamic.DynamicClassLoader.EnumInfo
 
getLoader() - Static method in class org.eclipse.persistence.exceptions.i18n.ExceptionMessageGenerator
Return the loader for loading the resource bundles.
getLoader() - Method in class org.eclipse.persistence.internal.core.helper.CoreConversionManager
INTERNAL
getLoader() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL:
getLoader() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the class loader for the session's application.
getLoadGroup() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
Return the load group set in the query.
getLoadGroup() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Return the load group set in the query.
getLobValueLimits() - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
PUBLIC: Return the BLOB/CLOB value limits on thin driver.
getLOBWriter() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return the LOBValueWriter instance.
getLocalBase() - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
 
getLocalBase() - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
 
getLocalBase() - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
The opposite side of the relation, this is used for conversion of the parameter using the others mapping.
getLocalContextProperties() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
ADVANCED: Return the properties that will be used to create the initial context for local JNDI access.
getLocalHostContext() - Method in class org.eclipse.persistence.sessions.coordination.rmi.RMITransportManager
INTERNAL: Return the context used for looking up in local JNDI.
getLocalName() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getLocalName() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getLocalName() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.Attribute
 
getLocalName() - Method in class org.eclipse.persistence.internal.oxm.Root
Gets the local name.
getLocalName() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getLocalName() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
PUBLIC: Get the local name of the context root element.
getLocalName() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
getLocalName() - Method in class org.eclipse.persistence.oxm.record.NodeRecord
 
getLocalName() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getLocalName() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
getLocalName() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
PUBLIC: Get the local name of the context root element.
getLocalName(int) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
getLocalName(int) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
getLocalNameBytes() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getLocalQuery(String, Vector) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTENAL: Return the query from the set of pre-defined queries with the given name and argument types.
getLocalQueryByArgumentTypes(String, List) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Return the query from the set of pre-defined queries with the given name and argument types.
getLocalResources() - Method in class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
INTERNAL:
getLocalTime() - Method in class org.eclipse.persistence.tools.profiler.Profile
 
getLocationAccessor() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: Returns this Descriptor's location accessor, if one is defined.
getLocationAccessor() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Returns this Descriptor's location accessor, if one is defined.
getLocator() - Method in class org.eclipse.persistence.internal.oxm.record.XMLEventReaderReader
 
getLocator() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
INTERNAL: return the Locator object associated with this reader
getLocator() - Method in class org.eclipse.persistence.internal.oxm.record.XMLStreamReaderReader
 
getLockableMappings() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Returns a reference to the mappings that must be traverse when locking
getLockAttribute() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
getLockedExpressions() - Method in class org.eclipse.persistence.internal.expressions.ForUpdateOfClause
 
getLockFields() - Method in class org.eclipse.persistence.descriptors.SelectedFieldsLockingPolicy
INTERNAL: Returns the lock fields
getLockFields(DatabaseTable) - Method in class org.eclipse.persistence.descriptors.SelectedFieldsLockingPolicy
INTERNAL: returns the lock fields based on the passed in table
getLockFieldsByTable() - Method in class org.eclipse.persistence.descriptors.SelectedFieldsLockingPolicy
INTERNAL: returns the lock fields
getLockingClause() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: It is not exactly as simple as a query being either locking or not.
getLockingMode() - Method in class org.eclipse.persistence.descriptors.PessimisticLockingPolicy
PUBLIC: Return locking mode.
getLockMode() - Method in class org.eclipse.persistence.internal.expressions.ForUpdateClause
 
getLockMode() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
PUBLIC: Return the current locking mode.
getLockModeType() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: returns the jakarta.persistence.LockModeType string value set on this query.
getLockOnChangeMode() - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
ADVANCED: returns the LockOnChange mode for this policy.
getLockOnChangeMode() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
ADVANCED: returns the LockOnChange mode for this policy.
getLockOnChangeMode() - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
ADVANCED: returns the LockOnChange mode for this policy.
getLockThread() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTERNAL:
getLog() - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Returns the attunity adapter message log.
getLog() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the writer to which an accessor writes logged messages and SQL.
getLog() - Static method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
getLog() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the writer to which an accessor writes logged messages and SQL.
getLogConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
getLogFilename() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Return the log filename.
getLogFilename() - Method in class org.eclipse.persistence.services.RuntimeServices
Return the log filename.
getLogger(String) - Method in class org.eclipse.persistence.logging.JavaLog
INTERNAL: Return the Logger for the given category
getLoggingOptions() - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.LogConfig
 
getLogin() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return the login
getLogin() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
OBSOLETE: Return the login, the login holds any database connection information given.
getLogin() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Return the login informaiton from the server.
getLogin() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Get the associated session login.
getLogin() - Method in interface org.eclipse.persistence.sequencing.SequencingControl
ADVANCED: Return a DatabaseLogin to be used by separate sequencing connection(s).
getLogin() - Method in class org.eclipse.persistence.sessions.Project
OBSOLETE: Return the login, the login holds any database connection information given.
getLogin() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Return the table descriptor specified for the class.
getLogin() - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
To get login from the server side
getLogin() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Get the associated session login.
getLogin() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Return the login to use for this connection.
getLogin() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Return the login used to create connections.
getLogin() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the login, the login holds any database connection information given.
getLoginConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPoolConfig
 
getLoginConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.DatabaseSessionConfig
 
getLogLevel() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
getLogLevel() - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.DefaultSessionLogConfig
 
getLogLevel() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the log level.
getLogLevel(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
getLogLevel(String) - Method in class org.eclipse.persistence.services.RuntimeServices
Return the log level
getLogLevel(String) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the log level.
getLogLevelProperty() - Method in enum org.eclipse.persistence.logging.LogCategory
Get log level property name for this logging category.
getLogSessionString() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the name of the session: class name + system hashcode.
getLogString(Accessor) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
Return the string for logging purposes.
getLogString(Accessor) - Method in class org.eclipse.persistence.eis.interactions.QueryStringInteraction
Return the string for logging purposes.
getLogString(Accessor) - Method in class org.eclipse.persistence.eis.interactions.XMLInteraction
Return the string for logging purposes.
getLogString(Accessor) - Method in class org.eclipse.persistence.eis.interactions.XQueryInteraction
Return the string for logging purposes.
getLogString(Accessor) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Return the SQL string for logging purposes.
getLogString(Accessor) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Return the SQL string for logging purposes.
getLogString(Accessor) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
INTERNAL: Build the log string for the call.
getLogString(Accessor) - Method in interface org.eclipse.persistence.queries.Call
INTERNAL: Return a string appropriate for the session log.
getLogString(Accessor) - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: Return the SQL string for this call.
getLogString(Accessor) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
Return the SQL string for logging purposes.
getLogType() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Return the log type, either "EclipseLink", "Java" or the simple name of the logging class used.
getLogType() - Method in class org.eclipse.persistence.services.RuntimeServices
Return the log type, either "EclipseLink", "Java" or the simple name of the logging class used.
getLongClassType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the type representation of class Long.
getLongestTime() - Method in class org.eclipse.persistence.tools.profiler.Profile
 
getLongType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the long type representation.
getLookupField(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
Internal: factored out of getIndicatingNoEntry(String) to reduce complexity and have get(string) use get(DatabaseField) instead of getIndicatingNoEntry and then doing an extra check
getLookupType() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getLookupType() - Method in class org.eclipse.persistence.sessions.JNDIConnector
Deprecated.
As of 2.6.0, replaced by configuration provided by ServerPlatform.getJNDIConnectorLookupType()
getMajor() - Method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Get major version number.
getMajor() - Method in class org.eclipse.persistence.internal.helper.JavaSEPlatform.Version
Get major version number.
getMajor() - Method in class org.eclipse.persistence.internal.helper.JavaVersion
Get major version number.
getManager() - Static method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return the session manager for current context.
getManualQueryKey(String, ClassDescriptor) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
getMapClass() - Method in interface org.eclipse.persistence.indirection.IndirectCollectionsFactory.IndirectCollectionsProvider
Class implementing IndirectMap.
getMapEntryType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the type representation of class Map.Entry.
getMapKeyDescriptor() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Return if descriptor for the map key mapping where the key is a OneToOne.
getMapKeyTargetType() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return the class this key mapping maps or the descriptor for it
getMapKeyTargetType() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Return the class this key mapping maps or the descriptor for it
getMapKeyTargetType() - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Return the class this key mapping maps or the descriptor for it
getMapKeyTargetType() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return the class this key mapping maps or the descriptor for it
getMapOfCacheKeyToDtosExplainingThreadExpectationsOnCacheKey() - Method in class org.eclipse.persistence.internal.helper.type.ConcurrencyManagerState
getMappedBy() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
ADVANCED: Allows the retrieval of the owning mapping for a particular mapping.
getMappedBy() - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
getMappedClass() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
PUBLIC: Answer the mapped class.
getMappedClassNamesUsingFilter(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
INTERNAL: This method traverses the EclipseLink descriptors and returns a Vector of the descriptor's reference class names that match the provided filter.
getMappedClassNamesUsingFilter(String) - Method in class org.eclipse.persistence.services.RuntimeServices
INTERNAL: This method traverses the EclipseLink descriptors and returns a Vector of the descriptor's reference class names that match the provided filter.
getMappedSuperclass(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the mapped superclass descriptor if one exists for the given class name.
getMappedSuperclass(String) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Use the Metadata key parameter to lookup the Descriptor from the Map of mappedSuperclass descriptors
getMappedSuperclassDescriptors() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return the Map of RelationalDescriptor objects representing mapped superclass parents keyed by className of the metadata class.
getMappedTranslationRow(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
INTERNAL:
getMapping() - Method in interface org.eclipse.persistence.descriptors.CMPPolicy.KeyElementAccessor
 
getMapping() - Method in class org.eclipse.persistence.descriptors.CMPPolicy.KeyIsElementAccessor
 
getMapping() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMappingHelper
INTERNAL: Return the mapping.
getMapping() - Method in exception org.eclipse.persistence.exceptions.DescriptorException
PUBLIC: Return the mapping that the problem was detected in.
getMapping() - Method in class org.eclipse.persistence.history.HistoryPolicy
PUBLIC:
getMapping() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
getMapping() - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
 
getMapping() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
getMapping() - Method in class org.eclipse.persistence.internal.indirection.BatchValueHolder
 
getMapping() - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return the database mapping that uses the indirection policy.
getMapping() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
getMapping() - Method in interface org.eclipse.persistence.internal.oxm.ContainerValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.MappingNodeValue
Return the mapping associated with this node value.
getMapping() - Method in class org.eclipse.persistence.internal.oxm.Reference
Return the XMLMapping associated with this reference.
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyObjectMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceObjectMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLDirectMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLObjectReferenceMappingNodeValue
 
getMapping() - Method in interface org.eclipse.persistence.internal.oxm.XMLSetting
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathObjectMappingNodeValue
 
getMapping() - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
getMapping() - Method in class org.eclipse.persistence.internal.sessions.ChangeRecord
ADVANCED: Returns the mapping for the attribute this ChangeRecord Represents
getMapping() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Return the associated mapping.
getMapping() - Method in class org.eclipse.persistence.mappings.converters.ClassInstanceConverter
INTERNAL: Return the mapping.
getMapping() - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Return the mapping.
getMapping() - Method in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
INTERNAL: Return the mapping.
getMapping() - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
INTERNAL: Return the mapping.
getMapping() - Method in class org.eclipse.persistence.mappings.structures.ArrayCollectionMappingHelper
INTERNAL: Return the mapping.
getMapping() - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
getMapping(String) - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getMappingForAttributeName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Returns the mapping associated with a given attribute name.
getMappingForAttributeName(String) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the mapping for the specified attribute name.
getMappingForAttributeName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Returns the mapping associated with a given attribute name.
getMappingForField(FIELD) - Method in class org.eclipse.persistence.internal.core.descriptors.CoreObjectBuilder
Return the mapping for the specified field.
getMappingForField(CoreField) - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
getMappingForField(DatabaseField) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return al the mapping for the specified field.
getMappingFromQueryKey() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
getMappingOfFirstPrimaryKey(ClassDescriptor) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
getMappingQueries() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: PERF: Return the internally stored prepared mapping queries.
getMappings() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Returns mappings
getMappings() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getMappings() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Returns mappings
getMappingsByAttribute() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return all the mapping to attribute associations
getMappingsByField() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Return all the mapping to field associations
getMappingsPostCalculateChanges() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Mappings that require postCalculateChanges method to be called
getMappingsPostCalculateChangesOnDeleted() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Mappings that require mappingsPostCalculateChangesOnDeleted method to be called
getMappingsRequiringInitialization() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getMapsIdValue() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: Set the mapped by id value
getMapThreadsThatAreCurrentlyWaitingToReleaseDeferredLocksJustificationClone() - Method in class org.eclipse.persistence.internal.helper.type.ConcurrencyManagerState
getMapThreadToObjectIdWithWriteLockManagerChangesClone() - Method in class org.eclipse.persistence.internal.helper.type.ConcurrencyManagerState
getMapThreadToReadLockAcquisitionMetadata() - Method in class org.eclipse.persistence.internal.helper.ReadLockManager
getMapThreadToWaitOnAcquireReadLockClone() - Method in class org.eclipse.persistence.internal.helper.type.ConcurrencyManagerState
getMapThreadToWaitOnAcquireReadLockCloneMethodName() - Method in class org.eclipse.persistence.internal.helper.type.ConcurrencyManagerState
getMapWriteLockManagerThreadToObjectIdsWithChangeSet() - Static method in class org.eclipse.persistence.internal.helper.WriteLockManager
getMarker() - Method in class org.eclipse.persistence.queries.CursoredStream
INTERNAL: Return the marker used for mark() & reset() operations.
getMarshalAttributeGroup() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
getMarshalContext(int) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalContext
 
getMarshalContext(int) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectMarshalContext
 
getMarshalContext(int) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedMarshalContext
 
getMarshaller() - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
getMarshaller() - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
getMarshaller() - Method in interface org.eclipse.persistence.oxm.record.JSONWriterRecord.Output
 
getMarshaller() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.OutputStreamOutput
 
getMarshaller() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
getMarshaller() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL:
getMarshaller() - Method in class org.eclipse.persistence.oxm.XMLBinder
 
getMarshalListener() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
 
getMarshalListener() - Method in class org.eclipse.persistence.oxm.XMLMarshaller
 
getMarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getMarshalNullRepresentation() - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
Get the enum that determines what XML to write when a null value is encountered.
getMarshalRecord() - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
getMatchingAttributeValueFromObject(AbstractRecord, Object, AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: This is used to preserve object identity during a refreshObject() query.
getMatchingBackupAttributeValue(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: This is used to match up objects during an update in a UOW.
getMaxAllowedFrequencyToProduceMassiveDumpLogMessage() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
If the system is perceived to be frozen and not evolving any longer, we will allow that every so often (e.g.
getMaxAllowedFrequencyToProduceTinyDumpLogMessage() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
Just like we have a massive dump log message see ConcurrencyUtil.getMaxAllowedFrequencyToProduceMassiveDumpLogMessage() we also want threads to produce "tiny" dump about the fact that they rae stuck.
getMaxAllowedSleepTime() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
getMaxBatchSize() - Method in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
 
getMaxBatchWritingSize() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
PUBLIC: Allow for the max batch writing size to be set.
getMaxBatchWritingSize() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getMaxBatchWritingSize() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Allow for the max batch writing size to be set.
getMaxConnections() - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPoolConfig
 
getMaxExclusive() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getMaxExclusive() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getMaxFieldNameSize() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: returns the maximum number of characters that can be used in a field name on this platform.
getMaxFieldNameSize() - Method in class org.eclipse.persistence.platform.database.AccessPlatform
INTERNAL: returns the maximum number of characters that can be used in a field name on this platform.
getMaxFieldNameSize() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: returns the maximum number of characters that can be used in a field name on this platform.
getMaxFieldNameSize() - Method in class org.eclipse.persistence.platform.database.DBasePlatform
INTERNAL: returns the maximum number of characters that can be used in a field name on this platform.
getMaxFieldNameSize() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
getMaxFieldNameSize() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
INTERNAL: returns the maximum number of characters that can be used in a field name on this platform.
getMaxFieldNameSize() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
getMaxFieldNameSize() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: returns the maximum number of characters that can be used in a field name on this platform.
getMaxFieldNameSize() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: returns the maximum number of characters that can be used in a field name on this platform.
getMaxFieldNameSize() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
getMaxFieldNameSize() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: returns the maximum number of characters that can be used in a field name on this platform.
getMaxFieldNameSize() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: returns the maximum number of characters that can be used in a field name on this platform.
getMaxFieldNameSize() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the maximum number of single byte characters that can be used in a field name on this platform, assuming DEFAULT_DSI_NAME=CODE is specified in Symfoware's operating environment file for the system (see Symfoware manual).
getMaxForeignKeyNameSize() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: returns the maximum number of characters that can be used in a foreign key name on this platform.
getMaxForeignKeyNameSize() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: returns the maximum number of characters that can be used in a foreign key name on this platform.
getMaxForeignKeyNameSize() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
INTERNAL: returns the maximum number of characters that can be used in a foreign key name on this platform.
getMaximumCachedResults() - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Return the maximum cached results.
getMaxInclusive() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getMaxInclusive() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getMaxIndexNameSize() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: returns the maximum number of characters that can be used in an index name on this platform.
getMaxLength() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getMaxLength() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getMaxNumberOfConnections() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Return the maximum number of connections allowed.
getMaxNumberOfNonPooledConnections() - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Return the number of non-pooled database connections allowed.
getMaxNumberOfNonPooledConnections() - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return the number of non-pooled database connections allowed.
getMaxOccurs() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Any
 
getMaxOccurs() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getMaxOccurs() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
getMaxOccurs() - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
getMaxOccurs() - Method in class org.eclipse.persistence.internal.oxm.schema.model.TypeDefParticle
 
getMaxPoolSize() - Method in interface org.eclipse.persistence.sequencing.SequencingControl
PUBLIC: Returns a maximum number of connections in sequencing connection pool
getMaxPrecision() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
getMaxRows() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
get max rows returned from the call
getMaxRows() - Method in class org.eclipse.persistence.queries.ReadQuery
PUBLIC: Return the limit for the maximum number of rows that any ResultSet can contain to the given number.
getMaxScale() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
getMaxSize() - Method in class org.eclipse.persistence.internal.helper.ConcurrentFixedCache
Return the fixed size of the parse cache.
getMaxSize() - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
 
getMaxSize() - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
 
getMaxSize() - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
 
getMaxSizeForPool(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will retrieve the max size of a particular connection pool
getMaxSizeForPool(String) - Method in class org.eclipse.persistence.services.RuntimeServices
This method will retrieve the max size of a particular connection pool
getMaxUniqueKeyNameSize() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: returns the maximum number of characters that can be used in a unique key name on this platform.
getMaxUniqueKeyNameSize() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: returns the maximum number of characters that can be used in a unique key name on this platform.
getMaxUniqueKeyNameSize() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
INTERNAL: returns the maximum number of characters that can be used in a unique key name on this platform.
getMBeanServer() - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
INTERNAL: Return the MBeanServer to be used for MBean registration and deregistration.
This MBeanServer reference is lazy loaded and cached on the platform.
There are multiple ways of getting the MBeanServer
getMBeanServer() - Method in class org.eclipse.persistence.platform.server.wls.WebLogic_10_Platform
INTERNAL: Return the MBeanServer to be used for MBean registration and deregistration.
This MBeanServer reference is lazy loaded and cached on the platform.
There are multiple ways of getting the MBeanServer
getMBeanSessionName() - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
Remove JMX reserved characters from the session name
getMediaType() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
INTERNAL:
getMediaType() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Get the MediaType for this unmarshaller.
getMediaType() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Get the MediaType for this xmlUnmarshaller.
getMediaType() - Method in enum org.eclipse.persistence.oxm.MediaType
 
getMediaType() - Method in class org.eclipse.persistence.oxm.XMLMarshaller
Get the MediaType for this xmlMarshaller.
getMediaType() - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
Get the MediaType for this xmlUnmarshaller.
getMediaType(String) - Static method in enum org.eclipse.persistence.oxm.MediaType
 
getMemberTypes() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Union
 
getMergedNewObjects() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTERNAL: Used to return a map containing new objects found through the registerObjectForMergeCloneIntoWorkingCopy method.
getMergedObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
getMergeManager() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
A reference to the last used merge manager.
getMergePolicy() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
getMessage() - Method in exception org.eclipse.persistence.exceptions.DatabaseException
PUBLIC: This is the database error message.
getMessage() - Method in exception org.eclipse.persistence.exceptions.DescriptorException
PUBLIC: Return the exception error message.
getMessage() - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
PUBLIC: Return the exception error message.
getMessage() - Method in exception org.eclipse.persistence.exceptions.IntegrityException
PUBLIC: This method is used to print out all the descriptor exceptions.
getMessage() - Method in exception org.eclipse.persistence.exceptions.QueryException
PUBLIC: Return the exception error message.
getMessage() - Method in class org.eclipse.persistence.logging.SessionLogEntry
Return the log entry's message.
getMetamodelIdClassMap() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return the Map of IdClass attribute lists keyed on owner class name.
getMethod - Variable in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
 
getMethod() - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Return the clone method.
getMethod() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
getMethod() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlVirtualAccessMethods
(Optional) Defines the name of the method used to retrieve virtual properties.
getMethod() - Method in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
INTERNAL: Returns the static method.
getMethod(Class<?>, String, Class<?>[], boolean) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get a method declared in the given class.
getMethodClass() - Method in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
PUBLIC: Returns the class to execute the static method on.
getMethodClassName() - Method in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
INTERNAL: Returns the class to execute the static method on.
getMethodName - Variable in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
 
getMethodName - Variable in class org.eclipse.persistence.internal.descriptors.VirtualAttributeMethodInfo
 
getMethodName - Variable in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
Name of the initial get method.
getMethodName() - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Return the clone method name.
getMethodName() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
getMethodName() - Method in class org.eclipse.persistence.internal.descriptors.MethodBasedFieldTransformation
 
getMethodName() - Method in class org.eclipse.persistence.mappings.transformers.MethodBasedAttributeTransformer
 
getMethodName() - Method in class org.eclipse.persistence.mappings.transformers.MethodBasedFieldTransformer
 
getMethodName() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlAccessMethods
 
getMethodName() - Method in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
PUBLIC: Returns the name of the static method.
getMethodParameterTypes(Method) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get the list of parameter types for a given method.
getMethodReturnType(Method) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get the return type for a given method.
getMethodReturnTypeNotValid(CollectionMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
getMethods() - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
getMethods(Class<?>) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get the list of methods in a class.
getMimeType() - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
INTERNAL
getMimeType() - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
INTERNAL
getMimeType() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper.EncodedData
 
getMimeType() - Method in class org.eclipse.persistence.oxm.mappings.FixedMimeTypePolicy
Return the default mime type for this policy.
getMimeType() - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
INTERNAL
getMimeType() - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
INTERNAL
getMimeType(Object) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
 
getMimeType(Object) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
 
getMimeType(Object) - Method in interface org.eclipse.persistence.internal.oxm.mappings.MimeTypePolicy
return a MIME type string
getMimeType(Object) - Method in class org.eclipse.persistence.oxm.mappings.FixedMimeTypePolicy
The mime type will be obtained from the objects field/property that is mapped to the XML attribute with name "contentType" and namespace URI "http://www.w3.org/2005/05/xmlmime".
getMimeType(Object) - Method in interface org.eclipse.persistence.oxm.mappings.MimeTypePolicy
return a MIME type string
getMimeType(Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
INTERNAL
getMimeType(Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
INTERNAL
getMimeTypePolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
 
getMimeTypePolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
getMimeTypePolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
 
getMinConnections() - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPoolConfig
 
getMinExclusive() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getMinExclusive() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getMinimumTimeIncrement(AbstractSession) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL: Return a minimal time increment supported by the platform.
getMinInclusive() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getMinInclusive() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getMinLength() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getMinLength() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getMinNumberOfConnections() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Return the minimum number of connections.
getMinOccurs() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Any
 
getMinOccurs() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getMinOccurs() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
getMinOccurs() - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
getMinOccurs() - Method in class org.eclipse.persistence.internal.oxm.schema.model.TypeDefParticle
 
getMinor() - Method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Get minor version number.
getMinor() - Method in class org.eclipse.persistence.internal.helper.JavaSEPlatform.Version
Get minor version number.
getMinor() - Method in class org.eclipse.persistence.internal.helper.JavaVersion
Get minor version number.
getMinPoolSize() - Method in interface org.eclipse.persistence.sequencing.SequencingControl
PUBLIC: Returns a minimum number of connections in sequencing connection pool.
getMinScale() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
getMinSizeForPool(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will retrieve the min size of a particular connection pool
getMinSizeForPool(String) - Method in class org.eclipse.persistence.services.RuntimeServices
This method will retrieve the min size of a particular connection pool
getMixedContentMapping() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
getMixedContentMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
getMode() - Method in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
getModifyRow() - Method in class org.eclipse.persistence.internal.expressions.SQLModifyStatement
 
getModifyRow() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Convenience method
getModifyRow() - Method in class org.eclipse.persistence.queries.ModifyQuery
INTERNAL: Return the modify row
getModuleName() - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
INTERNAL: getModuleName(): Answer the name of the context-root of the application that this session is associated with.
getModuleName() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: getModuleName(): Answer the name of the module (jar name) that my session is associated with.
getModuleName() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: getModuleName(): Answer the name of the module (jar name) that my session is associated with.
getModuleName() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
getModuleName(): Answer the name of the context-root of the application that this session is associated with.
getModuleName() - Method in class org.eclipse.persistence.services.RuntimeServices
getModuleName(): Answer the name of the context-root of the application that this session is associated with.
getModuleName(boolean) - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
INTERNAL:
getMonitorName() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the name to use for the query in performance monitoring.
getMoveIndexPairs() - Method in class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
ADVANCED: Return the indexes of the elements that were simply moved within the collection.
getMoveIndexPairs() - Method in interface org.eclipse.persistence.sessions.changesets.EISOrderedCollectionChangeRecord
ADVANCED: ADVANCED: Return the indexes of the elements that were simply moved within the collection.
getMoves() - Method in class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
ADVANCED: Return the entries for all the elements that were simply shuffled within the collection.
getMoves() - Method in interface org.eclipse.persistence.sessions.changesets.EISOrderedCollectionChangeRecord
ADVANCED: Return the entries for all the elements that were simply shuffled within the collection.
getMulticastGroupAddress() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.discovery.DiscoveryConfig
 
getMulticastGroupAddress() - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
PUBLIC: Return the host address of the multicast group.
getMulticastPort() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.discovery.DiscoveryConfig
 
getMulticastPort() - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
PUBLIC: Return the multicast port used for discovery.
getMultipleFieldIdentifiers() - Method in class org.eclipse.persistence.queries.FieldResult
INTERNAL:
getMultipleTableForeignKeyAssociations() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Returns the foreign key relationships used for multiple tables which were specified by the user.
getMultipleTableForeignKeys() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Returns the foreign key relationships used for multiple tables which were specified by the user.
getMultipleTableInsertOrder() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Returns the List of DatabaseTables in the order which INSERTS should take place.
getMultipleTableJoinExpression() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: This is normally generated for descriptors that have multiple tables.
getMultipleTablePrimaryKeyAssociations() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Returns the foreign key relationships used for multiple tables which were specified by the user.
getMultitenantContextProperties() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return a set of multitenant context properties this session
getMultitenantPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Retun the multitenant policy
getMultitenantPolicy() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL:
getName() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
getName() - Method in class org.eclipse.persistence.descriptors.partitioning.PartitioningPolicy
PUBLIC: Return the name of the policy.
getName() - Method in interface org.eclipse.persistence.dynamic.DynamicType
Return the entity type's name.
getName() - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Return the name of the ConnectionFactory within the JNDI Context.
getName() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
getName() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Return the name.
getName() - Method in class org.eclipse.persistence.internal.codegen.CodeDefinition
 
getName() - Method in interface org.eclipse.persistence.internal.core.helper.CoreField
Return the unqualified name of the field.
getName() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Return the name.
getName() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getName() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
getName() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Return the unqualified name of the field.
getName() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Get method for table name.
getName() - Method in enum org.eclipse.persistence.internal.mappings.converters.AttributeNamePrefix
INTERNAL: Get attribute name prefix identifier.
getName() - Method in class org.eclipse.persistence.internal.oxm.ByteArrayDataSource
 
getName() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Return the unqualified name of the field.
getName() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.Attribute
 
getName() - Method in class org.eclipse.persistence.internal.oxm.schema.model.AttributeGroup
 
getName() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
getName() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
getName() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getName() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
getName() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
getName() - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
getName() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the name of the session.
getName() - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPoolConfig
 
getName() - Method in class org.eclipse.persistence.internal.sessions.factories.model.property.PropertyConfig
 
getName() - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequenceConfig
 
getName() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
getName() - Method in enum org.eclipse.persistence.logging.LogCategory
Get logging category name.
getName() - Method in enum org.eclipse.persistence.logging.LogLevel
Get logging level name.
getName() - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
PUBLIC: Return the name for the query key.
getName() - Method in class org.eclipse.persistence.oxm.sequenced.Setting
Return the name of the setting.
getName() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return the name of the query
getName() - Method in class org.eclipse.persistence.queries.SQLResultSetMapping
 
getName() - Method in class org.eclipse.persistence.sequencing.Sequence
 
getName() - Method in class org.eclipse.persistence.sessions.JNDIConnector
PUBLIC: Return the name of the DataSource within the JNDI Context.
getName() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: get the name of the project.
getName() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Return the name of this pool.
getName() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the name of the session.
getName() - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
PUBLIC: Return the name of the object.
getName() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Return the name of the field.
getName() - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
getName() - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Return the name.
getName() - Method in class org.eclipse.persistence.tools.schemaframework.UniqueKeyConstraint
PUBLIC:
getNameAfterKey(String) - Static method in class org.eclipse.persistence.internal.mappings.converters.AttributeNameTokenizer
INTERNAL: Return an attribute name without key. dot notation prefix.
getNameAfterVersion(String) - Static method in class org.eclipse.persistence.internal.mappings.converters.AttributeNameTokenizer
INTERNAL: Return an attribute name without value. dot notation prefix.
getNameDelimited(DatasourcePlatform) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Returns this fields name with database delimiters if useDelimiters is true.
getNameDelimited(DatasourcePlatform) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Get method for table name.
getNameField() - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.TableSequenceConfig
 
getNameFieldName() - Method in class org.eclipse.persistence.sequencing.TableSequence
 
getNameForComparisons() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
INTERNAL: gets the string used for comparisons and in determining the hashcode.
getNameForFragment(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
getNameOrOwnerName() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
getNames() - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Lazily initialize and return the names of the items requested for use in each result object.
getNames() - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Return the names of report items, provided to ReportQuery.
getNamespace() - Method in class org.eclipse.persistence.internal.oxm.schema.model.AnyAttribute
 
getNamespace() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Import
 
getNameSpace() - Method in enum org.eclipse.persistence.logging.LogCategory
Get logger name space for this logging category.
getNameSpace() - Method in class org.eclipse.persistence.logging.SessionLogEntry
Return the name space of the log entry.
getNamespacePrefixMapper() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
NamespacePrefixMapper that can be used during marshal (instead of those set in the project meta data)
getNamespacePrefixMapper() - Method in class org.eclipse.persistence.oxm.XMLMarshaller
NamespacePrefixMapper that can be used during marshal (instead of those set in the project meta data)
getNamespaceResolver() - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Return the XML namespace resolver.
getNamespaceResolver() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Return the NamespaceResolver associated with this descriptor
getNamespaceResolver() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Get the NamespaceResolver associated with this XMLField
getNamespaceResolver() - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
getNamespaceResolver() - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
getNamespaceResolver() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getNamespaceResolver() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Name of the NamespaceResolver to be used during unmarshal Ignored unmarshalling XML.
getNamespaceResolver() - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
getNamespaceResolver() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Name of the NamespaceResolver to be used during unmarshal Ignored unmarshalling XML.
getNamespaceResolver() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
getNamespaceResolver() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
getNamespaceResolver() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
getNamespaceResolver() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: Return the NamespaceResolver associated with this descriptor
getNamespaceResolver() - Method in class org.eclipse.persistence.oxm.XMLField
Get the NamespaceResolver associated with this XMLField
getNamespaces() - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
INTERNAL: Returns a Vector of of Namespace objects in the current Namespace Resolver Used for deployment XML
getNamespaces() - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
 
getNamespaceSeparator() - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
getNamespaceSeparator() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getNamespaceSeparator() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
INTERNAL: The character used to separate the prefix and uri portions when namespaces are present
getNamespaceSeparator() - Method in interface org.eclipse.persistence.internal.oxm.record.XMLRecord
 
getNamespaceSeparator() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Get the namespace separator used during unmarshal operations.
getNamespaceSeparator() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Get the namespace separator used during marshal operations.
getNamespaceSeparator() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Get the namespace separator used during unmarshal operations.
getNamespaceSeparator() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getNamespaceSeparator() - Method in class org.eclipse.persistence.oxm.record.JsonRecord
INTERNAL: The character used to separate the prefix and uri portions when namespaces are present
getNamespaceSeparator() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL: The character used to separate the prefix and uri portions when namespaces are present
getNamespaceSeparator() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getNamespaceSeparator() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL: The character used to separate the prefix and uri portions when namespaces are present
getNameSpaceString(String) - Method in class org.eclipse.persistence.logging.JavaLog
INTERNAL: Return the name space for the given category from the map.
getNamespaceURI() - Method in class org.eclipse.persistence.internal.oxm.Namespace
 
getNamespaceURI() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getNamespaceURI() - Method in class org.eclipse.persistence.internal.oxm.Root
Gets the namespace uri.
getNamespaceURI() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getNamespaceURI() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
PUBLIC: Get the namespace URI for the context root element.
getNamespaceURI() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
getNamespaceURI() - Method in class org.eclipse.persistence.oxm.record.NodeRecord
 
getNamespaceURI() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getNamespaceURI() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
getNamespaceURI() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
PUBLIC: Get the namespace URI for the context root element.
getNamespaceURI() - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
getNamespaceURI(String) - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.StackUnmarshalNamespaceResolver
 
getNamespaceURI(String) - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceContext
 
getNamespaceURI(String) - Method in interface org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceResolver
Return the namespace URI for the specified prefix at the current scope.
getNamingServiceType() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
PUBLIC: Return the type of naming service used to look up remote connections to other service instances.
getNativeSequencing() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getNativeSequencing() - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
getNativeSQL() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getNativeTableInfo(String, String, AbstractSession) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Return the catalog information through using the native SQL catalog selects.
getNativeTableInfo(String, String, AbstractSession) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL: Not currently used.
getNativeTableInfo(String, String, AbstractSession) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Return the catalog information through using the native SQL catalog selects.
getNativeTableInfo(String, String, AbstractSession) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Return the catalog information through using the native SQL catalog selects.
getNativeTableInfo(String, String, AbstractSession) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Return the catalog information through using the native SQL catalog selects.
getNestedAttributeName() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Returns nested attribute name or null
getNestedFieldTranslations() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return the hashtable that stores the nested field translations.
getNestedJoinedMappingQuery(Expression) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
INTERNAL: Returns the nested query corresponding to the expression.
getNestedJoinQuery(JoinedAttributeManager, ObjectLevelReadQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return the query that is used when this mapping is part of a joined relationship This method is used when this mapping is used to map the key in a Map
getNestedJoinQuery(JoinedAttributeManager, ObjectLevelReadQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Return the query that is used when this mapping is part of a joined relationship This method is used when this mapping is used to map the key in a Map.
getNestedJoinQuery(JoinedAttributeManager, ObjectLevelReadQuery, AbstractSession) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Return the query that is used when this mapping is part of a joined relationship
getNestedJoinQuery(JoinedAttributeManager, ObjectLevelReadQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return the query that is used when this mapping is part of a joined relationship This method is used when this mapping is used to map the key in a Map
getNestedType() - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
Return the database type of the value contained in the collection type.
getNestedType() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCollection
Return the database type of the value contained in the collection type.
getNestedTypeField() - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDatabaseField
ADVANCED: For ARRAY fields, this field's type represents the type contained in the ARRAY.
getNestLevel() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
getNestTime() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
getNewAggregates() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The map stores any new aggregates that have been cloned.
getNewCollection() - Method in class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
ADVANCED: Return the entries for all the elements in the new collection.
getNewCollection() - Method in interface org.eclipse.persistence.sessions.changesets.EISOrderedCollectionChangeRecord
ADVANCED: Return the entries for all the elements in the new collection.
getNewKey() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
This method returns the key value that this object will be stored under in it's Respective hashmap.
getNewKey() - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCED: This method returns the key value that this object will be stored under in it's respective Map.
getNewLockValue(ModifyQuery) - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: Returns the new Timestamp value.
getNewLockValue(ModifyQuery) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: This method gets the write lock value from either the cache or the object stored in the query.
getNewObjectChangeSets() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: This method will return a reference to the new object change set collections.
getNewObjectsCache() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
Returns a new object cache
getNewObjectsCloneToMergeOriginal() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The stores a map from new object clones to the original object used from merge.
getNewObjectsCloneToOriginal() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The new objects stores any objects newly created during the unit of work.
getNewObjectsInParentOriginalToClone() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The returns the list that will hold the new objects from the Parent UnitOfWork
getNewObjectsOriginalToClone() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The new objects stores any objects newly created during the unit of work.
getNewSize() - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
getNewTempClassLoader(PersistenceUnitInfo) - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: JIRA EJBTHREE-572 requires that we use the real classLoader in place of the getNewTempClassLoader().
getNewTempClassLoader(PersistenceUnitInfo) - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
 
getNewValue() - Method in class org.eclipse.persistence.internal.sessions.DirectToFieldChangeRecord
ADVANCED: Returns the new value assigned during the change.
getNewValue() - Method in class org.eclipse.persistence.internal.sessions.ObjectReferenceChangeRecord
ADVANCED: Returns the new reference for this object
getNewValue() - Method in interface org.eclipse.persistence.sessions.changesets.DirectToFieldChangeRecord
ADVANCED: Returns the new value assigned during the change
getNewValue() - Method in interface org.eclipse.persistence.sessions.changesets.ObjectReferenceChangeRecord
ADVANCED: Returns the new reference for this object
getNext() - Method in class org.eclipse.persistence.internal.identitymaps.LinkedCacheKey
 
getNextElement() - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMapEnumeration
Get next element of CacheKey instances enumeration if this enumeration object has at least one more element to provide.
getNextFieldCounterValue() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Return the next value of fieldCounter
getNextFragment() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getNextNode() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getNextObject() - Method in class org.eclipse.persistence.queries.ScrollableCursor
 
getNextQueryId() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Called by a sessions queries to obtain individual query ids.
getNextSequenceNumberValue(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Return the sequnce number from the database
getNextSequenceNumberValue(Class<?>) - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Return the sequence number from the database.
getNextThreadPartOfDeadLock() - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
getNextTime() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
 
getNextValue(Class<?>) - Method in interface org.eclipse.persistence.internal.sequencing.Sequencing
INTERNAL: Return the newly-generated sequencing value.
getNextValue(AbstractSession, Class<?>) - Method in interface org.eclipse.persistence.internal.sequencing.SequencingServer
 
GetNextValue(Class<?>) - Constructor for class org.eclipse.persistence.internal.sessions.remote.SequencingFunctionCall.GetNextValue
 
getNode() - Method in class org.eclipse.persistence.internal.oxm.record.DOMInputSource
 
getNode(Object, Node, ABSTRACT_SESSION, DESCRIPTOR, boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
getNode(Object, Node, AbstractSession, XMLDescriptor, boolean) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
 
getNodeClass() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL:
getNodeForClass(String, Hashtable<String, HierarchyNode>) - Static method in class org.eclipse.persistence.internal.codegen.InheritanceHierarchyBuilder
INTERNAL: Based on a class name either return a pre-existing node from the hierarchyTree or build one and add it to the tree.
getNodeForObject(Object) - Method in class org.eclipse.persistence.oxm.documentpreservation.DocumentPreservationPolicy
 
getNodeOrderingPolicy() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DocumentPreservationPolicyConfig
 
getNodeOrderingPolicy() - Method in class org.eclipse.persistence.oxm.documentpreservation.DocumentPreservationPolicy
 
getNodes() - Method in class org.eclipse.persistence.internal.oxm.SAXFragmentBuilder
 
getNodes() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
 
getNodeToReplace(Node) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
getNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getNoNamespaceSchemaLocation() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getNoNamespaceSchemaLocation() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getNoNamespaceSchemaLocation() - Method in class org.eclipse.persistence.internal.oxm.Root
Gets the no namespace schema location which will be set on the XMLRoot during unmarshal.
getNoNamespaceSchemaLocation() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Get the no namespace schema location set on this XMLMarshaller
getNoNamespaceSchemaLocation() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getNonAttributeChild(int, XPathNode) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalContext
 
getNonAttributeChild(int, XPathNode) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectMarshalContext
 
getNonAttributeChild(int, XPathNode) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedMarshalContext
 
getNonAttributeChildren() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getNonAttributeChildrenMap() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getNonAttributeChildrenSize(XPathNode) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalContext
 
getNonAttributeChildrenSize(XPathNode) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectMarshalContext
 
getNonAttributeChildrenSize(XPathNode) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedMarshalContext
 
getNonAttributeXPathNode(String, String, String, Attributes) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getNonAttributeXPathNode(String, String, String, Attributes) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
INTERNAL:
getNonAttributeXPathNode(String, String, String, Attributes) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getNonDeferredCreateTime() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
ADVANCED: This setting is only available for CMP beans that are not being deferred.
getNonFetchJoinAttributeExpressions() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the attributes that must be joined, but not fetched, that is, do not trigger the value holder.
getNonNullNamespaceResolver() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
 
getNonNullNamespaceResolver() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
getNonPrimaryKeyMappings() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the non primary key mappings.
getNonReferenceEntityFetchGroup() - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Returns EntityFetchGroup corresponding to non relational attributes intersected with defaultFetchGroup.
getNonReferenceEntityFetchGroup(boolean, boolean) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Returns EntityFetchGroup corresponding to non relational attributes intersected with defaultFetchGroup.
getNonSelectFields() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Return the fields we don't want to select but want to join on.
getNoOfThreadsAllowedToDoWriteLockManagerAcquireRequiredLocksInParallel() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
getNoOfThreadsAllowedToObjectBuildInParallel() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
getNoWaitString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This syntax does no wait on the lock.
getNoWaitString() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 does not support NOWAIT.
getNullableArguments() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the list of arguments to check for null.
getNullCapableValue() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getNullCapableValues() - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
getNullCapableValues() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getNullCapableValues() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getNullCapableValues() - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
getNullCapableValues() - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
getNullCapableValues() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getNullPolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
 
getNullPolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
 
getNullPolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
 
getNullPolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
 
getNullPolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
 
getNullPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
INTERNAL: Get the AbstractNullPolicy from the Mapping.
The default policy is NullPolicy.
getNullPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
getNullPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
INTERNAL: Get the AbstractNullPolicy from the Mapping.
The default policy is NullPolicy.
getNullPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
INTERNAL: Get the AbstractNullPolicy from the Mapping.
The default policy is NullPolicy.
getNullPolicy() - Method in interface org.eclipse.persistence.oxm.mappings.XMLNillableMapping
Get the AbstractNullPolicy from the Mapping.
The default policy is NullPolicy.
getNullValue() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
 
getNullValue() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
 
getNullValue() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
PUBLIC: Allow for the value used for null to be specified.
getNullValue() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
PUBLIC: Allow for the value used for null to be specified.
getNumberOfActiveUnitsOfWork() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the number of units of work connected.
getNumberOfInstancesEffected() - Method in class org.eclipse.persistence.tools.profiler.Profile
 
getNumberOfNonPooledConnectionsUsed() - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Return the current number of non-pooled connections in use.
getNumberOfObjectsInAllIdentityMaps() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will SUM and return the number of objects in all Identity Maps in the session.
getNumberOfObjectsInAllIdentityMaps() - Method in class org.eclipse.persistence.services.RuntimeServices
This method will SUM and return the number of objects in all Identity Maps in the session.
getNumberOfObjectsInIdentityMap(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to return the number of objects in a particular Identity Map
getNumberOfObjectsInIdentityMap(String) - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to return the number of objects in a particular Identity Map
getNumberOfObjectsInIdentityMapSubCache(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to return the number of objects in a particular Identity Map's subcache.
getNumberOfObjectsInIdentityMapSubCache(String) - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to return the number of objects in a particular Identity Map's subcache.
getNumberOfPersistentClasses() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will answer the number of persistent classes contained in the session.
getNumberOfPersistentClasses() - Method in class org.eclipse.persistence.services.RuntimeServices
This method will answer the number of persistent classes contained in the session.
getNumberOfProperties() - Method in interface org.eclipse.persistence.dynamic.DynamicType
The current number of properties.
getNumberOfProperties() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getNumberOfReaders() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Number of writer that want the lock.
getNumberOfReadersOnCacheKeyBeforeIncrementingByOne() - Method in class org.eclipse.persistence.internal.helper.type.ReadLockAcquisitionMetadata
getNumberOfWritersWaiting() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Number of writers that want the lock.
getNumberVal() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: XMLType Function - gets a number value from an XMLType
getNumberVal() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
 
GetNumberVal - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
getObject() - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
PUBLIC: Synanym for source.
getObject() - Method in exception org.eclipse.persistence.exceptions.OptimisticLockException
PUBLIC: Return the object for which the problem was detected.
getObject() - Method in class org.eclipse.persistence.internal.helper.IndexedObject
 
getObject() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
getObject() - Method in class org.eclipse.persistence.internal.identitymaps.WeakCacheKey
 
getObject() - Method in class org.eclipse.persistence.internal.indirection.TransformerBasedValueHolder
Return the receiver.
getObject() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkTransformerValueHolder
 
getObject() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
getObject() - Method in class org.eclipse.persistence.internal.oxm.Root
Gets the object.
getObject() - Method in class org.eclipse.persistence.internal.sessions.remote.ObjectDescriptor
Return the domain object
getObject() - Method in class org.eclipse.persistence.internal.sessions.remote.Transporter
Returns the read object(s) from the server side.
getObject() - Method in class org.eclipse.persistence.oxm.JSONWithPadding
The Object that will be marshalled
getObject() - Method in exception org.eclipse.persistence.oxm.record.ValidatingMarshalRecord.MarshalSAXParseException
 
getObject() - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
getObject() - Method in class org.eclipse.persistence.queries.DoesExistQuery
PUBLIC: Return the object.
getObject() - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
PUBLIC: Return the object required for modification.
getObject() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
getObject(Class<?>, String) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Return the object registered given its name.
getObject(ResultSet, DatabaseField, ResultSetMetaData, int, DatabasePlatform, boolean, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return an object retrieved from resultSet with the getObject() method.
getObject(Node) - Method in class org.eclipse.persistence.oxm.XMLBinder
Gets the Java Object associated with the provided XML Node.
getObjectBuilder() - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
INTERNAL: Return the object builder
getObjectBuilder() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return the object builder
getObjectBuilder() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: Return the object builder
getObjectBuilder(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
Convenience method
getObjectBuilderForClass(Class<?>, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
Convenience method
getObjectChangePolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return this objects ObjectChangePolicy.
getObjectChangePolicyInternal() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return this objects ObjectChangePolicy and do not lazy initialize
getObjectChanges() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Returns the ObjectChanges held by this ChangeSet.
getObjectChangeSet() - Method in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
INTERNAL: Return the object change set associated with this listener
getObjectChangeSet() - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
PUBLIC: Return the ObjectChangeSet representing the object being changed
getObjectChangeSetForClone(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
ADVANCED: Get ChangeSet for a particular clone
getObjectChangeSetForClone(Object) - Method in interface org.eclipse.persistence.sessions.changesets.UnitOfWorkChangeSet
ADVANCED: Get ChangeSet for a particular clone
getObjectChangeSetToUOWClone() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: This method returns a reference to the collection
getObjectClass() - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
PUBLIC: Returns the class type of the object value.
getObjectClass() - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLListConverter
Get the Class of the elements of this collection's "sub-collection".
getObjectClass(Class<?>) - Static method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: This is used to determine the wrapper class for a primitive.
getObjectClass(Class<?>) - Static method in class org.eclipse.persistence.internal.helper.Helper
Returns the object class.
getObjectClassName() - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
INTERNAL: Return the name of the object type for the MW usage.
getObjectClassName() - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLListConverter
Get the Class name of the elements of this collection's "sub-collection".
getObjectCollection() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Return the internal object collection that stores the objects.
getObjectCorrespondingTo(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Return the corresponding objects from the remote session for the objects read from the server.
getObjectCorrespondingTo(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
INTERNAL: Return the corresponding objects from the remote session for the objects read from the server.
getObjectCorrespondingTo(Object, DistributedSession, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: return the object on the client corresponding to the specified object.
getObjectCorrespondingTo(Object, DistributedSession, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: return the object on the client corresponding to the specified object.
getObjectCorrespondingTo(Object, DistributedSession, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: return the object on the client corresponding to the specified object.
getObjectCorrespondingTo(Object, DistributedSession, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: return the object on the client corresponding to the specified object.
getObjectDescriptors() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
getObjectDescriptors() - Method in class org.eclipse.persistence.internal.sessions.remote.Transporter
Returns a hashtable of object descriptors.
getObjectEntityFetchGroup(Object) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Return FetchGroup held by the object.
getObjectFetchGroup(Object) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Return FetchGroup held by the object.
getObjectForMerge(MergeManager, AbstractSession, Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: For use within the distributed merge process, this method will get an object from the shared cache using a readlock.
getObjectForNode(Node) - Method in class org.eclipse.persistence.oxm.documentpreservation.DocumentPreservationPolicy
 
getObjectForNode(Node, Mapping) - Method in class org.eclipse.persistence.oxm.documentpreservation.DocumentPreservationPolicy
 
getObjectFromCache() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Get object from the cache if there is one.
getObjectFromNewObjects(Class<?>, Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return any new object matching the expression.
getObjectFromNewObjects(Expression, Class<?>, AbstractRecord, int) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return any new object matching the expression.
getObjectFromResultSet(ResultSet, int, int, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Get the object from the JDBC Result set.
getObjectFromResultSet(ResultSet, int, int, AbstractSession) - Method in class org.eclipse.persistence.platform.database.Informix11Platform
Overrides DatabasePlatform.getObjectFromResultSet(ResultSet, int, int, AbstractSession) so that if the supplied jdbcType is equal to Types.LONGVARCHAR, then the ResultSet.getString(int) method (instead of the ResultSet.getObject(int) method) is used to fetch the "raw" value of the column indicated by the supplied columnNumber from the supplied ResultSet.
getObjectFromResultSet(ResultSet, int, int, AbstractSession) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Get a timestamp value from a result set.
getObjectFromResultSet(ResultSet, int, int, AbstractSession) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
 
getObjectFromRow(AbstractRecord, AbstractSession, ObjectLevelReadQuery) - Method in interface org.eclipse.persistence.descriptors.SerializedObjectPolicy
Deserialize the object from the value corresponding to the policy field, nullify that value, set the object into the row using setSopObject, also return it.
getObjectFromRow(AbstractRecord, AbstractSession, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.internal.descriptors.SerializedObjectPolicyWrapper
 
getObjectName() - Method in class org.eclipse.persistence.services.RuntimeServices
 
getObjects() - Method in class org.eclipse.persistence.queries.DeleteAllQuery
PUBLIC: Return the objects that are to be deleted
getObjectsAlreadyMerged() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
getObjectsCorrespondingToAll(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, ContainerPolicy) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Return the corresponding objects from the remote session for the objects read from the server.
getObjectsCorrespondingToAll(Object, Map<Object, ObjectDescriptor>, Map<Object, Object>, ObjectLevelReadQuery, ContainerPolicy) - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
INTERNAL: Return the corresponding objects from the remote session for the objects read from the server.
getObjectsDeletedDuringCommit() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Returns all the objects which are deleted during root commit of unit of work.
getObjectsInIdentityMap(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will return a collection of the objects in the Identity Map.
getObjectsInIdentityMap(String) - Method in class org.eclipse.persistence.services.RuntimeServices
This method will return a collection of the objects in the Identity Map.
getObjectsInIdentityMapSubCacheAsMap(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will return a collection of the objects in the Identity Map.
getObjectsInIdentityMapSubCacheAsMap(String) - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to return a Map of the objects in a particular Identity Map's subcache.
getObjectsPerSecond() - Method in class org.eclipse.persistence.tools.profiler.Profile
 
getObjectsToDelete() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Deletion are cached until the end.
getObjectThroughOptimizedDataConversion(ResultSet, DatabaseField, int, int, DatabasePlatform, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Handle the ResultSet conversion into java optimally through calling the direct type API.
getObjectToMerge(Object, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
getObjectType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the Object type representation.
getObjectValue(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Convert the field value to an attribute value.
getObjectValue(Object, Session) - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL: Allows for subclasses to convert the the attribute or property value.
getObjectValue(Object, Session) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Allows for subclasses to convert the attribute value.
getObjectValue(Object, Session) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL:
getObjectValue(Object, Session) - Method in class org.eclipse.persistence.mappings.xdb.DirectToXMLTypeMapping
INTERNAL: Get the attribute value for the given field value.
getObjectValue(Object, SESSION) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
 
getObjectValue(Object, SESSION) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
 
getObjectValue(Object, SESSION) - Method in interface org.eclipse.persistence.internal.oxm.mappings.FragmentMapping
 
getObjectValueFromDataHandler(DataHandler, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryAttachmentHandler
 
getObjectValueWithoutClassCheck(Object, Session) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Same as getObjectValue method, but without checking fieldValue's class.
getObjID() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoveServerSideRemoteValueHolderCommand
INTERNAL: Use this method to get the the remote ValueHolder ID
getOldKey() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
This method returns the key value that this object was stored under in it's Respective hashmap.
getOldKey() - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCED: This method returns the key value that this object was stored under in it's respective Map.
getOldSize() - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
getOldValue() - Method in class org.eclipse.persistence.internal.sessions.AggregateChangeRecord
ADVANCED: If the owning UnitOfWork has shouldChangeRecordKeepOldValue set to true, then return the old value of the attribute represented by this ChangeRecord.
getOldValue() - Method in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
ADVANCED: If the owning UnitOfWork has shouldChangeRecordKeepOldValue set to true, then return the old value of the attribute represented by this ChangeRecord.
getOldValue() - Method in class org.eclipse.persistence.internal.sessions.DirectToFieldChangeRecord
ADVANCED: Return the old value of the attribute represented by this ChangeRecord.
getOldValue() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
getOldValue() - Method in class org.eclipse.persistence.internal.sessions.ObjectReferenceChangeRecord
Return the old value of the object reference.
getOldValue() - Method in class org.eclipse.persistence.internal.sessions.TransformationMappingChangeRecord
ADVANCED: Return the old value of the attribute represented by this ChangeRecord.
getOldValue() - Method in interface org.eclipse.persistence.sessions.changesets.AggregateChangeRecord
ADVANCED: If the owning UnitOfWork has shouldChangeRecordKeepOldValue set to true, then return the old value of the attribute represented by this ChangeRecord.
getOldValue() - Method in interface org.eclipse.persistence.sessions.changesets.ChangeRecord
ADVANCED: If the owning UnitOfWork has shouldChangeRecordKeepOldValue set to true, then return the old value of the attribute represented by this ChangeRecord.
getOldValue() - Method in interface org.eclipse.persistence.sessions.changesets.DirectToFieldChangeRecord
ADVANCED: Return the old value of the attribute represented by this ChangeRecord.
getOldValue() - Method in interface org.eclipse.persistence.sessions.changesets.ObjectReferenceChangeRecord
Return the old value of the object reference.
getOldValue(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
 
getOldValue(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
getOnClause() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
getOnConnectionError() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.TransportManagerConfig
 
getOneToOneMapping() - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Reduce casting clutter....
getOnlyInstancesExpression() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: Return the 'only instances expression'.
getOperation(Class<?>) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
INTERNAL: determines which operation to use for comparison.
getOperationStartTimes() - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
getOperationStartTimes() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
getOperationStartTimesByThread() - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
getOperationStartTimesByThread() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
getOperationTime(String) - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
getOperationTimings() - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
getOperationTimings() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
getOperationTimings() - Method in class org.eclipse.persistence.tools.profiler.Profile
 
getOperationTimingsByThread() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
getOperator() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Most expression have operators, so this is just a convenience method.
getOperator() - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
getOperator() - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
getOperator(int) - Static method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Create a new expression tree with the named operator.
getOperator(int) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
INTERNAL: Return the operator.
getOperator(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Return the operator for the operator constant defined in ExpressionOperator.
getOperator(Integer) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Lookup the operator with the given id.
getOptimisticLockingPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Returns the OptimisticLockingPolicy.
getOptimisticReadLockObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return optimistic read lock objects
getOptimizeDataConversion() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getOptimizedClonedExpressions() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: It is used by subqueries to avoid duplicate joins.
getOptionalArguments() - Method in class org.eclipse.persistence.queries.StoredProcedureCall
INTERNAL: Return the list of optional arguments.
getOrDefault(Object, V) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
getOrderByExpressions() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Return the order expressions for the query.
getOrderByExpressions() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Get the list of orderBy expressions.
getOrderByExpressions() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Return the order by expression.
getOrderByExpressions() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the order expressions for the query.
getOrderByExpressions_() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Get the list of orderBy expressions.
getOrderByNormalizedExpressions(Expression) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Aggregate order by all their fields by default.
getOrderByNormalizedExpressions(Expression) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return the list of fields that should be used if this mapping is used in an order by.
getOrderByNormalizedExpressions(Expression) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return null if this mapping is used in an order by.
getOrderByNormalizedExpressions(Expression) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Relationships order by their target primary key fields by default.
getOrderByNormalizedExpressions(Expression) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Order by foreign key fields if a foreign key mapping (avoids joins).
getOrderByQueryKeyExpressions() - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Return the ordering query keys.
getOrderCorrectionType() - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
 
getOrderCorrectionType() - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Specifies what should be done if the list of values read from listOrserField is invalid (there should be no nulls, no duplicates, no "holes").
getOrderedAddObjectIndex(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This method returns the index of an object added to the collection.
getOrderedAddObjectIndices() - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This method returns the collection of ChangeSets that they were added to the collection.
getOrderedAddObjects() - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This method returns the collection of ChangeSets in the order they were added to the collection.
getOrderedAttributes() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
getOrderedAttributes() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
getOrderedChangeObjectList() - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This method returns the Vector of OrderedChangeObjects.
getOrderedClasses() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
Return the constraint ordered classes.
getOrderedDescriptors() - Method in class org.eclipse.persistence.core.sessions.CoreProject
INTERNAL: Return the descriptors in the order added.
getOrderedDescriptors() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
Return the constraint ordered descriptors.
getOrderedDescriptors() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return the descriptors in the order added.
getOrderedElements() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
getOrderedElements() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
getOrderedFields() - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Return the field order.
getOrderedForeignKeyFields() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return a vector of the foreign key fields in the same order as the corresponding primary key fields are in their descriptor.
getOrderedPartitions() - Method in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
 
getOrderedRemoveObject(Integer) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This method returns the index of an object removed from the collection.
getOrderedRemoveObjectIndices() - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This method returns the ordered list of indices to remove from the collection.
getOrderedRemoveObjects() - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This method returns the collection of ChangeSets of objects removed from the collection.
getOrderSiblingsByExpressions() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Return the ORDER SIBLINGS BY expression
getOrderSiblingsByExpressions() - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC:
getOriginalCollection() - Method in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
Used for change tracking when user sets entire collection.
getOriginalFieldsForJoin() - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
getOriginalIndirectionObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return the original indirection object for a unit of work indirection object.
getOriginalIndirectionObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return the original indirection object for a unit of work indirection object.
getOriginalIndirectionObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return the original indirection object for a unit of work indirection object.
getOriginalIndirectionObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return the original indirection object for a unit of work indirection object.
getOriginalIndirectionObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Return the original indirection object for a unit of work indirection object.
getOriginalIndirectionObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the original indirection object for a unit of work indirection object.
getOriginalIndirectionObjectForMerge(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return the original indirection object for a unit of work indirection object.
getOriginalIndirectionObjectForMerge(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return the original indirection object for a unit of work indirection object.
getOriginalIndirectionObjectForMerge(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return the original indirection object for a unit of work indirection object.
getOriginalIndirectionObjectForMerge(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the original indirection object for a unit of work indirection object.
getOriginalObject() - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
PUBLIC: The source object represents the object the event is being raised on, some events also require a second object, for example the original object in a postClone.
getOriginalValueHolder(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return the original valueHolder object.
getOriginalValueHolder(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return the original valueHolder object.
getOriginalValueHolder(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return the original valueHolder object.
getOriginalValueHolder(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the original valueHolder object.
getOriginalVersionOfNewObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the original version of the new object (working clone).
getOriginalVersionOfObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Return the original version of the object(clone) from the parent's identity map.
getOriginalVersionOfObject(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Return the original version of the object(clone) from the parent's identity map.
getOriginalVersionOfObjectOrNull(Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the original version of the object(clone) from the parent's identity map.
getOriginalVersionOfObjectOrNull(Object, ObjectChangeSet, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the original version of the object(clone) from the parent's identity map.
getOuterJoinExpIndex() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
getOuterJoinExpressionsHolders() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: returns outerJoinExpressionHolders representing outerjoin expressions.
getOutput() - Method in class org.eclipse.persistence.internal.codegen.CodeGenerator
 
getOutputArgumentNames() - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
The argument names for the output record.
getOutputArguments() - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
The argument fields to the interaction that map into the output record.
getOutputArguments() - Method in class org.eclipse.persistence.eis.interactions.IndexedInteraction
The output arguments in order of occurance in the record.
getOutputCursors() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: Return the output cursors for this stored procedure call.
getOutputField() - Method in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
getOutputFileName() - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Return the file name that the generate .java file will be output to.
getOutputFileName() - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Return the file name that the generate .java file will be output to.
getOutputParameterValue(CallableStatement, int, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Get the return object from the statement.
getOutputParameterValue(CallableStatement, int, AbstractSession) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
getOutputParameterValue(CallableStatement, int, AbstractSession) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
 
getOutputParameterValue(CallableStatement, String, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Get the return object from the statement.
getOutputPath() - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Return the path that the generate .java file will be output to.
getOutputPath() - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Return the path that the generate .java file will be output to.
getOutputProcedureToken() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This method is used to print the output parameter token when stored procedures are called
getOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
This method is used to print the output parameter token when stored procedures are called
getOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
getOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
This method is used to print the output parameter token when stored procedures are called
getOutputProcedureToken() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
getOutputResultPath() - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: The output result path defines the root key for the MappedRecord that the desired interaction result is nested into.
getOutputRootElementName() - Method in class org.eclipse.persistence.eis.interactions.XMLInteraction
PUBLIC: Return the root element name to use for the output DOM.
getOutputRowFields() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL Returns the fields to be used in output row.
getOutputStream() - Method in class org.eclipse.persistence.internal.oxm.ByteArrayDataSource
 
getOutputStream() - Method in interface org.eclipse.persistence.oxm.record.JSONWriterRecord.Output
 
getOutputStream() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.OutputStreamOutput
 
getOutputStream() - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
Return the OutputStream that the object will be marshalled to.
getOutputWriter() - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Return the writer the output to.
getOutputWriter() - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Return the writer the output to.
getOverriddenLogStringForProperty(String) - Static method in class org.eclipse.persistence.config.PersistenceUnitProperties
INTERNAL: Return the overridden log string.
getOwnedSubTables() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
INTERNAL: much like getOwnedTables(), this gets the tables represented from the descriptor.
getOwnedTables() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Return the tables that this node owns for purposes of table aliasing.
getOwnedTables() - Method in class org.eclipse.persistence.internal.expressions.ManualQueryKeyExpression
INTERNAL: If we ever get in the circumstance of a manual query key to an aggregate, then we can assume that the owner of that aggregate isn't participating (and even if it is, we can't know which node it is, so *DO* use the aggregate's parents tables
getOwnedTables() - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
Exclude any tables defined by base.
getOwnedTables() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
Return any tables that are defined by this expression (and not its base).
getOwnedTables() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL:
getOwnedTables() - Method in class org.eclipse.persistence.internal.expressions.TableExpression
INTERNAL:
getOwnedTables() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
This owns (can access) the child's extra tables as well as its parent's tables so we should pull these from super (which gets them from the current descriptor)
getOwner() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
getOwner() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Content
 
getOwner() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
getOwner() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getOwner() - Method in class org.eclipse.persistence.internal.oxm.schema.model.TypeDefParticle
 
getOwner() - Method in class org.eclipse.persistence.internal.sessions.ChangeRecord
 
getOwner() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
getOwner() - Method in interface org.eclipse.persistence.sessions.changesets.ChangeRecord
ADVANCED: This method returns the ObjectChangeSet that references this ChangeRecord
getOwner() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
Return the ServerSession that is the owner of this connection pool.
getOwnerName() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Content
 
getOwnerName() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
getOwnerName() - Method in interface org.eclipse.persistence.internal.oxm.schema.model.Restrictable
 
getOwnerName() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getOwnerName() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
getOwnerName() - Method in class org.eclipse.persistence.internal.oxm.schema.model.TypeDefParticle
 
getOwningMap() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
getOwningMap() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
getOwningObject() - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
getOwningObject() - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
getOwningObject() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
getOwningObject() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL:
getOxmConversionManager() - Method in class org.eclipse.persistence.oxm.XMLContext
Returns conversion manager from session datasource platform.
getPackageName() - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
getPackageName() - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Return the package name of class to be generated.
getPackageName() - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Return the package name of class to be generated.
getPackageName(Class<?>) - Static method in class org.eclipse.persistence.internal.helper.Helper
return a package name for the specified class.
getPacketTimeToLive() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.discovery.DiscoveryConfig
 
getPacketTimeToLive() - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
PUBLIC: Returns the number of hops the data packets of the session announcement will take before expiring.
getPageSize() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Return the number of items to be faulted in for the stream.
getPageSize() - Method in class org.eclipse.persistence.queries.CursoredStream
INTERNAL: Return the page size for the stream.
getPageSize() - Method in class org.eclipse.persistence.queries.CursorPolicy
Return the number of elements to be read into a cursored stream when more elements are needed from the database.
getParameter(String) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression representing a parameter with the given name.
getParameter(String, Object) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Return an expression representing a parameter with the given name and type
getParameter(DatabaseField) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression representing a parameter with the given name.
getParameterBindings() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The parameter binding determines if the specific parameter should be bound.
getParameterDelimiter() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the String used to delimit an SQL parameter.
getParameterDelimiterChar() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the char used to delimit an SQL parameter.
getParameterizedMechanism() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Lazy init the parameterized SQL mechanism.
getParameters() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The parameters are the values in order of occurrence in the SQL statement.
getParameters() - Method in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
 
getParameters() - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
The parameters are the values in order of occurance in the SQL statement.
getParameters() - Method in class org.eclipse.persistence.logging.SessionLogEntry
 
getParameterTypes() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The parameter types determine if the parameter is a modify, translation or literal type.
getParameterTypes() - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
The parameter types determine if the parameter is a modify, translation or litteral type.
getParameterValueFromDatabaseCall(CallableStatement, int, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL Get the parameter from the JDBC statement with the given index.
getParameterValueFromDatabaseCall(CallableStatement, String, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL Get the parameter from the JDBC statement with the given name.
getParameterValueFromDatabaseCall(CallableStatement, String, AbstractSession) - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
 
getParent() - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
getParent() - Method in class org.eclipse.persistence.internal.codegen.HierarchyNode
 
getParent() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getParent() - Method in class org.eclipse.persistence.internal.queries.AttributeItem
 
getParent() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Gets the parent session.
getParent() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Return the parent.
getParent() - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
getParent() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Gets the parent SessionBroker.
getParent() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Return the parent.
getParent() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Return the parent.
getParentClass() - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
PUBLIC: Return the parent class.
getParentClass() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Return the parent class.
getParentClass() - Method in class org.eclipse.persistence.dynamic.DynamicClassWriter
 
getParentClass() - Method in interface org.eclipse.persistence.dynamic.EclipseLinkClassWriter
 
getParentClassName() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return the parent class name.
getParentClassName() - Method in class org.eclipse.persistence.dynamic.DynamicClassWriter
 
getParentClassName() - Method in interface org.eclipse.persistence.dynamic.EclipseLinkClassWriter
 
getParentClassName() - Method in class org.eclipse.persistence.services.ClassSummaryDetailBase
 
getParentDescriptor() - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL: Return the parent descriptor.
getParentDescriptor() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return the parent descriptor.
getParentDescriptorFromInheritancePolicy(Object) - Method in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
Get the descriptor that really represents this object In the case of inheritance, the object may represent a subclass of class the descriptor represents.
getParentDescriptorQueryManager() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Get the parent DescriptorQueryManager.
getParentDescriptors() - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Return all the parent descriptors.
getParentIdentityMapSession(ClassDescriptor, boolean, boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Returns the appropriate IdentityMap session for this descriptor.
getParentIdentityMapSession(ClassDescriptor, boolean, boolean) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSession
INTERNAL: Returns the appropriate IdentityMap session for this descriptor.
getParentIdentityMapSession(ClassDescriptor, boolean, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Returns the appropriate IdentityMap session for this descriptor.
getParentIdentityMapSession(ClassDescriptor, boolean, boolean) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Returns the appropriate IdentityMap session for this descriptor.
getParentIdentityMapSession(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Gets the next link in the chain of sessions followed by a query's check early return, the chain of sessions with identity maps all the way up to the root session.
getParentIdentityMapSession(DatabaseQuery, boolean, boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Gets the next link in the chain of sessions followed by a query's check early return, the chain of sessions with identity maps all the way up to the root session.
getParentInterfaceNames() - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
 
getParentInterfaces() - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Return the list of parent interfaces.
getParentMapping() - Method in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
INTERNAL:
getParentObjectForField(DatabaseField, Object) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the base value that is mapped to for given field.
getParentRecord() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getParentRecord() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getParentRecord() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
INTERNAL
getParentResultIndex() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
 
getParentSessionController() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
INTERNAL: Method returns the parent RemoteSessionController for this Remote UnitOfWork Used to retrieve Valueholders that were used on the client
getParentStatement() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Return the parent statement if using subselects.
getParentType() - Method in interface org.eclipse.persistence.dynamic.DynamicType
 
getParentType() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getParser() - Method in class org.eclipse.persistence.oxm.json.JsonParserSource
 
getPartialAttributeExpressions() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the partial attributes to select.
getPartialAttributeSelectionFields(boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the fields required in the select clause, for patial attribute reading.
getPartitionField() - Method in class org.eclipse.persistence.descriptors.partitioning.FieldPartitioningPolicy
PUBLIC: Return the database column or query parameter to partition queries by.
getPartitionFieldName() - Method in class org.eclipse.persistence.descriptors.partitioning.FieldPartitioningPolicy
PUBLIC: Return the database column or query parameter to partition queries by.
getPartitionID() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: Get Partition ID.
getPartitionID() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
 
getPartitionID() - Method in class org.eclipse.persistence.platform.server.wls.WebLogic_12_Platform
 
getPartitioningCallback() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return callback.
getPartitioningCallback() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return callback.
getPartitioningClasName() - Method in class org.eclipse.persistence.descriptors.partitioning.CustomPartitioningPolicy
 
getPartitioningPolicies() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return the map of partitioning policies, keyed by name.
getPartitioningPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the descriptor's partitioning policy.
getPartitioningPolicy() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the session's partitioning policy.
getPartitioningPolicy() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Return the mapping's partitioning policy.
getPartitioningPolicy() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return the query's partitioning policy.
getPartitioningPolicy() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the session's partitioning policy.
getPartitioningPolicy(String) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return the partitioning policies for the name.
getPartitioningPolicyName() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the name of the descriptor's partitioning policy.
getPartitioningPolicyName() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Return the name of the mapping's partitioning policy.
getPartitionName() - Method in class org.eclipse.persistence.platform.server.wls.WebLogic_12_Platform
 
getPartitions() - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartitioningPolicy
PUBLIC: Return the range partitions.
getPartitions() - Method in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
PUBLIC: Return the value partitions.
getPassword() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
This method will return the decrypted password.
getPassword() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
This method will return the decrypted password.
getPassword() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
PUBLIC: Return the password used as the value to the SECURITY_CREDENTIALS key in the cached context properties.
getPassword() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
Return the password.
getPassword() - Method in interface org.eclipse.persistence.sessions.Login
PUBLIC: All logins must take a user name and password.
getPasswordFromProperties(Properties) - Method in class org.eclipse.persistence.eis.EISConnectionSpec
INTERNAL: Retrieve the password property from the supplied Properties object
getPattern() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getPatterns() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getPatterns() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getPessimisticLockedObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL:
getPessimisticLockingPolicy() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
PUBLIC: Return the policy for bean pessimistic locking
getPessimisticLockTimeoutDefault() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Returns the default pessimistic lock timeout value.
getPessimisticLockTimeoutUnitDefault() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
 
getPingSQL() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for determining if an SQL exception was communication based.
getPingSQL() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getPingSQL() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink will attempt to test a connection if it encounters an exception on the connection when executing SQL.
getPKClass() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL:
getPKClassInstance() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL:
getPl2SQLName(ComplexDatabaseType) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
Return the conversion function name, generate the function if missing.
getPlatform() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return the platform.
getPlatform() - Method in class org.eclipse.persistence.internal.expressions.ExpressionJavaPrinter
 
getPlatform() - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
INTERNAL: Return the database platform specific information.
getPlatform() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the database platform currently connected to.
getPlatform() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Return the database platform currently connected to.
getPlatform() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
INTERNAL: Return the database platform currently connected to.
getPlatform() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Return the database platform specific information.
getPlatform() - Method in interface org.eclipse.persistence.sessions.Login
INTERNAL: Return the database platform specific information.
getPlatform() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the database platform currently connected to.
getPlatform(Class<?>) - Method in class org.eclipse.persistence.internal.core.sessions.CoreAbstractSession
INTERNAL: Return the database platform currently connected to for specified class.
getPlatform(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the database platform currently connected to for specified class.
getPlatform(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Return the database platform currently connected to for specified class.
getPlatform(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the platform for a particular class.
getPlatform(Class<?>) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Return the platform for a particular class.
getPlatformClass() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
getPlatformClassName() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Return the name of the database platform class.
getPlatformOperator(DatabasePlatform) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
getPlatformOperator(DatabasePlatform) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
getPlatformOperatorName(int) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Initialize a mapping to the platform operator names for usage with exceptions.
getPlatformOperatorNames() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Initialize a mapping to the platform operator names for usage with exceptions.
getPlatformOperators() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Return any platform-specific operators
getPlatformOperatorSelectors() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
 
getPolicy() - Method in class org.eclipse.persistence.descriptors.partitioning.CustomPartitioningPolicy
 
getPolicy() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Return the cursor policy.
getPolicy() - Method in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
getPool() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return the associated connection pool this connection was obtained from.
getPool() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return the associated connection pool this connection was obtained from.
getPoolName() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Return the pool name or null if not part of a pool.
getPoolsConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.ServerSessionConfig
 
getPosition() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Return the position of the stream inside the object collection.
getPosition() - Method in class org.eclipse.persistence.queries.CursoredStream
INTERNAL: Return the position of the stream inside the object collection
getPosition() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Retrieves the current cursor position (current row).
getPositionalNodes() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
getPositionalNodes() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
getPostBuildSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called after an object is built
getPostCloneSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called after an object is cloned
getPostDeleteSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called after an object is deleted
getPostInsertSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called after an object is inserted
getPostMergeSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called after an object is merged
getPostRefreshSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called after an object is refreshed
getPostUpdateSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called after an object is updated
getPostWriteSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called after an object is written
getPreallocationSize() - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequenceConfig
 
getPreallocationSize() - Method in class org.eclipse.persistence.sequencing.DefaultSequence
 
getPreallocationSize() - Method in class org.eclipse.persistence.sequencing.Sequence
 
getPrecision() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Returns the precision for a decimal column when generating DDL.
getPredecessor() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
getPreDeclaredNamespaceUris() - Method in class org.eclipse.persistence.internal.oxm.NamespacePrefixMapper
Returns a list of namespace uris that should be declared at the root of the xml document being marshalled.
getPreDeclaredNamespaceUris() - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.MapNamespacePrefixMapper
 
getPreDeclaredNamespaceUris() - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.NamespacePrefixMapperWrapper
 
getPreDeclaredNamespaceUris2() - Method in class org.eclipse.persistence.internal.oxm.NamespacePrefixMapper
Returns a string array of prefixes and namespace uris to be declared at the root of the document.
getPreDeclaredNamespaceUris2() - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.NamespacePrefixMapperWrapper
 
getPreDeleteMappings() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set of mappings that require early delete behavior.
getPreDeleteSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called before an object is deleted
getPredicate() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getPreferredPrefix(String, String, boolean) - Method in class org.eclipse.persistence.internal.oxm.NamespacePrefixMapper
 
getPreferredPrefix(String, String, boolean) - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.MapNamespacePrefixMapper
 
getPreferredPrefix(String, String, boolean) - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.NamespacePrefixMapperWrapper
 
getPrefetchedCacheKeys() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
 
getPrefix() - Method in class org.eclipse.persistence.internal.mappings.converters.AttributeNameTokenizer.TokensIterator
INTERNAL: Get attribute name prefix.
getPrefix() - Method in class org.eclipse.persistence.internal.oxm.Namespace
 
getPrefix() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getPrefix() - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
 
getPrefix(String) - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.StackUnmarshalNamespaceResolver
 
getPrefix(String) - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceContext
 
getPrefix(String) - Method in interface org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceResolver
Return the prefix for the specified namesapce URI at the current scope.
getPrefix(NamespaceContext, Element, String) - Method in class org.eclipse.persistence.internal.oxm.record.DomToXMLStreamWriter
 
getPrefixBytes() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getPrefixBytes(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
getPrefixedPropertyValue(String, String, Map) - Static method in class org.eclipse.persistence.internal.sessions.PropertiesHandler
INTERNAL: Gets property value from the map, if none found looks in System properties.
getPrefixes() - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
Returns the list of prefixes in the NamespaceResolver
getPrefixes() - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.StackUnmarshalNamespaceResolver
 
getPrefixes() - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceContext
 
getPrefixes() - Method in interface org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceResolver
Return the set of prefixes currently associated with a namespace URI.
getPrefixesForFragment() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getPrefixesForFragment() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
INTERNAL Returns a Map of any prefix mappings that were made before the most recent start element event.
getPrefixesForFragment() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getPrefixesToNamespaces() - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
 
getPrefixForFragment(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
getPrefixMapper() - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.NamespacePrefixMapperWrapper
 
getPrefixMapper() - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.PrefixMapperNamespaceResolver
 
getPrefixValues(String, Map) - Static method in class org.eclipse.persistence.internal.sessions.PropertiesHandler
INTERNAL: Gets properties' values from the map, if none found looks in System properties.
getPrefixValuesLogDebug(String, Map, AbstractSession) - Static method in class org.eclipse.persistence.internal.sessions.PropertiesHandler
 
getPreInsertSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called before an object is inserted
getPrePersistSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called before the create operation is applied to an object
getPreRemoveSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called before the remove operation is applied to an object
getPreUpdateSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called before an object is updated
getPrevCustomizer() - Method in class org.eclipse.persistence.internal.databaseaccess.ConnectionCustomizer
INTERNAL:
getPrevious() - Method in class org.eclipse.persistence.internal.identitymaps.LinkedCacheKey
 
getPreviousCall() - Method in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
 
getPreviousLevel() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
getPreviousObject() - Method in class org.eclipse.persistence.queries.ScrollableCursor
 
getPreWriteSelector() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: The name of the method called before an object is written
getPrimaryKey() - Method in class org.eclipse.persistence.internal.identitymaps.CacheId
 
getPrimaryKey() - Method in class org.eclipse.persistence.internal.oxm.Reference
Return the list of primary key values required to lookup the reference class in the cache.
getPrimaryKey() - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Return the primaryKey.
getPrimaryKey() - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
INTERNAL: Get the primary key for the query
getPrimaryKeyClassifications() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return primary key classifications.
getPrimaryKeyDescriptor() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
Return the descriptor for whichever side of the relation has the "primary key".
getPrimaryKeyExpression() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the primary key expression
getPrimaryKeyFieldNames() - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
PUBLIC: Return the names of all the primary keys.
getPrimaryKeyFieldNames() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the names of all the primary keys.
getPrimaryKeyFieldNames() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Return the names of all the primary keys.
getPrimaryKeyFieldNames() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
getPrimaryKeyFieldNames() - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC:
getPrimaryKeyFields() - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
INTERNAL: Return all the primary key fields
getPrimaryKeyFields() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return all the primary key fields
getPrimaryKeyFields() - Method in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
getPrimaryKeyFields() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: Return all the primary key fields
getPrimaryKeyFieldsForAutoJoin() - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
getPrimaryKeyFieldsForTable(ClassDescriptor, DatabaseTable) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
getPrimaryKeyFieldsForTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
getPrimaryKeyForObject(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL:
getPrimaryKeyForObject(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL:
getPrimaryKeyIdValidations() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Return what types are allowed in each primary key field (id).
getPrimaryKeyMap() - Method in class org.eclipse.persistence.internal.oxm.Reference
Return the map of primary key/values required to lookup the reference class in the cache.
getPrimaryKeyMappings() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return primary key mappings.
getPrimaryKeyMappings() - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
getPrimaryNamespace() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
getPrimaryNamespace() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
getPrimaryNamespace() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
getPrimaryNamespacePrefix() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
getPrimaryNamespacePrefix() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
getPrimaryNamespacePrefix() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
getPrimaryNamespaceXPath() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
getPrimaryPrefix() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolverWithPrefixes
 
getPrimaryProject() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.DatabaseSessionConfig
 
getPrimitiveClass(String) - Static method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Returns a class based on the passed in string.
getPrimitiveType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the primitive for the specified wrapper class.
getPrivateOwnedCriteria() - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: The private owned criteria is only used outside of the unit of work to compare the previous value of the reference.
getPrivateOwnedCriteria() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: The private owned criteria is only used outside of the unit of work to compare the previous value of the reference.
getProcedureArgument(String, Object, DatasourceCall.ParameterType, StoredProcedureCall, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Obtain the platform specific argument string
getProcedureArgument(String, Object, DatasourceCall.ParameterType, StoredProcedureCall, AbstractSession) - Method in class org.eclipse.persistence.platform.database.DB2Platform
Obtain the platform specific argument string
getProcedureArgument(String, Object, DatasourceCall.ParameterType, StoredProcedureCall, AbstractSession) - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
 
getProcedureArgument(String, Object, DatasourceCall.ParameterType, StoredProcedureCall, AbstractSession) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
 
getProcedureArgumentNames() - Method in class org.eclipse.persistence.queries.StoredProcedureCall
INTERNAL: The if the names are provide the order is not required to match the call def.
getProcedureArgumentString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for sp defs.
getProcedureArgumentString() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Pervasive uses ":" as prefix for procedure arguments.
getProcedureArgumentString() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
Used for sp defs.
getProcedureArgumentString() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Used for sp defs.
getProcedureArgumentString() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Used for sp defs.
getProcedureAsString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for stored procedure defs.
getProcedureAsString() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Used for stored procedure defs.
getProcedureAsString() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
MySQL does not use the AS token.
getProcedureAsString() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
getProcedureAsString() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Symfoware does not use the AS token.
getProcedureBeginString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for stored procedure defs.
getProcedureBeginString() - Method in class org.eclipse.persistence.platform.database.DB2Platform
Used for stored procedure defs.
getProcedureBeginString() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Used for stored procedure defs.
getProcedureBeginString() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL requires BEGIN.
getProcedureBeginString() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Pervasive requires BEGIN in a procedure statement.
getProcedureBeginString() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Used for sp calls.
getProcedureBeginString() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
getProcedureBeginString() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Used for stored procedure definitions.
getProcedureCallHeader() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for sp calls.
getProcedureCallHeader() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Used for sp calls.
getProcedureCallHeader() - Method in class org.eclipse.persistence.platform.database.H2Platform
INTERNAL: Used for stored procedure calls.
getProcedureCallHeader() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
getProcedureCallHeader() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Used for stored procedure calls.
getProcedureCallHeader() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Used for sp calls.
getProcedureCallHeader() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Pervasive uses CALL or EXECUTE not CALL PROCEDURE or EXECUTE PROCEDURE
getProcedureCallHeader() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
Used for sp calls.
getProcedureCallHeader() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Used for sp calls.
getProcedureCallHeader() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Used for sp calls.
getProcedureCallHeader() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Used for stored procedure calls.
getProcedureCallTail() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for sp calls.
getProcedureCallTail() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
Used for sp calls.
getProcedureCallTail() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
Used for sp calls.
getProcedureCallTail() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Used for sp calls.
getProcedureCallTail() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
getProcedureCallTail() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Used for stored procedure calls.
getProcedureEndString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for stored procedure defs.
getProcedureEndString() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Used for stored procedure defs.
getProcedureEndString() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Used for stored procedure defs.
getProcedureEndString() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL requires END.
getProcedureEndString() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Pervasive requires END in a procedure statement.
getProcedureEndString() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Used for sp calls.
getProcedureEndString() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
getProcedureEndString() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Used for stored procedure definitions.
getProcedureName() - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Return the name of the store procedure on the database.
getProcedureOptionList() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Some platforms have an option list Only to be used for stored procedure creation.
getProcedureOptionList() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
DB2 on Z uses ":" as prefix for procedure arguments.
getProcedures() - Method in class org.eclipse.persistence.tools.schemaframework.PackageDefinition
Packages can contain sets of procedures.
getProcessContents() - Method in class org.eclipse.persistence.internal.oxm.schema.model.AnyAttribute
 
getProduct() - Static method in class org.eclipse.persistence.Version
 
getProfiler() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the profiler.
getProfiler() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
getProfiler() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the profiler.
getProfiles() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
Return the profiles logged in this profiler.
getProfileTime() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
getProfileTime() - Method in class org.eclipse.persistence.tools.profiler.Profile
 
getProfileWeight() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Return the DMS sensor weight
getProfileWeight() - Method in class org.eclipse.persistence.services.RuntimeServices
Return the DMS sensor weight
getProfileWeight() - Method in interface org.eclipse.persistence.sessions.SessionProfiler
INTERNAL: Return DMS sensor weight(DMS)
getProfileWeight() - Method in class org.eclipse.persistence.sessions.SessionProfilerAdapter
INTERNAL: Return DMS sensor weight(DMS)
getProfileWeight() - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
Return the level of profiling.
getProfileWeight() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
getProfilingType() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to get the type of profiling.
getProfilingType() - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to get the type of profiling.
getProject() - Method in interface org.eclipse.persistence.core.sessions.CoreSession
PUBLIC: Return the project.
getProject() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the project, the project holds configuartion information including the descriptors.
getProject() - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Return the project to generate from.
getProject() - Static method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
Cache the creation and initialization of the Session XML mapping project.
getProject() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the project.
getProjectString() - Method in class org.eclipse.persistence.internal.sessions.factories.model.project.ProjectConfig
 
getProperties() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Returns the user defined properties.
getProperties() - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
Returns the adapter specific properties.
getProperties() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Return a properties object for a given instance of the XMLUnmarshaller.
getProperties() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Allow for user defined properties.
getProperties() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: used as a temporary store for custom SDK usage
getProperties() - Method in class org.eclipse.persistence.oxm.XMLMarshaller
Return a properties object for a given instance of the XMLMarshaller.
getProperties() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Property support for use by mappings.
getProperties() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: The properties are additional, driver-specific, connection information to be passed to the driver.
getProperties() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
ADVANCED: This method will return the collection of custom properties set on the Connection policy.
getProperties() - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Allow for user defined properties.
getProperties() - Method in class org.eclipse.persistence.sessions.SessionEvent
PUBLIC: Additional properties may be added to the event.
getProperties(String) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGeneratorProperties
Return the Properties object for the given namespace uri.
getPropertiesMap() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
Gets the properties map.
getPropertiesMap() - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGeneratorProperties
Lazily initialize the URI->Properties map
getPropertiesNames() - Method in interface org.eclipse.persistence.dynamic.DynamicType
The current names of properties.
getPropertiesNames() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getProperty(Object) - Method in class org.eclipse.persistence.internal.oxm.Marshaller
Return the property for a given key, if one exists.
getProperty(Object) - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Return the property for a given key, if one exists.
getProperty(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Return the property for a given key, if one exists.
getProperty(Object) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: Allow user defined properties.
getProperty(Object) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Property support used by mappings to store temporary stuff in the query.
getProperty(Object) - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Returns the property associated with the corresponding key.
getProperty(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Returns the descriptor property associated the given String.
getProperty(String) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: Returns the adapter property associated the given name.
getProperty(String) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
getProperty(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
getProperty(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
getProperty(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Returns the user defined property.
getProperty(String) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Search for and return the user defined property from this UOW, if it not found then search for the property from parent.
getProperty(String) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: The properties are additional, driver-specific, connection information to be passed to the driver.
getProperty(String) - Method in interface org.eclipse.persistence.sessions.Login
PUBLIC: The properties are additional, driver-specific, connection information to be passed to the driver.
getProperty(String) - Method in class org.eclipse.persistence.sessions.server.ClientSession
Search for and return the user defined property from this client session, if it not found then search for the property from parent.
getProperty(String) - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Returns the user defined property.
getProperty(String) - Method in class org.eclipse.persistence.sessions.SessionEvent
PUBLIC: Additional properties may be added to the event.
getProperty(String, String) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
getProperty(String, String) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGeneratorProperties
Return the property value for a given namespace/key pair.
getProperty(DatabaseField) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression representing a property with the given name.
getPropertyConfigs() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
getPropertyConfigs() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
 
getPropertyIndex(String) - Method in interface org.eclipse.persistence.dynamic.DynamicType
 
getPropertyIndex(String) - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getPropertyNames() - Method in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
 
getPropertyType(int) - Method in interface org.eclipse.persistence.dynamic.DynamicType
 
getPropertyType(int) - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getPropertyType(String) - Method in interface org.eclipse.persistence.dynamic.DynamicType
 
getPropertyType(String) - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
getPropertyValue(String, String) - Static method in class org.eclipse.persistence.internal.sessions.PropertiesHandler
INTERNAL: Given property name and value verifies and translates the value.
getPropertyValue(String, Map) - Static method in class org.eclipse.persistence.internal.sessions.PropertiesHandler
INTERNAL: Gets property value from the map, if none found looks in System properties.
getPropertyValue(String, Map, boolean) - Static method in class org.eclipse.persistence.internal.sessions.PropertiesHandler
 
getPropertyValueLogDebug(String, String, AbstractSession) - Static method in class org.eclipse.persistence.internal.sessions.PropertiesHandler
 
getPropertyValueLogDebug(String, Map, AbstractSession) - Static method in class org.eclipse.persistence.internal.sessions.PropertiesHandler
 
getPropertyValueLogDebug(String, Map, AbstractSession, boolean) - Static method in class org.eclipse.persistence.internal.sessions.PropertiesHandler
 
getProtectedForeignKeys() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
INTERNAL: Return the FK cache
getProtectedForeignKeys() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
getProxy(Class<A>, Object) - Static method in class org.eclipse.persistence.internal.oxm.CycleRecoverableContextProxy
 
getPublicId() - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.LocatorImpl
 
getPublicMethod(Class<?>, String, Class<?>[], boolean) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get a public method declared in the given class.
getPublisher() - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
 
getQName(int) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
getQName(int) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
getQName(Element) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
getQualified(String) - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL:
getQualifiedFieldName() - Method in class org.eclipse.persistence.mappings.querykeys.DirectQueryKey
PUBLIC: Return the qualified field name for the query key.
getQualifiedName() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
getQualifiedName() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
getQualifiedName(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
getQualifiedName(DatasourcePlatform) - Method in class org.eclipse.persistence.internal.expressions.NestedTable
INTERNAL:
getQualifiedNameDelimited(DatasourcePlatform) - Method in class org.eclipse.persistence.internal.expressions.NestedTable
INTERNAL:
getQualifiedNameDelimited(DatasourcePlatform) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Return the qualified name of the field.
getQualifiedNameDelimited(DatasourcePlatform) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
getQualifiedSequenceTableName() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
getQualifiedTableName() - Method in class org.eclipse.persistence.sequencing.TableSequence
 
getQualifier() - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL:
getQualifier() - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
PUBLIC: Most major databases support a creator name scope.
getQualifier() - Static method in class org.eclipse.persistence.Version
 
getQueries() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Return the pre-defined queries for the descriptor.
getQueries() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Return all pre-defined queries.
getQueries() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: List of queries that upon initialization are copied over to the session
getQueries() - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Return all pre-defined queries.
getQuery() - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
PUBLIC: The query causing the event.
getQuery() - Method in exception org.eclipse.persistence.exceptions.DatabaseException
PUBLIC: This method returns the databaseQuery.
getQuery() - Method in exception org.eclipse.persistence.exceptions.OptimisticLockException
PUBLIC: Return the query in which the problem was detected.
getQuery() - Method in exception org.eclipse.persistence.exceptions.QueryException
PUBLIC: Return the query in which the problem was detected.
getQuery() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Back reference to query, unfortunately required for events.
getQuery() - Method in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
INTERNAL:
getQuery() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Query held as it may store properties needed to generate the SQL
getQuery() - Method in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
Return the query.
getQuery() - Method in class org.eclipse.persistence.internal.jpa.jpql.ConstructorQueryMappings
Returns the DatabaseQuery for which its JPQL query was scanned to check if it's constructor query and if so, to gather the information.
getQuery() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Return the query that uses the mechanism.
getQuery() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Return the associated query.
getQuery() - Method in class org.eclipse.persistence.internal.sessions.remote.Transporter
Return the query associated with this transporter.
getQuery() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Return the query associated with the stream.
getQuery() - Method in class org.eclipse.persistence.queries.CursorPolicy
INTERNAL: Return the query.
getQuery() - Method in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
INTERNAL: Return the query.
getQuery() - Method in class org.eclipse.persistence.queries.JPQLCall
Back reference to query, unfortunately required for events.
getQuery() - Method in class org.eclipse.persistence.sessions.SessionEvent
PUBLIC: Some events may have a query associated with them (pre/postExecuteQuery).
getQuery(String) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Return the query name from the set of pre-defined queries If only one query exists with this name, it will be returned.
getQuery(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the query from the session pre-defined queries with the given name.
getQuery(String) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Return the query from the session pre-defined queries with the given name.
getQuery(String) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Was PUBLIC: customer will be redirected to Session.
getQuery(String) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the query from the session pre-defined queries with the given name.
getQuery(String, List) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the query from the session pre-defined queries with the given name and argument types.
getQuery(String, List) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the query from the session pre-defined queries with the given name.
getQuery(String, Vector) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Return the query from the set of pre-defined queries with the given name and argument types.
getQuery(String, Vector) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the query from the session pre-defined queries with the given name and argument types.
getQuery(String, Vector) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Return the query from the session pre-defined queries with the given name.
getQuery(String, Vector) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL:
getQuery(String, Vector, boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the query from the session pre-defined queries with the given name and argument types.
getQuery(String, Vector, boolean) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Return the query from the session pre-defined queries with the given name and argument types.
getQueryArgumentsRecord() - Method in exception org.eclipse.persistence.exceptions.DatabaseException
PUBLIC: Return the query arguments used in the original query when exception is thrown
getQueryArgumentsRecord() - Method in exception org.eclipse.persistence.exceptions.QueryException
PUBLIC: Return the query argements used in the original query when exception is thrown
getQueryBuilder() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL Return the query builder used to parser JPQL.
getQueryByExamplePolicy() - Method in class org.eclipse.persistence.internal.queries.QueryByExampleMechanism
PUBLIC: When using Query By Example, an instance of QueryByExamplePolicy is used to customize the query.
getQueryByExamplePolicy() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: When using Query By Example, an instance of QueryByExamplePolicy is used to customize the query.
getQueryClass() - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL:
getQueryClass() - Method in class org.eclipse.persistence.tools.profiler.Profile
 
getQueryExpressions() - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: return a collection of expressions if PK's are used.
getQueryFromParent(String, Vector) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: CR#3711: Check if the class for this descriptor has a parent class.
getQueryId() - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: This method is used to get the time in millis that this query is being executed at.
getQuerykeyExpression() - Method in class org.eclipse.persistence.internal.expressions.NestedTable
 
getQueryKeyNamed(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return the query key with the specified name
getQueryKeyOrNull() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
getQueryKeyOrNull() - Method in class org.eclipse.persistence.internal.expressions.FromAliasExpression
INTERNAL: If a descriptor cannot be found, then return null.
getQueryKeyOrNull() - Method in class org.eclipse.persistence.internal.expressions.ManualQueryKeyExpression
 
getQueryKeyOrNull() - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
 
getQueryKeyOrNull() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
getQueryKeys() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the query keys.
getQueryManager() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the queryManager.
getQueryManager(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
Convenience method
getQueryMechanism() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the mechanism assigned to the query
getQueryNounName(String) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: TopLink_sessionName_domainClass_queryClass_queryName (if exist).
getQueryPrimaryKey() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Return the primary key stored in this query if there is one This is overridden by subclasses that actually hold a primary key
getQueryPrimaryKey() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Return the primary key stored in this query
getQueryResult(ReadQuery, List, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Get the cached results associated with a query.
getQueryResult(ReadQuery, List, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Get the cached results associated with a query.
getQueryResult(ReadQuery, List, boolean) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Get the cached results associated with a query.
getQueryResult(ReadQuery, List, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
INTERNAL: Get the cached results associated with a query.
getQueryResults(AbstractSession) - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: To any user of this object with some knowledge of what the query's results may contain.
getQueryResults(AbstractSession, boolean) - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: To any user of this object with some knowledge of what the query's results may contain.
getQueryResults(AbstractSession, AbstractRecord, boolean) - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: To any user of this object with some knowledge of what the query's results may contain.
getQueryResultsCachePolicy() - Method in class org.eclipse.persistence.queries.ReadQuery
PUBLIC: Return the QueryResultsCachePolicy for this query.
getQueryRetryAttemptCount() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getQueryRetryAttemptCount() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return the number of attempts EclipseLink should make to re-connect to a database and re-execute a query after a query has failed because of a communication issue.
getQueryString() - Method in class org.eclipse.persistence.eis.interactions.QueryStringInteraction
PUBLIC: Return the query string.
getQueryString() - Method in class org.eclipse.persistence.eis.interactions.XQueryInteraction
INTERNAL: Return the query string.
getQueryString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Return the query string (SQL) of the call.
getQueryString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Return the query string of the call.
getQueryString() - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
Return the query string of the call.
getQueryTimeout() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Return the number of seconds queries will wait for their Statement to execute.
getQueryTimeout() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Get timeout limit from the call
getQueryTimeout() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return the number of seconds the driver will wait for a Statement to execute to the given number of seconds.
getQueryTimeoutDefault() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the default query timeout for this session.
getQueryTimeoutUnit() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
getQueryTimeoutUnit() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return the unit of time the driver will wait for a Statement to execute.
getQueryTimeoutUnitDefault() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
 
getQueueNode() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTENRAL: Used to get the node that this merge manager is stored in, within the WriteLocksManager write lockers queue
getReadAllCall() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's read-all call.
getReadAllQuery() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's read query.
getReadAllSQLString() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's read SQL string.
getReadAllSubclassesView() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: The view can be used to optimize/customize the query for all subclasses where they have multiple tables.
getReadAllSubclassesViewName() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: The view can be used to optimize/customize the query for all subclasses where they have multiple tables.
getReadConnectionPool() - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Handles allocating connections for read queries.
getReadConnectionPool() - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return the read connection pool.
getReadConnectionPoolConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.PoolsConfig
 
getReader() - Method in class org.eclipse.persistence.internal.oxm.ByteArraySource
 
getReader() - Method in class org.eclipse.persistence.tools.PackageRenamer
 
getReadLockGlobalAcquisitionNumber() - Method in class org.eclipse.persistence.internal.helper.type.ReadLockAcquisitionMetadata
getReadLockManager(Thread) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
The method is not synchronized because for now we assume that each thread will ask for its own lock manager.
getReadLockManagerEnsureResultIsNotNull(Thread) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Same as ConcurrencyManager.getReadLockManager(Thread) but in this case a not null result is ensured
getReadLockManagerMapClone() - Method in class org.eclipse.persistence.internal.helper.type.ConcurrencyManagerState
getReadLockManagers() - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Return the deferred lock manager hashtable (thread - DeferredLockManager).
getReadLocks() - Method in class org.eclipse.persistence.internal.helper.ReadLockManager
Return a set of the deferred locks
getReadLogin() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Return the login for the read connection.
getReadLogin() - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Return the login for the read connection.
getReadObjectCall() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's read-object call.
getReadObjectQuery() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's read query.
getReadObjectQuery() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Convenience method
getReadObjectSQLString() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's read SQL string.
getReadOnlyClasses() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Returns the set of read-only classes in this UnitOfWork.
getReadOnlyClasses() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Returns the set of read-only classes in this UnitOfWork.
getReadOnlyMappingsByField() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Return all the read-only mapping to field associations
getReadOnlyMappingsForField(DatabaseField) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return all the read-only mapping for the specified field.
getReadQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Get custom read query from query manager.
getReadQuery() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Get custom all read query from query manager.
getReadQuery() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Get custom single object read query from query manager.
getReadSession(Class<?>) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Return the session corresponding to this class.
getReadSession(Object) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Return the session corresponding to this object.
getReadSession(XMLDescriptor) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Return the session corresponding to this XMLDescriptor.
getReadStatementsCount() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return the number of read statements.
getReadTime() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
INTERNAL: Return the current value of the Read Time variable
getReadTime() - Method in class org.eclipse.persistence.internal.sessions.remote.ObjectDescriptor
Return the read time of the associated object
getReadTime() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
INTERNAL: Return the current value of the Read Time variable
getRealAttributeValueFromAttribute(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return the value of an attribute unwrapping value holders if required.
getRealAttributeValueFromAttribute(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Returns the attribute value from the reference object.
getRealAttributeValueFromAttribute(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Returns the real attribute value from the reference object's attribute value.
getRealAttributeValueFromAttribute(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Object reference must unwrap the reference object if required.
getRealAttributeValueFromObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return the "real" attribute value, as opposed to any wrapper.
getRealAttributeValueFromObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return the "real" attribute value, as opposed to any wrapper.
getRealAttributeValueFromObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return the "real" attribute value, as opposed to any wrapper.
getRealAttributeValueFromObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return the "real" attribute value, as opposed to any wrapper.
getRealAttributeValueFromObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Return the "real" attribute value, as opposed to any wrapper.
getRealAttributeValueFromObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the "real" attribute value, as opposed to any wrapper.
getRealAttributeValueFromObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
Return the "real" attribute value, as opposed to any wrapper.
getRealAttributeValueFromObject(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return the value of an attribute unwrapping value holders if required.
getRealCollectionAttributeValueFromObject(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
Convenience method.
getRealCollectionAttributeValueFromObject(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return the value of an attribute, unwrapping value holders if necessary.
getRealCollectionAttributeValueFromObject(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Convenience method.
getRealCollectionAttributeValueFromObject(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Convenience method.
getRealCollectionAttributeValueFromObject(Object, AbstractSession) - Method in interface org.eclipse.persistence.mappings.structures.ArrayCollectionMapping
Return the attribute value from the specified object, unwrapping the value holder if necessary.
getRecord() - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
PUBLIC: Return the record that is associated with some events, such as postBuild, and aboutToUpdate.
getRecord() - Method in class org.eclipse.persistence.eis.EISDOMRecord
Return the JCA adapter record.
getRecord() - Method in class org.eclipse.persistence.eis.EISMappedRecord
Return the wrapped record.
getRecord() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
getRecord() - Method in class org.eclipse.persistence.internal.sessions.TransformationMappingChangeRecord
ADVANCED: This method is used to access the changes of the fields in a transformation mapping.
getRecord() - Method in interface org.eclipse.persistence.sessions.changesets.TransformationMappingChangeRecord
ADVANCED: This method is used to access the changes of the fields in a transformation mapping.
getRecord() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
getRecordConverter() - Method in class org.eclipse.persistence.eis.EISPlatform
Return the record converter.
getRecordFactory() - Method in class org.eclipse.persistence.eis.EISAccessor
Return the RecordFactory.
getRecordName() - Method in class org.eclipse.persistence.eis.EISDOMRecord
Forward to the record.
getRecordShortDescription() - Method in class org.eclipse.persistence.eis.EISDOMRecord
Forward to the record.
getRedirector() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return the query redirector.
getRedirectorForQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return the query redirector.
getRef() - Method in class org.eclipse.persistence.internal.oxm.schema.model.AttributeGroup
 
getRef() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
getRef() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
getRef(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Get the ref for the object.
getRefContentHandler() - Method in class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
getReference(Class<?>, Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Get an instance, whose state may be lazily fetched.
getReference(Class<?>, Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
Get an instance, whose state may be lazily fetched.
getReference(ObjectReferenceMapping, Object) - Method in class org.eclipse.persistence.internal.oxm.ReferenceResolver
Retrieve the reference for a given mapping instance.
getReference(ObjectReferenceMapping, Object, Field) - Method in class org.eclipse.persistence.internal.oxm.ReferenceResolver
Return a reference for the given mapping and source object, that doesn't already contain an entry for the provided field.
getReferenceCache() - Method in class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap
Return the linked reference cache.
getReferenceCache() - Method in class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap.ReferenceCacheKey
 
getReferenceCacheNode() - Method in class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap.ReferenceCacheKey
 
getReferenceClass() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
getReferenceClass() - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
PUBLIC: Returns the reference class
getReferenceClass() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ObjectReferenceMapping
 
getReferenceClass() - Method in class org.eclipse.persistence.mappings.AggregateMapping
PUBLIC: Returns the reference class
getReferenceClass() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: This cannot be used with direct collection mappings.
getReferenceClass() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Returns the reference class.
getReferenceClass() - Method in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
PUBLIC: Return the reference class of the relationship.
getReferenceClass() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return the domain class associated with this query.
getReferenceClass() - Method in class org.eclipse.persistence.queries.DoesExistQuery
Return the domain class associated with this query.
getReferenceClass() - Method in class org.eclipse.persistence.queries.ModifyAllQuery
PUBLIC: Return the reference class for this query.
getReferenceClass() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
PUBLIC: Return the reference class of the query.
getReferenceClass() - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
Return the domain class associated with this query.
getReferenceClass() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Return the reference class of the query.
getReferenceClassName() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
getReferenceClassName() - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
 
getReferenceClassName() - Method in interface org.eclipse.persistence.internal.oxm.mappings.InverseReferenceMapping
 
getReferenceClassName() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ObjectReferenceMapping
INTERNAL:
getReferenceClassName() - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Used by MW.
getReferenceClassName() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
getReferenceClassName() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Returns the reference class name.
getReferenceClassName() - Method in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
PUBLIC: Return the reference class name of the relationship.
getReferenceClassName() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: return the name of the reference class.
getReferenceClassName() - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Return the name of the reference class for this query Note: Although the API is designed to avoid requirement of classes being on the classpath, this is not a user defined query type, so it is ok to access the class.
getReferenceClassName() - Method in class org.eclipse.persistence.queries.ModifyAllQuery
INTERNAL: Return the name of the reference class of the query.
getReferenceClassName() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Return the reference class of the query.
getReferenceClassName() - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
INTERNAL: Return the reference class for a query Note: Although the API is designed to avoid classpath dependencies for the MW, since the object is specified at runtime, this will not be an issue.
getReferenceClassName() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the reference class of the query.
getReferenceDescriptor() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
PUBLIC: Return the referenceDescriptor.
getReferenceDescriptor() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
 
getReferenceDescriptor() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Return the referenceDescriptor.
getReferenceDescriptor() - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Return the referenceDescriptor.
getReferenceDescriptor() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: Return the referenceDescriptor.
getReferenceDescriptor() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: There is none on direct collection.
getReferenceDescriptor() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return the referenceDescriptor.
getReferenceDescriptor() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Get the descriptor for this mapping This method is potentially called when this mapping is used as a map key and will return null since direct mappings do not have reference descriptors.
getReferenceDescriptor() - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Get the descriptor for the Map Key
getReferenceDescriptor(Class<?>, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: for inheritance purpose
getReferenceDescriptor(Class<?>, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: For inheritance purposes.
getReferenceDescriptor(Class<?>, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Since aggregate object mappings clone their descriptors, for inheritance the correct child clone must be found.
getReferenceDescriptor(Class<?>, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
getReferenceDescriptor(Class<?>, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
getReferenceDescriptor(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
Convenience method
getReferenceDescriptor(DOMRecord) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
getReferenceDescriptor(DOMRecord) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
getReferenceFields() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return the fields used to build the aggregate object.
getReferenceKeyFieldNames() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return the reference key field names associated with the mapping.
getReferenceKeyFields() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return the reference key fields.
getReferenceMode() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
getReferenceObjectKeys(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: get reference object keys
getReferenceResolver() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getReferenceResolver() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
INTERNAL: The ReferenceResolver that is leveraged by key based mappings.
getReferenceResolver() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: The ReferenceResolver that is leveraged by key based mappings.
getReferenceResolver() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getReferenceTable() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
Calculate the reference table for based on the various QueryKeyExpression usages (join query keys, custom defined query keys, or query keys for mappings).
getReferenceTable() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
getReferenceTable() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return the direct table.
getReferenceTable(ClassDescriptor) - Method in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
PUBLIC: Returns the reference table.
getReferenceTableName() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Returns the name of the reference table
getReferenceTableQualifiedName() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Returns the qualified name of the reference table.
getRefreshCascadePolicy() - Method in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
INTERNAL: Returns the refresh cascade policy that was set on the query that was used to instantiate the valueholder a null value means that a non refresh query was used.
getRefreshMetadataListener() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: This currently only used by JPA with RCM to force a refresh of the metadata used within EntityManagerFactoryWrappers
getRefValue(Ref, Connection) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Platforms that support java.sql.Ref may override this method.
getRefValue(Ref, AbstractSession, Connection) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: This method builds a REF using the unwrapped connection within the session
getRegisteredObjects() - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Return the registered objects.
getRelatedNodes() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
getRelationFieldForTargetField(DatabaseField) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Return the relation field for the target field.
getRelationshipMappings() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Return all relationship mappings.
getRelationshipPartner() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return the relationshipPartner mapping for this bi-directional mapping.
getRelationshipPartner() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return the relationshipPartner mapping for this bi-directional mapping.
getRelationshipPartner() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return the relationshipPartner mapping for this bi-directional mapping.
getRelationshipPartnerAttributeName() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Use this method retrieve the relationship partner attribute name of this bidirectional Mapping.
getRelationshipSourceObject() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
getRelationTable() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
Return null by default, only QueryKeyExpression can have a relation table.
getRelationTable() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
Calculate the relation table for based on the various QueryKeyExpression usages (join query keys, custom defined query keys, or query keys for mappings).
getRelationTable() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
Calculate the relation table for based on the various QueryKeyExpression usages (join query keys, custom defined query keys, or query keys for mappings).
getRelationTable() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Return the relation table associated with the mapping.
getRelationTable() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Return RelationTable.
getRelationTable() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Return the relation table associated with the mapping.
getRelationTable(ClassDescriptor) - Method in class org.eclipse.persistence.mappings.querykeys.DirectCollectionQueryKey
PUBLIC: Returns the reference table.
getRelationTable(ClassDescriptor) - Method in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
PUBLIC: Returns the relation table.
getRelationTable(ClassDescriptor) - Method in class org.eclipse.persistence.mappings.querykeys.ManyToManyQueryKey
PUBLIC: Returns the reference table.
getRelationTable(ClassDescriptor) - Method in class org.eclipse.persistence.mappings.querykeys.OneToManyQueryKey
PUBLIC: Returns the reference table.
getRelationTableMechanism() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Returns RelationTableMechanism that may be owned by the mapping.
getRelationTableMechanism() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Returns RelationTableMechanism that may be owned by the mapping, that allows to configure the mapping to use relation table (just like ManyToManyMapping).
getRelationTableName() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Return the relation table name associated with the mapping.
getRelationTableName() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Return the relation table name associated with the mapping.
getRelationTableQualifiedName() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Return the relation table qualified name associated with the mapping.
getRelationTableQualifiedName() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Return the relation table qualified name associated with the mapping.
getRemainingValidTime(Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Return the remaining life of this object.
getRemainingValidTime(Object) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Returns the remaining life of the given Object.
getRemainingValidTime(CacheKey) - Method in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
INTERNAL: Return the remaining life of this object
getRemainingValidTime(CacheKey) - Method in class org.eclipse.persistence.descriptors.invalidation.NoExpiryCacheInvalidationPolicy
INTERNAL: Return the remaining life of this object Override the default implementation.
getRemoteCommandManager() - Method in class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
INTERNAL: Returns the remote command manager
getRemoteCommandManager() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL:
getRemoteCommandManagerConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
getRemoteConnection() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Return the remote connection.
getRemoteContextProperties() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
ADVANCED: Return the cached properties that will be used to create the initial context when doing remote JNDI lookups.
getRemoteCursors() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
return the pre-remoted cursors
getRemoteHostContext(String) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Return the context used for looking up in the JNDI space of the specified remote URL.
getRemoteIdentityMapClass() - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Return the class of identity map to be used by this descriptor.
getRemoteIdentityMapClass() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return the class of identity map to be used by this descriptor.
getRemoteIdentityMapSize() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Return the size of the remote identity map.
getRemoteIdentityMapSize() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the size of the remote identity map.
getRemoteSessionController() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Return the remote session controller
getRemoteUnitOfWork() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
getRemoteValueHolders() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
INTERNAL: return the pre-serialized remote value holders
getRemovedElements() - Method in interface org.eclipse.persistence.indirection.IndirectCollection
INTERNAL: Return if the collection has any elements removed that have been deferred to instantiation.
getRemovedElements() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Return the elements that have been removed before instantiation.
getRemovedElements() - Method in class org.eclipse.persistence.indirection.IndirectMap
INTERNAL: Return the elements that have been removed before instantiation.
getRemovedElements() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Return the elements that have been removed before instantiation.
getRemovedObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The removed objects stores any newly registered objects removed during the nested unit of work.
getRemoveIndexes() - Method in class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
ADVANCED: Return the indexes into the old collection of the elements that were removed.
getRemoveIndexes() - Method in interface org.eclipse.persistence.sessions.changesets.EISOrderedCollectionChangeRecord
ADVANCED: Return the indexes into the old collection of the elements that were removed.
getRemoveObjectList() - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
PUBLIC: This method returns the Map that contains the removed values from the collection and their corresponding ChangeSets.
getRemoveObjectList() - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
ADVANCED: This method returns the list of removed objects.
getRemoveObjectList() - Method in interface org.eclipse.persistence.sessions.changesets.CollectionChangeRecord
ADVANCED: This method returns the Map that contains the removed values from the collection and their corresponding ChangeSets.
getRemoveObjectList() - Method in interface org.eclipse.persistence.sessions.changesets.DirectCollectionChangeRecord
ADVANCED: This method returns the collection of Primitive Objects that were removed to the collection.
getRemoveObjectMap() - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
This method returns the collection of objects that were removed from the collection.
getRemoveObjects() - Method in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
Returns the removed items list.
getRemoveReadLockProblemsDetected() - Method in class org.eclipse.persistence.internal.helper.ReadLockManager
getRemoves() - Method in class org.eclipse.persistence.eis.EISCollectionChangeRecord
ADVANCED: Return the removed stuff.
getRemoves() - Method in class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
ADVANCED: Return the entries for all the elements removed from the old collection.
getRemoves() - Method in interface org.eclipse.persistence.sessions.changesets.EISCollectionChangeRecord
ADVANCED: Return the removed objects.
getRemoves() - Method in interface org.eclipse.persistence.sessions.changesets.EISOrderedCollectionChangeRecord
ADVANCED: Return the entries for all the elements removed from the old collection.
getReplicateWrites() - Method in class org.eclipse.persistence.descriptors.partitioning.RoundRobinPartitioningPolicy
PUBLIC: Return if write queries should be replicated.
getReplicateWrites() - Method in class org.eclipse.persistence.descriptors.partitioning.UnionPartitioningPolicy
PUBLIC: Return if write queries should be replicated.
getReportItems() - Method in class org.eclipse.persistence.queries.ConstructorReportItem
 
getResource() - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
 
getResourceName() - Method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
getResourceName() - Method in exception org.eclipse.persistence.exceptions.StaticWeaveException
 
getResourceName() - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: Returns the resource name we are trying to load.
getResourcePath() - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
INTERNAL: Will return the the resource name with full path of the resource file.
getRestriction() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Content
 
getRestriction() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
getResult() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
The result set is stored for the return value of cursor selects.
getResult() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
getResult() - Method in class org.eclipse.persistence.internal.expressions.ExpressionIterator
 
getResult() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
Return the Result for this Schema.
getResult() - Method in interface org.eclipse.persistence.internal.oxm.UnmarshallerHandler
Returns the object that was unmarshalled from the SAX events.
getResult() - Method in class org.eclipse.persistence.oxm.XMLUnmarshallerHandler
Returns the object that was unmarshalled from the SAX events.
getResult() - Method in class org.eclipse.persistence.queries.ComplexQueryResult
PUBLIC: Return the result of the query.
getResult() - Method in class org.eclipse.persistence.sessions.SessionEvent
PUBLIC: Some events may have a result associated with them (pre/postExecuteQuery).
getResultIndex() - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
getResultKey() - Method in class org.eclipse.persistence.queries.ReportQueryResult
INTERNAL: Return the unique key for this result
getResults() - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Return the results.
getResults() - Method in class org.eclipse.persistence.queries.SQLResultSetMapping
Accessor for the internally stored list of ColumnResult.
getResultSet() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Return the result set (cursor).
getResultSetConcurrency() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
getResultSetConcurrency() - Method in class org.eclipse.persistence.queries.ScrollableCursorPolicy
PUBLIC: The ResultSetConcurrency specifies if the resultset is updatable.
getResultSetFetchSize() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
getResultSetType() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
getResultSetType() - Method in class org.eclipse.persistence.queries.ScrollableCursorPolicy
PUBLIC: The ResultSetType specifies if the resultset is sensitive to changes made by others.
getResultType() - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
getResultType() - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
getResultType() - Method in class org.eclipse.persistence.queries.DataReadQuery
Return the result type to be configured, MAP, ARRAY, VALUE, ATTRIBUTE (MAP is the default, DatabaseRecord).
getReturnFields() - Method in class org.eclipse.persistence.internal.expressions.SQLModifyStatement
 
getReturnFieldsToGenerateInsert() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return fields used to build insert statement.
getReturnFieldsToGenerateUpdate() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return fields used to build update statement.
getReturnFieldsToMergeInsert() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return fields used in to map into entity for insert.
getReturnFieldsToMergeUpdate() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return fields used in to map into entity for update.
getReturningPolicies() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return returning policy from current descriptor and from mappings
getReturningPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return returning policy.
getReturnsResultSet() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
ADVANCED: This method returns a value that represents if the customer has set whether or not EclipseLink should expect the stored procedure to returning a JDBC ResultSet.
getReturnType() - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
getReturnType() - Method in class org.eclipse.persistence.internal.codegen.ReflectiveMethodDefinition
 
getReturnType() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The return type is one of, NoReturn, ReturnOneRow or ReturnManyRows.
getReturnType() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Return the return type.
getReturnTypeClass() - Method in class org.eclipse.persistence.internal.codegen.ReflectiveMethodDefinition
 
getReuseContainer() - Method in interface org.eclipse.persistence.internal.oxm.ContainerValue
Return true if the original container on the object should be used if present.
getReuseContainer() - Method in interface org.eclipse.persistence.internal.oxm.mappings.XMLContainerMapping
Return true if a pre-initialized container already set on the field/property should be used.
getReuseContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
 
getReuseContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
getReuseContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
getReuseContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
getReuseContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
getReuseContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
 
getReuseContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
 
getReuseContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
getReuseContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
getReuseContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
 
getReuseContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
getReuseContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
Return true if the original container on the object should be used if present.
getReuseContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
Return true if the original container on the object should be used if present.
getReuseContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
Return true if the original container on the object should be used if present.
getReuseContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
Return true if the original container on the object should be used if present.
getReuseContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
Return true if the original container on the object should be used if present.
getReuseContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
Return true if the original container on the object should be used if present.
getReuseContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
Return true if the original container on the object should be used if present.
getReuseJMSTopicPublisher() - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
PUBLIC: flag used to toggle between j2EE/JMS spec compliant behavior and legacy behavior.
getRMIRegistryNamingServiceConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.RMITransportManagerConfig
 
getRootDescriptor() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This method returns the root descriptor for for this descriptor's class heirarchy.
getRootElementName() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getRootElementName() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
Return the root element's prefix qualified name
getRootElementName() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getRootElementNamespaceUri() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getRootElementNamespaceUri() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
Return the root element's namespace URI
getRootElementNamespaceUri() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getRootEntity() - Method in class org.eclipse.persistence.queries.FetchGroup
INTERNAL:
getRootParentDescriptor() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return the root parent descriptor
getRootSession(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: The session that this query is executed against when not in transaction.
getRootXPathNode() - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
getRootXPathNode() - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
getRootXPathNode() - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
getRow() - Method in class org.eclipse.persistence.internal.indirection.BackupValueHolder
 
getRow() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Return the row.
getRuntimeServicesMBean() - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
INTERNAL: Return the cached server specific services MBean
getScale() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Returns the scale for a decimal column when generating DDL.
getSchema() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Get the current schema.
getSchema() - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
getSchema() - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
getSchema() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
getSchema() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Include
 
getSchema() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
 
getSchema() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
getSchema() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
getSchema() - Method in class org.eclipse.persistence.oxm.XMLBinder
 
getSchema(String, NamespaceResolver, HashMap<String, Schema>, SchemaModelGeneratorProperties) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Return the Schema for a given namespace.
getSchemaContext() - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
Get the path to the simple/complex type definition, element or group to be referenced in the schema
getSchemaContext() - Method in interface org.eclipse.persistence.platform.xml.XMLSchemaReference
Returns the path to be traversed for validation purposes.
getSchemaContextAsQName() - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
 
getSchemaContextAsQName(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
INTERNAL:
getSchemaLocation() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getSchemaLocation() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getSchemaLocation() - Method in class org.eclipse.persistence.internal.oxm.Root
Gets the schema location which will be set on the XMLRoot during unmarshal.
getSchemaLocation() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Include
 
getSchemaLocation() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Get the schema location set on this XMLMarshaller
getSchemaLocation() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getSchemaReference() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Return the SchemaReference associated with this descriptor
getSchemaReference() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: Return the SchemaReference associated with this descriptor
getSchemaType() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Return the schema type associated with this field
getSchemaType() - Method in class org.eclipse.persistence.internal.oxm.Root
Gets the schema type.
getSchemaType() - Method in class org.eclipse.persistence.oxm.XMLField
Return the schema type associated with this field
getSchemaType() - Method in class org.eclipse.persistence.oxm.XMLUnionField
Return the first schema type in the list of schema types
getSchemaType(XMLField, Object, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
Return a QName representation the schema type for a given XMLField, if applicable.
getSchemaTypeForDirectMapping(DirectMapping, Schema) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Return the schema type for a given mapping's xmlfield.
getSchemaTypeForElement(Field, Class<?>, Schema) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Return the schema type for a given xmlfield.
getSchemaTypeForValue(Object, CoreAbstractSession) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
INTERNAL:
getSchemaTypeForValue(Object, CoreAbstractSession) - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL:
getSchemaTypeForValue(Object, CoreAbstractSession) - Method in class org.eclipse.persistence.oxm.XMLUnionField
 
getSchemaTypes() - Method in interface org.eclipse.persistence.internal.oxm.mappings.UnionField
Return the list of schema types
getSchemaTypes() - Method in class org.eclipse.persistence.oxm.XMLUnionField
Return the list of schema types
getSchemaTypeString(QName, Schema) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Return the schema type as a string for a given QName and Schema.
getSecondaryNamespace() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
getSecondaryNamespace() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
getSecondaryNamespace() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
getSecondaryNamespacePrefix() - Method in class org.eclipse.persistence.internal.sessions.factories.EclipseLinkObjectPersistenceRuntimeXMLProject
 
getSecondaryNamespacePrefix() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
getSecondaryNamespacePrefix() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
 
getSecondaryNamespaceXPath() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
getSecondaryPrefix() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolverWithPrefixes
 
getSecondChild() - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
getSecurableObject() - Method in class org.eclipse.persistence.internal.security.SecurableObjectHolder
 
getSecurableObjectHolder() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Return the encryption securable holder.
getSelectCall() - Method in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
getSelectCall() - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
getSelectCallForExist() - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
getSelectCallForExist() - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
getSelectCallForNotExist() - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
getSelectClause() - Method in class org.eclipse.persistence.tools.schemaframework.ViewDefinition
The select clause is the select statement that is mapped into the view.
getSelectFields() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Returns the set of fields that should be selected to build this mapping's value(s).
getSelectFields() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Returns the set of fields that should be selected to build this mapping's value(s).
getSelectForUpdateNoWaitString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This syntax does no wait on the lock.
getSelectForUpdateNoWaitString() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
getSelectForUpdateNoWaitString() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: This syntax does no wait on the lock.
getSelectForUpdateOfString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
For fine-grained pessimistic locking the column names can be specified individually.
getSelectForUpdateString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Most database support a syntax.
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.DB2MainframePlatform
INTERNAL: Used for pessimistic locking in DB2.
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Used for pessimistic locking in DB2.
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.DBasePlatform
 
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
 
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
WITH LOCK is required on FB to hold the lock.
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Informix seems to like this syntax instead of the OF * syntax.
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Used for pessimistic locking.
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
 
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Temporary workaround to avoid joined queries with FOR UPDATE in them
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Lock.
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Symfoware supports "for update" for row locking.
getSelectForUpdateString() - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
INTERNAL: Used for pessimistic locking.
getSelectForUpdateWaitString(Integer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Platforms that support the WAIT option should override this method.
getSelectForUpdateWaitString(Integer) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
 
getSelectionCriteria() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Return the selection criteria for the mechanism.
getSelectionCriteria() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return the selection criteria of the query.
getSelectionCriteria() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Return the selection criteria for the statement.
getSelectionCriteria() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Returns the selection criteria stored in the mapping selection query.
getSelectionCriteria() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return the selection criteria of the query.
getSelectionCriteriaClone() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: The clone of the selection criteria is needed for in-memory conforming each object read from the Cursor.
getSelectionFields() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return all selection fields
getSelectionFields() - Method in interface org.eclipse.persistence.descriptors.SerializedObjectPolicy
Lists the database fields that should be read by the query using the policy.
getSelectionFields() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
getSelectionFields() - Method in class org.eclipse.persistence.internal.descriptors.SerializedObjectPolicyWrapper
 
getSelectionFields() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the fields selected by the query.
getSelectionFields(SQLSelectStatement, boolean) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return the fields required in the select clause.
getSelectionFields(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return all selection fields
getSelectionFields(ReadQuery) - Method in class org.eclipse.persistence.expressions.Expression
 
getSelectionFields(ReadQuery) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL:
getSelectionFields(ReadQuery) - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
INTERNAL:
getSelectionFields(ReadQuery) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL:
getSelectionFields(ReadQuery) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL:
getSelectionId() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return Id of the object to be selected by the query.
getSelectionObject() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return the selection object of the query.
getSelectionQuery() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Returns the read query associated with the mapping.
getSelectionQueryContainerPolicy() - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Get the container policy from the selection query for this mapping.
getSelectionQueryContainerPolicy() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Get the container policy from the selection query for this mapping.
getSelector() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Return the selector id.
getSelectQuery() - Method in class org.eclipse.persistence.sequencing.QuerySequence
PUBLIC:
getSelectSequenceQuery() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
OBSOLETE: This method lazy initializes the select sequence number query.
getSelectTables() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Returns the table(s) that should be selected to build this mapping's value(s).
getSelectTables() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Returns the table(s) that should be selected to build this mapping's value(s).
getSelfChildren() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getSelfNodeValueForAttribute(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getSendMode() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.RMITransportManagerConfig
 
getSensorName(String, String) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: TopLink_sessionName_domainClass_queryClass_queryName (if exist)_operationName (if exist).
getSeparators() - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
 
getSequence() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return the descriptor's sequence.
getSequence() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
getSequence() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
getSequence() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
getSequence() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getSequence(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Get sequence corresponding to the name
getSequence(String) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Get sequence corresponding to the name.
getSequence(String) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
Get sequence corresponding to the name
getSequenceConfigs() - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
getSequenceConnectionPoolConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.PoolsConfig
 
getSequenceCounterField() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getSequenceCounterField() - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
getSequenceCounterFieldName() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
getSequenceCounterFieldName() - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
PUBLIC:
getSequenceCounterFieldName() - Method in class org.eclipse.persistence.tools.schemaframework.UnaryTableSequenceDefinition
PUBLIC: Return the name of the only field of this table
getSequenceMapping() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Return the sequence mapping.
getSequenceNameField() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getSequenceNameField() - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
getSequenceNameFieldName() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
getSequenceNameFieldName() - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
PUBLIC:
getSequenceNumberField() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Get sequence number field
getSequenceNumberFieldName() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Get sequence number field name
getSequenceNumberName() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Get sequence number name
getSequenceNumberNamed(Object) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
INTERNAL: Perform remote function call
getSequenceNumberNamed(Object) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Perform remote function call
getSequenceNumberNamed(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
INTERNAL: Get the value returned by remote function call
getSequenceNumberNamed(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
INTERNAL: Get the value returned by remote function call
getSequenceNumberNamed(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
INTERNAL: Get the value returned by remote function call
getSequencePreallocationSize() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
getSequencePreallocationSize() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
getSequencePreallocationSize() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getSequencePreallocationSize() - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
getSequencePreallocationSize() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Method returns the value of the Sequence Preallocation size
getSequencePreallocationSize() - Method in class org.eclipse.persistence.services.RuntimeServices
Method returns the value of the Sequence Preallocation size
getSequences() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Returns a map of sequence names to Sequences (may be null).
getSequences() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
INTERNAL: Returns a map of sequence names to Sequences (may be null).
getSequences() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
Returns a map of sequence names to Sequences (may be null).
getSequencesToWrite() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Used only for writing into XML or Java.
getSequencesToWrite() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
INTERNAL: Used only for writing into XML or Java.
getSequencesToWrite() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Used only for writing the login into XML or Java.
getSequenceTable() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getSequenceTable() - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
getSequenceTable() - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
Return the database table for the sequence.
getSequenceTableIndexes() - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
PUBLIC:
getSequenceTableName() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
getSequenceTableName() - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
PUBLIC:
getSequenceTableName(Session) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
This returns the Sequence Table's qualified name, without delimiting.
getSequenceTableQualifiedName() - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
PUBLIC:
getSequenceTableQualifier() - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
PUBLIC:
getSequencing() - Method in interface org.eclipse.persistence.internal.sequencing.SequencingHome
 
getSequencing() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the Sequencing object used by the session.
getSequencing() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Return the Sequencing object used by the session.
getSequencing() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the Sequencing object used by the session.
getSequencing() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Return the Sequencing object used by the session.
getSequencing() - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
INTERNAL: Return the Sequencing object used by the session.
getSequencing() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Return the Sequencing object used by the session.
getSequencingCallback(SequencingCallbackFactory) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return sequencing callback.
getSequencingCallback(SequencingCallbackFactory) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return sequencing callback.
getSequencingCallback(DatabaseSession, SequencingCallbackFactory) - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
Return sequencingCallback corresponding to the passed session.
getSequencingConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
getSequencingConfigNonNull() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getSequencingControl() - Method in interface org.eclipse.persistence.internal.sequencing.SequencingHome
 
getSequencingControl() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Return SequencingControl which used for sequencing setup and customization including management of sequencing preallocation.
getSequencingControl() - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Return SequencingControl which used for sequencing setup and customization including management of sequencing preallocation.
getSequencingHome() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Return SequencingHome which used to obtain all sequence-related interfaces for DatabaseSession
getSequencingHome() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PROTECTED: Session broker doesn't have SequencingHome.
getSequencingServer() - Method in interface org.eclipse.persistence.internal.sequencing.SequencingHome
 
getSequencingServer() - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Return SequencingServer object owned by the session.
getSerializedObjectPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL:
getSerializedObjectPolicyClassName() - Method in class org.eclipse.persistence.internal.descriptors.SerializedObjectPolicyWrapper
 
getSerializer() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
Return the Serializer to use by default for serialization.
getSerializer() - Method in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
Return the serialize used for this converter.
getSerializer() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
PUBLIC: Return the Serializer to use for serialization of commands.
getSerializer() - Method in interface org.eclipse.persistence.sessions.Session
Return the Serializer to use by default for serialization.
getSerializerClassName() - Method in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
Return the class name of the serializer.
getSerializerPackage() - Method in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
Return the package used for XML and JSON serialization JAXBContext.
getServerClassName() - Method in class org.eclipse.persistence.internal.sessions.factories.model.platform.CustomServerPlatformConfig
 
getServerClassName() - Method in class org.eclipse.persistence.internal.sessions.factories.model.platform.ServerPlatformConfig
 
getServerIndirectionObject() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Return the object on the server that holds on to the remote value holder.
getServerLog() - Method in class org.eclipse.persistence.platform.server.glassfish.GlassfishPlatform
 
getServerLog() - Method in class org.eclipse.persistence.platform.server.NoServerPlatform
INTERNAL: getServerLog(): Return the ServerLog for this platform Return the default ServerLog in the base
getServerLog() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: getServerLog(): Return the ServerLog for this platform Return the default ServerLog in the base
getServerLog() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: getServerLog(): Return the ServerLog for this platform Return the default ServerLog in the base
getServerLog() - Method in class org.eclipse.persistence.platform.server.was.WebSphere_7_Platform
 
getServerName() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The server name is the name of the database instance.
getServerNameAndVersion() - Method in class org.eclipse.persistence.platform.server.NoServerPlatform
PUBLIC: getServerNameAndVersion(): Answer null because this does not apply to NoServerPlatform.
getServerNameAndVersion() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
PUBLIC: getServerNameAndVersion(): Talk to the relevant server class library, and get the server name and version
getServerNameAndVersion() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
PUBLIC: getServerNameAndVersion(): Talk to the relevant server class library, and get the server name and version
getServerPlatform() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Marked internal as this is not customer API but helper methods for accessing the server platform from within EclipseLink's other sessions types (ie not DatabaseSession)
getServerPlatform() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Answer the server platform to handle server specific behavior for WLS, Oc4j, etc.
getServerPlatform() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Marked internal as this is not customer API but helper methods for accessing the server platform from within EclipseLink's other sessions types (i.e.
getServerPlatform() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
INTERNAL: Return the serverPlatform that identifies the application server
getServerPlatform() - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Answer the server platform defining server-specific behavior for the receiver (Oc4j, WLS, ...).
getServerPlatform() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Marked internal as this is not customer API but helper methods for accessing the server platform from within other sessions types (i.e.
getServerPlatform() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the server platform currently used.
getServerPlatformConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
getServiceId() - Method in class org.eclipse.persistence.internal.sessions.coordination.RemoteConnection
INTERNAL: Return the service info of the receiving service
getServiceId() - Method in class org.eclipse.persistence.internal.sessions.coordination.ServiceAnnouncement
INTERNAL: Return the id of the service sending this announcement
getServiceId() - Method in class org.eclipse.persistence.sessions.coordination.Command
PUBLIC: Return the service identifier of the service where the command originated
getServiceId() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
INTERNAL: Return the service info that identifies this service instance
getServiceName() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
ADVANCED: This method is used to get the globally unique identifier for this connection.
getSession() - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
PUBLIC: The session in which the event is raised.
getSession() - Method in class org.eclipse.persistence.dynamic.DynamicHelper
 
getSession() - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
PUBLIC: Return the session.
getSession() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
getSession() - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL:
getSession() - Method in class org.eclipse.persistence.internal.databaseaccess.ConnectionCustomizer
INTERNAL:
getSession() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
getSession() - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
 
getSession() - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
getSession() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
 
getSession() - Method in class org.eclipse.persistence.internal.indirection.BackupValueHolder
 
getSession() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Return the session.
getSession() - Method in class org.eclipse.persistence.internal.oxm.Context.ContextState
 
getSession() - Method in class org.eclipse.persistence.internal.oxm.Context
INTERNAL:
getSession() - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
getSession() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getSession() - Method in interface org.eclipse.persistence.internal.oxm.record.XMLRecord
 
getSession() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Convenience method
getSession() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Return the session that this is managing commits for.
getSession() - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: get the session associated with this IdentityMapAccessor
getSession() - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: get the session associated with this IdentityMapAccessor
getSession() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
getSession() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
 
getSession() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Get the associated server side session.
getSession() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
Return the session.
getSession() - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
getSession() - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Get the session that owns this SessionLog.
getSession() - Method in class org.eclipse.persistence.logging.SessionLogEntry
Return the session that generated the log entry.
getSession() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
getSession() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
getSession() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Return the handle to the session
getSession() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the current session.
getSession() - Method in class org.eclipse.persistence.services.DevelopmentServices
INTERNAL:
getSession() - Method in class org.eclipse.persistence.services.RuntimeServices
INTERNAL:
getSession() - Method in class org.eclipse.persistence.sessions.CopyGroup
INTERNAL: Return the session.
getSession() - Method in interface org.eclipse.persistence.sessions.ExternalTransactionController
INTERNAL: Return the manager's session.
getSession() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIServerSessionManagerDispatcher
 
getSession() - Method in class org.eclipse.persistence.sessions.SessionEvent
PUBLIC: The session in which the event is raised.
getSession() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Get the session for this session event manager
getSession() - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
getSession() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
getSession() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
getSession() - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
 
getSession() - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
 
getSession() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return the manager's session.
getSession(int) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: XMLContext xmlContext = new XMLContext("path0:path1");
DatabaseSession session = xmlContext.getSession(0); // returns session for path0
getSession(DESCRIPTOR) - Method in class org.eclipse.persistence.internal.oxm.Context.ContextState
INTERNAL: Return the session corresponding to this Descriptor.
getSession(DESCRIPTOR) - Method in class org.eclipse.persistence.internal.oxm.Context
 
getSession(Class<?>) - Method in class org.eclipse.persistence.internal.oxm.Context.ContextState
INTERNAL: Return the session corresponding to this class.
getSession(Class<?>) - Method in class org.eclipse.persistence.internal.oxm.Context
INTERNAL: Return the session corresponding to this class.
getSession(Class<?>) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Return the session corresponding to this class.
getSession(Object) - Method in class org.eclipse.persistence.internal.oxm.Context.ContextState
INTERNAL: Return the session corresponding to this object.
getSession(Object) - Method in class org.eclipse.persistence.internal.oxm.Context
INTERNAL: Return the session corresponding to this object.
getSession(Object) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Return the session corresponding to this object.
getSession(String) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return the session by name.
getSession(String, boolean) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return the session by name.
getSession(String, boolean, boolean) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return the session by name.
getSession(String, ClassLoader) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return the session by name.
getSession(String, Object) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return the session by name, using the classloader of the Object specified.
getSession(String, String) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return the session by name, in the file specified.
getSession(String, String, ClassLoader) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return the session by name, in the file specified, using the class loader to find the resource.
getSession(SessionConfig, Project) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Return the correct session type from the sessionConfig
getSession(XMLDescriptor) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Return the session corresponding to this XMLDescriptor.
getSession(XMLSessionConfigLoader) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return the session by name, loading the configuration from the file specified in the loader, using the loading options provided on the loader.
getSession(XMLSessionConfigLoader, String, ClassLoader) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return the session by name, loading the configuration from the file specified in the XMLSessionConfigLoader.
getSession(XMLSessionConfigLoader, String, ClassLoader, boolean, boolean) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return the session by name, loading the configuration from the file specified in the loader.
getSession(XMLSessionConfigLoader, String, ClassLoader, boolean, boolean, boolean) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return the session by name, loading the configuration from the file specified in the loader.
getSessionCompleted() - Method in class org.eclipse.persistence.internal.sessions.factories.SessionBrokerPlaceHolder
 
getSessionConfigs() - Method in class org.eclipse.persistence.internal.sessions.factories.model.SessionConfigs
 
getSessionCustomizerClass() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
getSessionEventListeners() - Method in class org.eclipse.persistence.internal.sessions.factories.model.event.SessionEventManagerConfig
 
getSessionEventManagerConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
getSessionForClass(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the session to be used for the class.
getSessionForClass(Class<?>) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Return the session to be used for the class.
getSessionForName(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the session by name.
getSessionForName(String) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Return the session by name.
getSessionForQuery(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Answers the session to be used for the given query.
getSessionLog() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return the session log to which an accessor logs messages and SQL.
getSessionLog() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return the session log to which an accessor logs messages and SQL.
getSessionName() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return the name of the session local to this descriptor.
getSessionName() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return the name of the session that the query should be executed under.
getSessionName() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Answer the name of the EclipseLink session this MBean represents.
getSessionName() - Method in class org.eclipse.persistence.services.RuntimeServices
Answer the name of the EclipseLink session this MBean represents.
getSessionName() - Method in class org.eclipse.persistence.sessions.factories.SessionFactory
 
getSessionName() - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: Returns the name of the Session in the sessions XML file desired to be loaded.
getSessionNames() - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionBrokerConfig
 
getSessionNamesByClass() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Return sessions indexed by class, each class can only have one default session.
getSessionNamesRequired() - Method in class org.eclipse.persistence.internal.sessions.factories.SessionBrokerPlaceHolder
 
getSessions() - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Return the EclipseLink session used to marshal.
getSessions() - Method in class org.eclipse.persistence.sessions.factories.SessionManager
INTERNAL: Return a hashtable on all sessions.
getSessionsByName() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Return sessions indexed by name.
getSessionString() - Method in class org.eclipse.persistence.logging.EclipseLinkLogRecord
 
getSessionString(Session) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
Return the current session including the type and id.
getSessionType() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Answer the type of the EclipseLink session this MBean represents.
getSessionType() - Method in class org.eclipse.persistence.services.RuntimeServices
Answer the type of the EclipseLink session this MBean represents.
getSessionTypeString() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Returns the type of session, its class.
getSessionTypeString() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Returns the type of session, its class.
getSessionTypeString() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Returns the type of session, its class.
getSessionXMLPath() - Method in class org.eclipse.persistence.sessions.factories.SessionFactory
 
getSetClass() - Method in interface org.eclipse.persistence.indirection.IndirectCollectionsFactory.IndirectCollectionsProvider
Class implementing IndirectSet.
getSetMethod() - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Return the set method for the attribute accessor.
getSetMethod() - Method in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
This method will lazily initialize the set method Lazy initialization occurs to that we are not required to have a handle on the actual class that we are using until runtime.
getSetMethodName() - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Return the name of the set method for the attribute accessor.
getSetMethodName() - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeMethodInfo
 
getSetMethodName() - Method in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
 
getSetMethodName() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: This method is invoked reflectively on the reference object to set the value of the attribute in the object.
getSetMethodParameterType() - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
 
getSetMethodParameterType() - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeAccessor
Return the set method parameter type.
getSetMethodParameterType(int) - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
 
getSetMethodParameterTypes() - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
 
getSetMethodParameterTypes() - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeAccessor
Return the set method parameter types.
getSetThreadWaitingToReleaseDeferredLocksClone() - Method in class org.eclipse.persistence.internal.helper.type.ConcurrencyManagerState
getSetting() - Method in class org.eclipse.persistence.internal.oxm.Reference
 
getSettings() - Method in interface org.eclipse.persistence.oxm.sequenced.SequencedObject
 
getSettingsFromObject(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLSequencedObjectBuilder
 
getShallowCommits() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Return any objects that have been shallow committed during this commit process.
getSharedSession() - Method in class org.eclipse.persistence.sessions.factories.SessionFactory
Helper method that looks up the singleton session and ensure that if the application has been hot-deployed it gets a fresh version of the server.
getSharedSession(boolean, boolean) - Method in class org.eclipse.persistence.sessions.factories.SessionFactory
Used in place of getSharedSession() when the calling application needs access to the session prior to login or it wishes to force the session configuration to be re-loaded an applied.
getShortClassName(Class<?>) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answers the unqualified class name for the provided class.
getShortClassName(Object) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answers the unqualified class name for the specified object.
getShortClassName(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answers the unqualified class name from the specified String.
getShortClassType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the Short class representation.
getShortestTime() - Method in class org.eclipse.persistence.tools.profiler.Profile
 
getShortName() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getShortType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the short type representation.
getShouldBindAllParameters() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Returns the internal tri-state value of shouldBindParameters used far cascading these settings
getShouldBindAllParameters() - Method in class org.eclipse.persistence.services.DevelopmentServices
Method returns if all Parameters should be bound or not
getShouldBindAllParameters() - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
Method returns if all Parameters should be bound or not
getShouldBindAllParameters() - Method in class org.eclipse.persistence.services.RuntimeServices
Method returns if all Parameters should be bound or not
getShouldBindAllParameters() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used to help bean introspection.
getShouldCacheAllStatements() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Returns if statements should be cached or not
getShouldCacheAllStatements() - Method in class org.eclipse.persistence.services.RuntimeServices
Returns if statements should be cached or not
getShouldCacheAllStatements() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used to help bean introspection.
getShouldLogExceptionStackTrace() - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.LoggingOptionsConfig
 
getShouldLogMessages() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to determine if messages should be logged by the session
getShouldLogMessages() - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to determine if logging is turned on
getShouldLogPerformanceProfiler() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to determine if we should be logging when using the Performance Profiler
getShouldLogPerformanceProfiler() - Method in class org.eclipse.persistence.services.RuntimeServices
Method indicates if Performance profile should be logged
getShouldOptimizeDataConversion() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used to help bean introspection.
getShouldPrintConnection() - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.LoggingOptionsConfig
 
getShouldPrintDate() - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.LoggingOptionsConfig
 
getShouldPrintSession() - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.LoggingOptionsConfig
 
getShouldPrintThread() - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.LoggingOptionsConfig
 
getShouldProfilePerformance() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will return if profiling is turned on or not
getShouldProfilePerformance() - Method in class org.eclipse.persistence.services.RuntimeServices
This method will return if profiling is turned on or not
getShouldThrowConformExceptions() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return whether to throw exceptions on conforming queries
getShouldTrimStrings() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used to help bean introspection.
getSimpleContent() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
getSimpleType() - Method in class org.eclipse.persistence.internal.oxm.schema.model.List
 
getSimpleType() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getSimpleType() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
getSimpleTypes() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Union
 
getSingleValueToWriteForUnion(Object, CoreAbstractSession) - Method in class org.eclipse.persistence.oxm.XMLUnionField
 
getSingleValueToWriteForUnion(XMLUnionField, Object, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
Return a single QName representation for a given XMLUnionField, if applicable.
getSize() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
 
getSize() - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Return the number of CacheKeys in the IdentityMap.
getSize() - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Return the number of CacheKeys in the IdentityMap.
getSize() - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Return the number of CacheKeys in the IdentityMap.
getSize() - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Return 0 as no objects are cached.
getSize() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
Return the batch fetch size.
getSize() - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Return the number of CacheKeys in the IdentityMap.
getSize() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Return the size of the field, this is only required for some field types.
getSize() - Method in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
PUBLIC: Return the maximum size of the array.
getSize(Class<?>, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Return the number of actual objects of type myClass in the IdentityMap.
getSize(Class<?>, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Return the number of actual objects of type myClass in the IdentityMap.
getSize(Class<?>, boolean) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Return the number of actual objects of type myClass in the IdentityMap.
getSize(Class<?>, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Return 0 as no objects are cached.
getSize(Class<?>, boolean) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Return the number of actual objects of type myClass in the IdentityMap.
getSizeForPool(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will retrieve the size of a particular connection pool
getSizeForPool(String) - Method in class org.eclipse.persistence.services.RuntimeServices
This method will retrieve the size of a particular connection pool
getSizeQuery() - Method in class org.eclipse.persistence.queries.CursoredStreamPolicy
Return the query used to read the size.
getSkipCount() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
getSopObject() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL:
getSourceAttributeName() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
getSourceClassName() - Method in class org.eclipse.persistence.logging.SessionLogEntry
 
getSourceFields() - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
getSourceFields() - Method in class org.eclipse.persistence.tools.schemaframework.UniqueKeyConstraint
PUBLIC:
getSourceForeignKeyFields() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Return the source foreign key fields.
getSourceForeignKeysToTargetKeys() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Sets the target foreign key fields.
getSourceKeyFieldNames() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Return the source key field names associated with the mapping.
getSourceKeyFieldNames() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Return the source key field names associated with the mapping.
getSourceKeyFieldNames() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Return the source key field names associated with the mapping.
getSourceKeyFieldNames() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
PUBLIC: Return the source key field names associated with the mapping.
getSourceKeyFieldNames() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Return the source key field names associated with the mapping.
getSourceKeyFields() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Return the source key names associated with the mapping
getSourceKeyFields() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return the source key fields.
getSourceKeyFields() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Return all the source key fields associated with the mapping.
getSourceKeyFields() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Return the source key fields.
getSourceKeyFields() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Return all the source key fields associated with the mapping.
getSourceKeysToTargetForeignKeys() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Return the source/target key fields.
getSourceMapping() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL:
getSourceMethodName() - Method in class org.eclipse.persistence.logging.SessionLogEntry
 
getSourceObject() - Method in exception org.eclipse.persistence.exceptions.ConversionException
PUBLIC: Return the object for which the problem was detected.
getSourceObject() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
getSourceObject() - Method in class org.eclipse.persistence.internal.oxm.Reference
Return the source object for this reference.
getSourceRelationKeyFieldNames() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Return the source relation key field names associated with the mapping.
getSourceRelationKeyFieldNames() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Return the source relation key field names associated with the mapping.
getSourceRelationKeyFields() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Return all the source relation key fields associated with the mapping.
getSourceRelationKeyFields() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Return all the source relation key fields associated with the mapping.
getSourceTable() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
Calculate the source table for based on the various QueryKeyExpression usages (join query keys, custom defined query keys, or query keys for mappings).
getSourceTable() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
getSourceTable() - Method in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
PUBLIC: Returns the source table.
getSourceToTargetKeyFieldAssociations() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ObjectReferenceMapping
Return a list of source-target xmlfield pairs.
getSourceToTargetKeyFieldAssociations() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return a collection of the source to target field value associations.
getSourceToTargetKeyFieldAssociations() - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
INTERNAL: Return a list of source-target xmlfield pairs.
getSourceToTargetKeyFields() - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: Gets the foreign key fields.
getSourceToTargetKeyFields() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Returns the source keys to target keys fields association.
getSourceToTargetQueryKeyFieldAssociations() - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
PUBLIC: Return a collection of the field to query key associations.
getSourceToTargetQueryKeyNames() - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Returns the source keys to target keys fields association.
getSpecialOperations() - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: The special operations to use in place of equal.
getSQL2PlName(ComplexDatabaseType) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
Return the conversion function name, generate the function if missing.
getSqlCode() - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
getSqlCode() - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
getSqlCode() - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
 
getSqlCode() - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
getSqlCode() - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
getSqlCode() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCollection
 
getSqlCode() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCursor
 
getSqlCode() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
getSQLDateType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the Date type representation.
getSQLResultMapping() - Method in class org.eclipse.persistence.queries.SQLResult
INTERNAL: Return the SQLResultSetMapping this SQLResult is part of.
getSQLResultSetMapping() - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: This will be the SQLResultSetMapping that is used by this query to process the database results
getSQLResultSetMapping(String) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Get a named SQLResultSetMapping from this project.
getSQLResultSetMappingName() - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: Return the result set mapping name.
getSQLResultSetMappingNames() - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: Return the result set mapping name.
getSQLResultSetMappings() - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: This will be the SQLResultSetMapping that is used by this query to process the database results
getSQLStatement() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
INTERNAL: Return the sqlStatement
getSQLStatement() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return the SQL statement of the query.
getSQLStatements() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Normally only a single statement is used, however multiple table may require multiple statements on write.
getSQLString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Return the SQL string that will be executed.
getSQLString() - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: Return the SQL string of the query.
getSQLString() - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: Return the SQL string for this call.
getSQLStrings() - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: Return the SQL strings of the query.
getSqlType() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Return the JDBC type that corresponds to the field.
getSqlTypeName() - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDatabaseField
ADVANCED: For ARRAY and STRUCT fields, this is the user defined type for the field.
getStack() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
getStart() - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
getStart(int) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
getStartDelimiter() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Delimiter to use for fields and tables using spaces or other special values.
getStartDelimiter() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Delimiter to use for fields and tables using spaces or other special values.
getStartFieldName() - Method in class org.eclipse.persistence.history.HistoryPolicy
PUBLIC: Answers the name of the start field.
getStartFields() - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
getStartStrings() - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
 
getStartValue() - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartition
PUBLIC: Return the range start value.
getStartWithExpression() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Return the StartWith expression
getStartWithExpression() - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC:
getState() - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: State of the connection.
getState() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Find out what the lifecycle state of this UoW is in.
getStatement() - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Return the statement that expression is for.
getStatement() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
The statement is stored for the return value of cursor selects.
getStatement() - Method in class org.eclipse.persistence.internal.expressions.ExpressionIterator
 
getStatement() - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
 
getStatement() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Return the Statement.
getStatementCache() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
The statement cache stores a fixed sized number of prepared statements.
getStatementCacheSize() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
The statement cache size for prepare parameterized statements.
getStatementCacheSize() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Returns the statement cache size.
getStatementCacheSize() - Method in class org.eclipse.persistence.services.RuntimeServices
Returns the statement cache size.
getStatementCacheSize() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: If prepared statement caching is used, return the cache size.
getStatements() - Method in class org.eclipse.persistence.tools.schemaframework.PackageDefinition
The statements are the SQL lines of code.
getStatements() - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The statements are the SQL lines of code in procedure.
getStaticMetamodelClass(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the static metamodel class associated with the given model class if available.
getStoredProcedureParameterPrefix() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
getStoredProcedureParameterPrefix() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
 
getStoredProcedureParameterPrefix() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Pervasive uses ":" as prefix for procedure parameters.
getStoredProcedureParameterPrefix() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
getStoredProcedureParameterPrefix() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
 
getStoredProcedureParameterPrefix() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
getStoredProcedureStatementsCount() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return the number of stored procedure call.
getStoredProcedureTerminationToken() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Returns the delimiter between stored procedures in multiple stored procedure calls.
getStreamsForBinding() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getStringAndFreeSQLXML(Object) - Static method in class org.eclipse.persistence.internal.helper.JavaPlatform
INTERNAL: Casts the passed object to SQLXML and calls getString and free methods
getStringBinding() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getStringBindingSize() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
getStringBindingSize() - Method in class org.eclipse.persistence.services.DevelopmentServices
Return the size of strings after which will be bound into the statement
getStringBindingSize() - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
Return the size of strings after which will be bound into the statement
getStringBindingSize() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Return the size of strings after which will be bound into the statement If we are not using a DatabaseLogin, or we're not using string binding, answer 0 (zero).
getStringBindingSize() - Method in class org.eclipse.persistence.services.RuntimeServices
Return the size of strings after which will be bound into the statement If we are not using a DatabaseLogin, or we're not using string binding, answer 0 (zero).
getStringBindingSize() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used to help bean introspection.
getStringBuffer() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getStringBuffer() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
INTERNAL: This is the text handler during unmarshal operations.
getStringBuffer() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
INTERNAL: This is the text handler during unmarshal operations.
getStringForQName(QName) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
getStringForQName(QName) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
getStringForQName(QName) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
getStringType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the String type representation.
getStringVal() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: XMLType Function - gets a string value from an XMLType
getStringVal() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
 
GetStringVal - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
getStructConverterClasses() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.StructConverterConfig
 
getStructConverterConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getStructConverters() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Get the map of StructConverters that will be used to preprocess STRUCT data as it is read
getStructConverters() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Returns structure converter class names that would be set on the databasePlatform instance This is used to avoid the platform instance changing at login.
getStructName() - Method in interface org.eclipse.persistence.platform.database.converters.StructConverter
PUBLIC:
getStructureName() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
This is required for ObjectArrayMapping which defines a name for the collection type.
getStructureName() - Method in class org.eclipse.persistence.mappings.structures.ArrayMapping
PUBLIC: Return the name of the structure.
getStructureName() - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
PUBLIC: Return the structure name of the nestedTable.
getStructureName() - Method in class org.eclipse.persistence.mappings.structures.ObjectArrayMapping
PUBLIC: Return the name of the structure.
getStructureName() - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
PUBLIC: Return the name of the structure.
getStructureName() - Method in class org.eclipse.persistence.mappings.structures.StructureMapping
INTERNAL: Return the name of the structure.
getSubclassDescriptor(Class<?>) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: use aggregate in inheritance
getSubClassGroups() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL:
getSubQuery() - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
 
getSubscriber() - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
 
getSubSelect() - Method in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
 
getSubSelect() - Method in class org.eclipse.persistence.internal.expressions.SubSelectDatabaseTable
 
getSubSize() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Return the sub-size of the field.
getSubstitutionGroup() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getSuperClass() - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
getSupplementDetailString(SessionLogEntry) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
Return the supplement detail information including date, session, thread, connection, source class name and source method name.
getSupportedNonServerSessionProperties() - Static method in class org.eclipse.persistence.config.PersistenceUnitProperties
 
getSupportedProperties() - Static method in class org.eclipse.persistence.config.EntityManagerProperties
 
getSynchronizationType() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
getSystemChangeNumberQuery() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
PUBLIC: The query to select the current system change number from Oracle.
getSystemId() - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.LocatorImpl
 
getSystemId() - Method in class org.eclipse.persistence.internal.oxm.record.ExtendedResult
 
getSystemId() - Method in class org.eclipse.persistence.internal.oxm.record.ExtendedSource
 
getSystemId() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
Get the SystemId for this Schema.
getSystemProperty(String) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
INTERNAL: Get the System property indicated by the specified key.
getSystemProperty(String, String) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
INTERNAL: Get the System property indicated by the specified key.
getSystemPropertyBoolean(String, boolean) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
INTERNAL: Get boolean value of the System property indicated by the specified key.
getSystemTime() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Get the stored value of the current time.
getTable() - Method in class org.eclipse.persistence.internal.expressions.SQLModifyStatement
 
getTable() - Method in class org.eclipse.persistence.internal.expressions.TableExpression
 
getTable() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
getTable() - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.TableSequenceConfig
 
getTable() - Method in class org.eclipse.persistence.sequencing.TableSequence
 
getTable() - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
 
getTable(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Checks if table name exists with the current descriptor or not.
getTable(String) - Method in class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
getTable(String) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL: Return the new database table associated with this tenant.
getTable(String) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression representing a table in a data-level query.
getTable(String) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
getTable(DatabaseTable) - Method in class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
getTable(DatabaseTable) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL: Return the new database table associated with this tenant.
getTable(DatabaseTable) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression representing a table in a data-level query.
getTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
getTableAliases() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Return the aliases used.
getTableAliases() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL: Return the aliases used.
getTableAliases() - Method in class org.eclipse.persistence.internal.expressions.OuterJoinExpressionHolder
INTERNAL: Return the aliases used.
getTableAliases() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Return the aliases used.
getTableAliases() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
getTableAliasInSelectCallForExist() - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
getTableAliasInSelectCallForExist() - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
getTableAliasInSelectCallForNotExist() - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
getTableCreationSuffix() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
PUBLIC: Get the String used on all table creation statements generated from the DefaultTableGenerator with a session using this project (DDL generation).
getTableCreationSuffix() - Method in class org.eclipse.persistence.platform.database.DB2MainframePlatform
 
getTableCreationSuffix() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
 
getTableCreationSuffix() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Get the String used on all table creation statements generated from the DefaultTableGenerator with a session using this project (DDL generation).
getTableCreator() - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Return the table creator to generate from.
getTableDefFromDBTable(DatabaseTable) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Build a table definition object from a database table object
getTableDefinitions() - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Return the tables.
getTableExistsQuery(TableDefinition) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Returns query to check whether given table exists.
getTableExistsQuery(TableDefinition) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Returns query to check whether given table exists.
getTableExistsQuery(TableDefinition) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Returns query to check whether given table exists.
getTableIndexes() - Method in class org.eclipse.persistence.sequencing.TableSequence
 
getTableInfo(String, String[], AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return the table metadata for the specified selection criteria limited to the context of the current Accessor.
getTableInfo(String, String[], AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
 
getTableInfo(String, String[], AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
 
getTableInfo(String, String, String, String[]) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Get a description of tables available in a catalog.
getTableInfo(String, String, String, String[], AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return the table metadata for the specified selection criteria.
getTableInfo(String, String, String, String[], AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Get a description of tables available in a catalog.
getTableInfo(String, String, String, String[], AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return table information for the specified database objects.
getTableName() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the name of the descriptor's first table.
getTableName() - Method in class org.eclipse.persistence.descriptors.RelationalDescriptor
PUBLIC: Return the name of the descriptor's first table.
getTableName() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
getTableName() - Method in class org.eclipse.persistence.sequencing.TableSequence
 
getTableName(DatabaseTable, String) - Method in class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
getTableName(DatabaseTable, String) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL: Return the tenant table name.
getTableNames() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return the table names.
getTableNames() - Method in class org.eclipse.persistence.descriptors.RelationalDescriptor
PUBLIC: Return the table names.
getTableNames() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Return the table names.
getTablePerClassPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Returns the TablePerClassPolicy.
getTablePerTenantDescriptors() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return list of table per tenant multitenant descriptors.
getTablePerTenantQueries() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return list of table per tenant multitenant descriptors.
getTableQualifier() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Return the qualifier for the table.
getTableQualifier() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Return the qualifier for the table.
getTableQualifier() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
getTableQualifier() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
getTableQualifier() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Return the qualifier for the all of the tables referenced by EclipseLink.
getTableQualifier() - Method in interface org.eclipse.persistence.sessions.Login
PUBLIC: Return the qualifier for the all of the tables.
getTableQualifierDelimited(DatasourcePlatform) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
getTables() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return all the tables.
getTables() - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
INTERNAL: This method returns a vector which holds all the tables of database
getTables() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Return all the tables.
getTables() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: Return all the tables.
getTables_databaseFieldsToValues() - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
getTableSequence() - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
 
getTablesJoinExpressions() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Used in case descriptor has additional tables: each additional table mapped to an expression joining it.
getTablesToPrimaryKeyFields() - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
getTabs(int) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return a string containing the specified number of tabs.
getTargetClass() - Method in class org.eclipse.persistence.internal.oxm.Reference
Return the target (reference) class for this reference.
getTargetFieldForQueryKeyName(String) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: return a database field based on a query key name
getTargetFields() - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
getTargetForeignKeyFieldNames() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Return the target foregin key field names associated with the mapping.
getTargetForeignKeyFieldNames() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Return the target foreign key field names associated with the mapping.
getTargetForeignKeyFields() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Return the source foreign key fields.
getTargetForeignKeyFields() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Return the target foregin key fields associated with the mapping
getTargetForeignKeyFields() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Return the target foreign key fields.
getTargetForeignKeysToSourceKeys() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Return the target/source key fields.
getTargetForeignKeyToSourceKeys() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL:
getTargetIdenttyMap() - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Return the instance of the IdentityMap that this intercpetor is wrapping.
getTargetKeyFieldNames() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Return the target key field names associated with the mapping.
getTargetKeyFieldNames() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Return the target key field names associated with the mapping.
getTargetKeyFields() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Return all the target keys associated with the mapping.
getTargetKeyFields() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Return all the target keys associated with the mapping.
getTargetNamespace() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getTargetObjectPrimaryKeys() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Get target object primary key row.
getTargetPrimaryKeyFields() - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatementForTempTable
 
getTargetPrimaryKeyFields() - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Returns list of primary key fields from the reference descriptor.
getTargetPrimaryKeyFields() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Primary keys of targetForeignKeyTable.
getTargetRelationKeyFieldNames() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Return the target relation key field names associated with the mapping.
getTargetRelationKeyFieldNames() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Return the target relation key field names associated with the mapping.
getTargetRelationKeyFields() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Return all the target relation key fields associated with the mapping.
getTargetRelationKeyFields() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Return all the target relation key fields associated with the mapping.
getTargetTable() - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatementForTempTable
 
getTargetTable() - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
getTargetTable() - Method in class org.eclipse.persistence.tools.schemaframework.IndexDefinition
 
getTargetToSourceKeyFields() - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: Gets the target foreign key fields.
getTargetToSourceKeyFields() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Returns the target keys to source keys fields association.
getTargetVersionOfSourceObject(Object, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: If required, get the targetVersion of the source object from the merge manager.
getTargetVersionOfSourceObject(Object, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: If required, get the targetVersion of the source object from the merge manager.
getTargetVersionOfSourceObject(Object, Object, MergeManager, AbstractSession) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: If required, get the targetVersion of the source object from the merge manager
getTargetVersionOfSourceObject(Object, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: If required, get the targetVersion of the source object from the merge manager Used with MapKeyContainerPolicy to abstract getting the target version of a source key
getTargetVersionOfSourceObject(Object, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Return the corresponding value that should be assigned to the target object for the source object.
getTargetVersionOfSourceObject(MergeManager, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: This method is used to return the complex object specified within the change record.
getTargetVersionOfSourceObject(MergeManager, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: This method is used to return the complex object specified within the change record.
getTargetXPathFragment(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Return the last fragment before text() in the XPath that a given XPathFragment is part of.
getTemporaryCachedQueryResults() - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: Get results from the remporary cache.
getTempResolver(Element) - Method in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
Returns the namespace resolver in the map of temporary namespace resolvers for a given element
getTempSession() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
 
getTempTableForTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: May override this method if the platform support temporary tables.
getTempTableForTable(DatabaseTable) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 temp table syntax.
getTempTableForTable(DatabaseTable) - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
getTempTableForTable(DatabaseTable) - Method in class org.eclipse.persistence.platform.database.Informix11Platform
Overrides the superclass implementation to return a new DatabaseTable with no DatabaseTable.getTableQualifier().
getTempTableForTable(DatabaseTable) - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
getTempTableForTable(DatabaseTable) - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
INTERNAL:
getTempTableForTable(DatabaseTable) - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
Used for sp calls.
getTempTableForTable(DatabaseTable) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL:
getTempTableForTable(DatabaseTable) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL:
getTenantDiscriminatorFields() - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL:
getTenantDiscriminatorFieldsKeyedOnContext() - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL:
getTerminationStrings() - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
 
getTextNode() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getTextWrapperFragment() - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
getTextWrapperFragment() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getTextWrapperFragment() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getTextWrapperFragment() - Method in class org.eclipse.persistence.oxm.record.JsonRecord
INTERNAL: The optional fragment used to wrap the text() mappings
getTextWrapperFragment() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL: The optional fragment used to wrap the text() mappings
getTextWrapperFragment() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
INTERNAL: The optional fragment used to wrap the text() mappings
getTextWrapperFragment() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getThread() - Method in class org.eclipse.persistence.logging.SessionLogEntry
Return the thread that was active when the log entry was generated.
getThreadBlockingTheDeferringThreadFromFinishing() - Method in class org.eclipse.persistence.internal.helper.type.IsBuildObjectCompleteOutcome
getThreadDepth() - Method in class org.eclipse.persistence.internal.helper.DeferredLockManager
Return the depth of the thread associated with the DLM, being used to release the lock
getThreadNamesKnownToBeStuckTryingToAcquireLock() - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
getThreadNamesKnownToBeStuckTryingToAcquireLockForReading() - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
getThreadNamesThatAcquiredActiveLock() - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
getThreadNamesThatAcquiredDeferredLock() - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
getThreadNamesThatAcquiredReadLock() - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
getThreadNotAbleToAccessResource() - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
getThreadPool() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: Return the thread pool, initializing if required.
getThreadPoolSize() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
Return the thread pool size.
getThreadPoolSize() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
Return the thread pool size.
getThreadsKnownToBeStuckTryingToAcquireLock() - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
getThreadsKnownToBeStuckTryingToAcquireLockForReading() - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
getThreadsThatAcquiredActiveLock() - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
getThreadsThatAcquiredDeferredLock() - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
getThreadsThatAcquiredReadLock() - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
getThreadsToWaitOnAcquire() - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
getThreadsToWaitOnAcquireMethodName() - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
getThreadsToWaitOnAcquireReadLock() - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
getThreadsToWaitOnAcquireReadLockMethodName() - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
getThreadString(Thread) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
Return the specified thread information.
getThreadsWaitingToReleaseDeferredLocks() - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
getThreadsWaitingToReleaseDeferredLocksJustification() - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
getThreadToFailToAcquireCacheKeys() - Static method in class org.eclipse.persistence.internal.helper.WriteLockManager
getTimeConnectionEstablished() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will return a long indicating the exact time in Milliseconds that the session connected to the database.
getTimeConnectionEstablished() - Method in class org.eclipse.persistence.services.RuntimeServices
This method will return a long indicating the exact time in Milliseconds that the session connected to the database.
getTimePerObject() - Method in class org.eclipse.persistence.tools.profiler.Profile
 
getTimestampFromServer(AbstractSession, String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Answer the timestamp from the server.
getTimestampFromServer(AbstractSession, String) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Answer the timestamp from the server.
getTimestampFromServer(AbstractSession, String) - Method in class org.eclipse.persistence.platform.database.AccessPlatform
Access do not support millisecond well, truncate the millisecond from the timestamp
getTimestampQuery() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
This method can be overridden by subclasses to return a query that will return the timestamp from the server.
getTimestampQuery() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
This method can be overridden by subclasses to return a query that will return the timestamp from the server.
getTimestampQuery() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: This method returns the query to select the timestamp from the server for DB2.
getTimestampQuery() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL: This method returns the query to select the timestamp from the server for Derby.
getTimestampQuery() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
 
getTimestampQuery() - Method in class org.eclipse.persistence.platform.database.H2Platform
 
getTimestampQuery() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
 
getTimestampQuery() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: This method returns the query to select the timestamp from the server for MySQL.
getTimestampQuery() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
PUBLIC: This method returns the query to select the timestamp from the server for Oracle.
getTimestampQuery() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: This method returns the query to select the timestamp from the server for Postgres.
getTimestampQuery() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
PUBLIC: This method returns the query to select the timestamp from the server for SQLServer.
getTimestampQuery() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
PUBLIC: This method returns the query to select the timestamp from the server for Sybase.
getTimestampQuery() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
This method returns the query to select the timestamp from the database.
getTimestampQuery() - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
PUBLIC: TimesTen uses the Oracle syntax for getting the current timestamp.
getTimestampType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the timestamp type representation.
getTimeToLive() - Method in class org.eclipse.persistence.descriptors.invalidation.TimeToLiveCacheInvalidationPolicy
PUBLIC: Return the time-to-live specified for this policy.
getTimeType() - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the Time type representation.
getTimeZone() - Method in interface org.eclipse.persistence.internal.helper.TimeZoneHolder
 
getTimeZone() - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Return the specified TimeZone used for all String to date object conversions.
getTopic() - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
 
getTopic(Context) - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
INTERNAL:
getTopicConnection() - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
 
getTopicConnectionFactory() - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
 
getTopicConnectionFactory(Context) - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
INTERNAL:
getTopicConnectionFactoryName() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.JMSPublishingTransportManagerConfig
 
getTopicConnectionFactoryName() - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
PUBLIC: Return the JMS Topic Connection Factory Name for the JMS Topic connections.
getTopicHostUrl() - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
PUBLIC: Return the URL of the machine on the network that hosts the JMS Topic.
getTopicHostURL() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.JMSPublishingTransportManagerConfig
 
getTopicName() - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL:
getTopicName() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.JMSPublishingTransportManagerConfig
 
getTopicName() - Method in class org.eclipse.persistence.sessions.coordination.broadcast.BroadcastTransportManager
PUBLIC: Return the topic name that this TransportManager will be connecting to.
getTopicSession() - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
 
getTopLevelAttributes() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getTopLevelComplexTypes() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getTopLevelElements() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getTopLevelSimpleTypes() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
getTotalDigits() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
getTotalDigits() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getTotalNumberOfConnections() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: Return the total number of connections currently in use.
getTotalNumberOfKeysAcquiredForReading() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
getTotalNumberOfKeysReleasedForReading() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
getTotalNumberOfKeysReleasedForReadingBlewUpExceptionDueToCacheKeyHavingReachedCounterZero() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
getTotalTime() - Method in class org.eclipse.persistence.tools.profiler.Profile
 
getTrackedAttributeName() - Method in interface org.eclipse.persistence.descriptors.changetracking.CollectionChangeTracker
PUBLIC: Return the Attribute name this collection is mapped under.
getTrackedAttributeName() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Return the mapping attribute name, used to raise change events.
getTrackedAttributeName() - Method in class org.eclipse.persistence.indirection.IndirectMap
INTERNAL: Return the mapping attribute name, used to raise change events.
getTrackedAttributeName() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Return the mapping attribute name, used to raise change events.
getTransaction() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: PERF: Return the associated external transaction.
getTransaction() - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
 
getTransaction() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return the active external transaction object, or null if none is active.
getTransaction_impl() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return the active external transaction for the calling thread, or null if none is currently active for this thread.
getTransaction_impl() - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Return the active external transaction, or null if none is currently active for this thread.
getTransactionController() - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
 
getTransactionId() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
getTransactionIsolation() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Returns the transaction isolation setting for a connection.
getTransactionIsolation() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return the transaction isolation setting for the connection.
getTransactionKey() - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
 
getTransactionKey(Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return a key for the specified external transaction object.
getTransactionKey_impl(Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return a key for the specified external transaction object.
getTransactionKey_impl(Object) - Method in class org.eclipse.persistence.transaction.JTA11TransactionController
INTERNAL: Return a key for the specified external transaction object.
getTransactionKey_impl(Object) - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Return a key for the specified external transaction object.
getTransactionManager() - Method in class org.eclipse.persistence.transaction.JTATransactionController
PUBLIC: Return the transaction manager used to control the JTA transactions.
getTransactionMutex() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: The transaction mutex ensure mutual exclusion on transaction across multiple threads.
getTransactionStatus() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return the transaction status.
getTransactionStatus_impl() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return the transaction status.
getTransactionStatus_impl() - Method in class org.eclipse.persistence.transaction.JTA11TransactionController
INTERNAL: Return the transaction status as an object.
getTransactionStatus_impl() - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Return the transaction status as an object.
getTransactionSynchronizationRegistry() - Method in class org.eclipse.persistence.transaction.JTA11TransactionController
PUBLIC: Return the synchronization objects registry used to control the JTA 1.1 transactions.
getTransformationMapping() - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Reduce casting clutter....
getTransformationMappings() - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
getTransformationMappings() - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
getTransformationMappings() - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
getTransformationRecord() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getTransformationRecord() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getTransformationRecord() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getTransformer() - Method in class org.eclipse.persistence.internal.indirection.TransformerBasedValueHolder
Return the method.
getTransformer() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
INTERNAL
getTransformer() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
INTERNAL
getTransformerClass() - Method in class org.eclipse.persistence.internal.descriptors.TransformerBasedFieldTransformation
 
getTransformerClassName() - Method in class org.eclipse.persistence.internal.descriptors.TransformerBasedFieldTransformation
 
getTransformerMethodName() - Method in class org.eclipse.persistence.internal.helper.TransformerHelper
 
getTransformerMethodParameters(boolean) - Method in class org.eclipse.persistence.internal.helper.TransformerHelper
 
getTransientCompatibleAnnotations() - Static method in class org.eclipse.persistence.annotations.TransientCompatibleAnnotations
PUBLIC: Return a list of classnames of annotations that are compatible with the jakarta.persistence.Transient annotation.
getTranslatedSQLString(Session, DataRecord) - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: This can be used to access a queries translated SQL if they have been prepared, (i.e.
getTranslatedSQLStrings(Session, DataRecord) - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: This can be used to access a queries translated SQL if they have been prepared, (i.e.
getTranslationRow() - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
INTERNAL: Return the row for translation
getTranslationRow() - Method in class org.eclipse.persistence.internal.expressions.SQLStatement
INTERNAL: Return the row for translation
getTranslationRow() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Convenience method
getTranslationRow() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Gets the translation row the query was executed with, used for incremental conforming.
getTranslationRow() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the row for translation
getTransportClass() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.UserDefinedTransportManagerConfig
 
getTransportManager() - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
PUBLIC: Return the transport manager that manages sending and receiving of remote commands.
getTransportManager() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
getTransportManagerConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.rcm.RemoteCommandManagerConfig
 
getTreatCriteria() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
INTERNAL: this returns a single expression to represent the join from the main table to all child descriptor tables Only if outer joins should be printed in the where clause
getTrimStrings() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
getTuner() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
Return the tuner used to tune the configuration of this session.
getTxManagerFactoryClass() - Method in class org.eclipse.persistence.transaction.was.WebSphereEJBEmbeddableTransactionController
 
getTxManagerFactoryClass() - Method in class org.eclipse.persistence.transaction.was.WebSphereLibertyTransactionController
 
getTxManagerFactoryClass() - Method in class org.eclipse.persistence.transaction.was.WebSphereTransactionController
 
getTxManagerFactoryMethod() - Method in class org.eclipse.persistence.transaction.was.WebSphereEJBEmbeddableTransactionController
 
getTxManagerFactoryMethod() - Method in class org.eclipse.persistence.transaction.was.WebSphereLibertyTransactionController
 
getTxManagerFactoryMethod() - Method in class org.eclipse.persistence.transaction.was.WebSphereTransactionController
 
getType() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
getType() - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
 
getType() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Return the type of function.
getType() - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
getType() - Method in class org.eclipse.persistence.internal.codegen.ReflectiveAttributeDefinition
 
getType() - Method in interface org.eclipse.persistence.internal.core.helper.CoreField
 
getType() - Method in class org.eclipse.persistence.internal.databaseaccess.InParameterForCallableStatement
 
getType() - Method in class org.eclipse.persistence.internal.descriptors.QueryArgument
 
getType() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
Gets internal impl class of DynamicType.
getType() - Method in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
 
getType() - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
The inferred type of this parameter.
getType() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
getType() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
 
getType() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
getType() - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
Indicates if the schema reference references a simple type definition, complex type definition, element, or group.
getType() - Method in interface org.eclipse.persistence.platform.xml.XMLSchemaReference
Indicates if the schema reference references a simple type definition, complex type definition, element or group
getType() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
Return the batch fetch type, (JOIN, IN, EXISTS).
getType() - Method in class org.eclipse.persistence.sessions.serializers.AbstractSerializer
 
getType() - Method in class org.eclipse.persistence.sessions.serializers.JavaSerializer
 
getType() - Method in interface org.eclipse.persistence.sessions.serializers.Serializer
 
getType() - Method in class org.eclipse.persistence.sessions.serializers.XMLSerializer
 
getType() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Return the type of the field.
getType() - Method in class org.eclipse.persistence.tools.schemaframework.NestedTableDefinition
PUBLIC: Return the type of the field.
getType() - Method in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
PUBLIC: Return the type of the field.
getType(int) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
getType(int) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
getType(String) - Method in class org.eclipse.persistence.dynamic.DynamicHelper
Lookup the dynamic type for an alias.
getType(String) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
getType(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
getType(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
getType(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
getType(ClassDescriptor) - Static method in class org.eclipse.persistence.dynamic.DynamicHelper
 
getType(DynamicEntity) - Static method in class org.eclipse.persistence.dynamic.DynamicHelper
Provide access to the entity's type.
getTypeClause() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
getTypeConverters() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Get the map of TypeConverters This map indexes StructConverters by the Java Class they are meant to convert
getTypeDefinition() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Return the type definition of the field.
getTypeDefParticle() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
getTypeDefParticle() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
getTypeDefParticle() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
getTypedField(FIELD) - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
INTERNAL: searches first descriptor than its ReturningPolicy for an equal field
getTypedField(FIELD) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: searches first descriptor than its ReturningPolicy for an equal field
getTypedField(StringTokenizer) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
getTypedField(DatabaseField) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: searches first descriptor than its ReturningPolicy for an equal field
getTypedField(DatabaseField) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
getTypeField() - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
 
getTypeFieldName() - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
PUBLIC: This method returns the name of the typeField of the mapping.
getTypeForImplementor(Class<?>) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Return the type for a specified implementor
getTypeIndicatorNameTranslation() - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Return the typeIndicatorName translation Used by the Mapping Workbench to avoid classpath dependencies
getTypeIndicatorTranslation() - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Return the type indicators.
getTypeName() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL: Returns the name of the type this group represents
getTypeName() - Method in class org.eclipse.persistence.internal.codegen.AttributeDefinition
 
getTypeName() - Method in class org.eclipse.persistence.internal.codegen.NonreflectiveAttributeDefinition
 
getTypeName() - Method in class org.eclipse.persistence.internal.codegen.ReflectiveAttributeDefinition
 
getTypeName() - Method in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
getTypeName() - Method in class org.eclipse.persistence.internal.descriptors.QueryArgument
INTERNAL: Return the classname of the type.
getTypeName() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
getTypeName() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
getTypeName() - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
getTypeName() - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
getTypeName() - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
getTypeName() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Return the type name of the field.
getTypeName() - Method in class org.eclipse.persistence.tools.schemaframework.NestedTableDefinition
PUBLIC: Return the type of the field.
getTypeName() - Method in class org.eclipse.persistence.tools.schemaframework.TypeTableDefinition
PUBLIC: The name of the type that this table is of.
getTypeName() - Method in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
PUBLIC: Return the type of the field.
getTypeName(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the name of the specified type.
getTypeQName() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getTypeQName() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getTypeQName() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getTypeSize() - Method in class org.eclipse.persistence.tools.schemaframework.NestedTableDefinition
PUBLIC: Return the size of the element field, this is only required for some field types.
getTypeSize() - Method in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
PUBLIC: Return the size of the element field, this is only required for some field types.
getTypeStrings() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
getTypesuffix() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Returns a type suffix (like unicode, byte or ascii) for maxdb create table stmts
getUnaryTableSequence() - Method in class org.eclipse.persistence.tools.schemaframework.UnaryTableSequenceDefinition
 
getUnconvertedProperties() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Used to store un-converted properties, which are subsequenctly converted at runtime (through the convertClassNamesToClasses method.
getUnconvertedProperties() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Used to store un-converted properties, which are subsequenctly converted at runtime (through the convertClassNamesToClasses method.
getUnformattedMessage() - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL:
getUnifiedMapOfThreadsStuckTryingToAcquireWriteLock() - Method in class org.eclipse.persistence.internal.helper.type.ConcurrencyManagerState
getUnifiedMapOfThreadsStuckTryingToAcquireWriteLockMethodName() - Method in class org.eclipse.persistence.internal.helper.type.ConcurrencyManagerState
getUnion() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
getUnionExpressions() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
getUnionExpressions() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Return any union expressions.
getUnionUnpartitionableQueries() - Method in class org.eclipse.persistence.descriptors.partitioning.FieldPartitioningPolicy
PUBLIC: Return if queries that do not contain the partition field should be sent to every database and have the result unioned.
getUniqueConstraintDeletionString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for constraint deletion.
getUniqueConstraintDeletionString() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Used for unique constraint deletion.
getUniqueConstraints() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Return a list of the unique constraints for this table.
getUniqueKeys() - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC:
getUnitOfWork() - Method in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
INTERNAL: Return the unit of work associated with this listener
getUnitOfWork() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
getUnitOfWork() - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
 
getUnitOfWorkCacheIsolationLevel() - Method in class org.eclipse.persistence.descriptors.CachePolicy
ADVANCED: Return the unit of work cache isolation setting.
getUnitOfWorkCacheIsolationLevel() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Return the unit of work cache isolation setting.
getUnitOfWorkChangeSet() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Returns the currentChangeSet from the UnitOfWork.
getUnitOfWorkChangeSet() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Returns the currentChangeSet from the UnitOfWork.
getUnitOfWorkClone() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Returns the UnitOfWork Clone that this ChangeSet was built for.
getUnitOfWorkValueHolder() - Method in class org.eclipse.persistence.internal.indirection.BackupValueHolder
Return the original uow clone's value holder.
getUnitsOfWork() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return the hashtable keyed on the external transaction objects with values that are the associated units of work.
getUnmappedContentHandlerClass() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Get the class that will be instantiated to handled unmapped content Class must implement the org.eclipse.persistence.oxm.unmapped.UnmappedContentHandler interface
getUnmappedContentHandlerClass() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Get the class that will be instantiated to handled unmapped content Class must implement the org.eclipse.persistence.oxm.unmapped.UnmappedContentHandler interface
getUnmappedFields() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: This method returns any of the fields that are not mapped in the object.
getUnmappedTranslationRow(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
INTERNAL:
getUnmarshalAttributeGroup() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getUnmarshalAttributeGroup() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getUnmarshalAttributeGroup() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
INTERNAL: Returns the AttributeGroup or the name of the AttributeGroup to be used to unmarshal.
getUnmarshalAttributeGroup() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
INTERNAL: Returns the AttributeGroup or the name of the AttributeGroup to be used to unmarshal.
getUnmarshalAttributeGroup() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getUnmarshalContext() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getUnmarshalContext() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getUnmarshalContext() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getUnmarshaller() - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractUnmarshalRecord
 
getUnmarshaller() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
getUnmarshaller() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getUnmarshaller() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getUnmarshaller() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getUnmarshaller() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL:
getUnmarshallerHandler() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
 
getUnmarshallerHandler() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
getUnmarshallerHandler() - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
 
getUnmarshalListener() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
 
getUnmarshalListener() - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
 
getUnmarshalNamespaceResolver() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
getUnmarshalNamespaceResolver() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getUnmarshalNamespaceResolver() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getUnmarshalNamespaceResolver() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getUnmarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getUnmarshalRecord() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
INTERNAL
getUnregisteredDeletedCloneForOriginal(Object) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Called only by UnitOfWorkIdentityMapAccessor.getAndCloneCacheKeyFromParent method.
getUnregisteredExistingObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Used to lazy Initialize the unregistered existing Objects collection.
getUnregisteredNewObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This is used to store unregistered objects discovered in the parent so that the child unit of work knows not to register them on commit.
getUnregisteredNewObjectsCache() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
Returns an unregistered new object cache
getUnregisteredNewObjectsInParent() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This is used to store unregistered objects discovered in the parent so that the child unit of work knows not to register them on commit.
getUOWChangeSet() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
ADVANCED: This method is used to return the parent UnitOfWorkChangeSet.
getUOWChangeSet() - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCED: This method is used to return the parent ChangeSet.
getUOWCloneForObjectChangeSet(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
ADVANCED: This method returns the Clone for a particular changeSet
getUOWCloneForObjectChangeSet(ObjectChangeSet) - Method in interface org.eclipse.persistence.sessions.changesets.UnitOfWorkChangeSet
ADVANCED: This method returns the Clone for a particular changeSet
getUpdateAllFields() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
ADVANCED: Return true if descriptor is set to update all fields for an object of this type when an update occurs.
getUpdateAtIndexQuery() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
getUpdateCall() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's update call.
getUpdateCallCacheSize() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the size of the update call cache.
getUpdateClauses() - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
getUpdateClauses() - Method in class org.eclipse.persistence.queries.UpdateAllQuery
INTERNAL: Return the updates stored for an update all query
getUpdateQuery() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's update query.
getUpdateQuery() - Method in class org.eclipse.persistence.sequencing.QuerySequence
PUBLIC:
getUpdateSequenceQuery() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
OBSOLETE: This method lazy initializes the update sequence number query.
getUpdateSQLString() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return the receiver's update SQL string.
getUri() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.Attribute
 
getURI(int) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
getURI(int) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
getUrl() - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
PUBLIC: Return the URL for this command manager.
getUrl() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
PUBLIC: Return the URL for this command manager.
getURL() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
 
getURL() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.RMIRegistryNamingServiceConfig
 
getURL() - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaClassPathReference
 
getURL() - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaFileReference
 
getURL() - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
 
getURL() - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaURLReference
 
getURL() - Method in interface org.eclipse.persistence.platform.xml.XMLSchemaReference
A URL which referenes the Schema.
getURL() - Method in class org.eclipse.persistence.sessions.coordination.ServiceId
INTERNAL: Return the URL for the service
getURL() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return the JDBC URL.
getURLString() - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaURLReference
 
getUse() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Attribute
 
getUseDescriptorsToValidateInheritedObjects() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: return if we should use the descriptor inheritance to determine if an object can be returned from the identity map or not.
getUsedFields() - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatementForTempTable
 
getUsedFields() - Method in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
getUsedFields() - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForTempTable
 
getUseExclusiveConnection() - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPolicyConfig
 
getUseLazyInstantiation() - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
 
getUseNationalCharacterVaryingTypeForString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
getUserJavaTypesForDeploymentXML() - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL:
getUsername() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
getUsername() - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
 
getUserName() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
PUBLIC: Return the user name used as the value to the SECURITY_PRINCIPAL key in the cached context properties.
getUserName() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: The user name is the database login name.
getUserName() - Method in interface org.eclipse.persistence.sessions.Login
PUBLIC: All logins must take a user name and password.
getUserXMLTypesForDeploymentXML() - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL:
getUsesBatchWriting() - Method in class org.eclipse.persistence.services.DevelopmentServices
This method will return if batchWriting is in use or not.
getUsesBatchWriting() - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method will return if batchWriting is in use or not.
getUsesBatchWriting() - Method in class org.eclipse.persistence.services.RuntimeServices
This method will return if batchWriting is in use or not.
getUsesBinding() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used to help bean introspection.
getUsesByteArrayBinding() - Method in class org.eclipse.persistence.services.DevelopmentServices
Shows if Byte Array Binding is turned on or not
getUsesByteArrayBinding() - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
Shows if Byte Array Binding is turned on or not
getUsesByteArrayBinding() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Shows if Byte Array Binding is turned on or not
getUsesByteArrayBinding() - Method in class org.eclipse.persistence.services.RuntimeServices
Shows if Byte Array Binding is turned on or not
getUsesEclipseLinkProfiling() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method answers true if EclipseLink Performance Profiling is on.
getUsesEclipseLinkProfiling() - Method in class org.eclipse.persistence.services.RuntimeServices
This method answers true if EclipseLink Performance Profiling is on.
getUsesJDBCBatchWriting() - Method in class org.eclipse.persistence.services.DevelopmentServices
This method will return if batchWriting is in use or not.
getUsesJDBCBatchWriting() - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method will return if batchWriting is in use or not.
getUsesJDBCBatchWriting() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will return if batchWriting is in use or not.
getUsesJDBCBatchWriting() - Method in class org.eclipse.persistence.services.RuntimeServices
This method will return if batchWriting is in use or not.
getUsesNativeSequencing() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used to help bean introspection.
getUsesNativeSQL() - Method in class org.eclipse.persistence.services.DevelopmentServices
Shows if native SQL is being used
getUsesNativeSQL() - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
Shows if native SQL is being used
getUsesNativeSQL() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Shows if native SQL is being used
getUsesNativeSQL() - Method in class org.eclipse.persistence.services.RuntimeServices
Shows if native SQL is being used
getUsesNativeSQL() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used to help bean introspection.
getUsesStreamsForBinding() - Method in class org.eclipse.persistence.services.DevelopmentServices
This method indicates if streams are being used for binding
getUsesStreamsForBinding() - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method indicates if streams are being used for binding
getUsesStreamsForBinding() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method indicates if streams are being used for binding
getUsesStreamsForBinding() - Method in class org.eclipse.persistence.services.RuntimeServices
This method indicates if streams are being used for binding
getUsesStreamsForBinding() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used to help bean introspection.
getUsesStringBinding() - Method in class org.eclipse.persistence.services.DevelopmentServices
This method indicates if Strings are being bound
getUsesStringBinding() - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method indicates if Strings are being bound
getUsesStringBinding() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method indicates if Strings are being bound
getUsesStringBinding() - Method in class org.eclipse.persistence.services.RuntimeServices
This method indicates if Strings are being bound
getUsesStringBinding() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used to help bean introspection.
getUseUniqueFieldAliases() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Return True if unique field aliases will be generated of the form "fieldname AS fieldnameX", False otherwise.
getUseUpperCaseForComparisons() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
getUUIDQuery() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
This method can be overridden by subclasses to return a query that will return the UUID from the server.
getUUIDQuery() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
This method can be overridden by subclasses to return a query that will return the UUID from the server.
getUUIDQuery() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: This method returns the query to select the UUID from the server for MySQL.
getValidationLevel() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not referred in the unit of work cache.
getValidationLevel() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not referred in the unit of work cache.
getValidationMode() - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
getValidationMode() - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
getValidationMode() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
getValidationMode() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Get the validation mode set on this XMLUnmarshaller By default, the unmarshaller is set to be NONVALIDATING
getValidationMode() - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
getValidatorHandler() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
getValidatorHandler() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
getValue() - Method in class org.eclipse.persistence.history.AsOfClause
PUBLIC: The past time represented by the receiver.
getValue() - Method in class org.eclipse.persistence.indirection.ValueHolder
PUBLIC: Return the wrapped object.
getValue() - Method in interface org.eclipse.persistence.indirection.ValueHolderInterface
PUBLIC: Return the value.
getValue() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl.PropertyWrapper
Gets the value.
getValue() - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
 
getValue() - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
 
getValue() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Return the object.
getValue() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.Attribute
 
getValue() - Method in interface org.eclipse.persistence.internal.oxm.XMLSetting
Gets the value to be marshalled using the specified mapping.
getValue() - Method in class org.eclipse.persistence.internal.oxm.XPathPredicate
 
getValue() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordEntry
 
getValue() - Method in class org.eclipse.persistence.internal.sessions.factories.model.property.PropertyConfig
 
getValue() - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.ObjectTypeFieldAssociation
 
getValue() - Method in class org.eclipse.persistence.mappings.Association
PUBLIC: Return the value.
getValue() - Method in class org.eclipse.persistence.mappings.transformers.ConstantTransformer
PUBLIC: Return the value of the constant.
getValue() - Method in class org.eclipse.persistence.oxm.record.XMLEntry
 
getValue() - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
getValue() - Method in class org.eclipse.persistence.queries.ReportQueryResult.RecordEntry
 
getValue(int) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
getValue(int) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
getValue(CharSequence, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
This call back mechanism provides an opportunity for the XMLReader to provide an alternate conversion.
getValue(Object, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.ChoiceUnmarshalContext
 
getValue(Object, AbstractSession) - Method in interface org.eclipse.persistence.descriptors.CMPPolicy.KeyElementAccessor
 
getValue(Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.CMPPolicy.KeyIsElementAccessor
 
getValue(String) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
getValue(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
getValue(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
getValue(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
getValue(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
Extract the value from the row.
getValue(AbstractRecord, DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
Extract the value from the row.
getValue(UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.indirection.CacheBasedValueHolder
Process against the UOW and attempt to load a local copy before going to the shared cache If null is returned then the calling UOW will instantiate as normal.
getValue(UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Process against the UOW and attempt to load a local copy before going to the shared cache If null is returned then the calling UOW will instantiate as normal.
getValue(UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
Process against the UOW and attempt to load a local copy before going to the shared cache If null is returned then the calling UOW will instantiate as normal.
getValue(Session) - Method in class org.eclipse.persistence.internal.descriptors.MultitenantPrimaryKeyAccessor
The only API of value on this accessor is getValue.
getValueByXPath(Object, String, NAMESPACE_RESOLVER, Class<T>) - Method in class org.eclipse.persistence.internal.oxm.Context
Query the object model based on the corresponding document.
getValueByXPath(Object, String, NamespaceResolver, Class<T>) - Method in class org.eclipse.persistence.oxm.XMLContext
Query the object model based on the corresponding XML document.
getValueClass() - Method in class org.eclipse.persistence.mappings.DirectMapMapping
PUBLIC: This is a helper method to get the object class from the value converter if it is a TypeConversionConverter.
getValueConverter() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
Return the converter on the mapping.
getValueConverter() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Return the converter on the mapping.
getValueConverter() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
PUBLIC: Return the converter on the mapping.
getValueConverter() - Method in class org.eclipse.persistence.queries.DataReadQuery
INTERNAL: Conversion not supported.
getValueConverter() - Method in class org.eclipse.persistence.queries.DirectReadQuery
PUBLIC: Return the converter on the query.
getValueForInOutParameter(Object, AbstractRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: Returns value for INOUT parameter.
getValueForInParameter(Object, AbstractRecord, AbstractRecord, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: Returns value for IN parameter.
getValueFromField(Field, Object) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get the value of the given field in the given object.
getValueFromObjectForExpression(AbstractSession, Object, ObjectExpression) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
INTERNAL: Helper method to get the value from the clone for the expression passed in, triggering joins on all intermediate steps.
getValueFromProxy(Object) - Static method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Given a proxy object, trigger the indirection and return the actual object represented by the proxy.
getValueFromRecord(String, MappedRecord, EISAccessor) - Method in class org.eclipse.persistence.eis.EISPlatform
Retrieves the field value from the record.
getValueFromRecord(DatabaseRecord) - Method in class org.eclipse.persistence.queries.FieldResult
INTERNAL: This method is a convenience method for extracting values from Results
getValueFromRecord(DatabaseRecord, ResultSetMappingQuery) - Method in class org.eclipse.persistence.queries.ColumnResult
INTERNAL: This method is a convenience method for extracting values from Results
getValueFromRecord(DatabaseRecord, ResultSetMappingQuery) - Method in class org.eclipse.persistence.queries.ConstructorResult
INTERNAL: This method is a convenience method for extracting values from results/
getValueFromRecord(DatabaseRecord, ResultSetMappingQuery) - Method in class org.eclipse.persistence.queries.EntityResult
INTERNAL: This method is a convenience method for extracting values from Results
getValueFromRecord(DatabaseRecord, ResultSetMappingQuery) - Method in class org.eclipse.persistence.queries.SQLResult
INTERNAL: This method is a convenience method for extracting values from Results
getValueFromRecordForMapping(DatabaseRecord, DatabaseMapping, FieldResult, DatabaseRecord) - Method in class org.eclipse.persistence.queries.EntityResult
INTERNAL: This method is for processing all FieldResults for a mapping.
getValueFromRemoteValueHolder(RemoteValueHolder) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: extract and return the appropriate value from the specified remote value holder
getValueFromRemoteValueHolder(RemoteValueHolder) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Extract and return the appropriate value from the specified remote value holder.
getValueFromRemoteValueHolder(RemoteValueHolder) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Extract and return the appropriate value from the specified remote value holder.
getValueFromRemoteValueHolder(RemoteValueHolder<?>) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Extract and return the appropriate value from the specified remote value holder.
getValueFromRemoteValueHolder(RemoteValueHolder<?>) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Extract and return the appropriate value from the specified remote value holder.
getValueFromRemoteValueHolder(RemoteValueHolder<?>) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Extract and return the appropriate value from the specified remote value holder.
getValueFromRemoteValueHolder(RemoteValueHolder<?>) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Extract and return the appropriate value from the specified remote value holder.
getValueFromResultSet(int, DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
 
getValueFromServerObject() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
This is used for a remote unit of work.
getValueHolder() - Method in interface org.eclipse.persistence.indirection.IndirectContainer
PUBLIC: This is used by the indirection policy to build the UOW clone of the container.
getValueHolder() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Return the valueHolder.
getValueHolder() - Method in class org.eclipse.persistence.indirection.IndirectMap
PUBLIC: Return the valueHolder.
getValueHolder() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Return the valueHolder.
getValueHolder() - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionHandler
INTERNAL: Get the ValueHolder associated with this handler.
getValueMapping() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
 
getValues() - Method in class org.eclipse.persistence.eis.EISMappedRecord
INTERNAL: getValues() is sued internally in a few places, so try to make that work for mapped records.
getValues() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL:
getValues() - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
INTERNAL:
getValues() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: This should not be used, but added some support for it as is called from some places such as sdk call used in the descriptor to define operation not supported, may also be called from TopLink in some places.
getValues(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
 
getValues(String) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Retrieve the value for the field name.
getValues(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
 
getValues(DatabaseField) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Given a DatabaseField, return the corresponding values from the document
getValues(DatabaseField, AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
getValuesIndicatingNoEntry(List<DatabaseField>) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
getValuesIndicatingNoEntry(List<DatabaseField>, boolean) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
getValuesIndicatingNoEntry(DatabaseField) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
getValuesIndicatingNoEntry(DatabaseField, boolean) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Given a DatabaseField, return the corresponding values from the document
getValuesIndicatingNoEntry(DatabaseField, boolean, AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
getValuesIndicatingNoEntry(DatabaseField, AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
getValuesToExclude() - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: Decides which attributes to ignore based on the values they are set to.
getValueToPutInCache(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Return the value that should be stored in the identity map.
getValueToPutInCache(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: Return the value that should be stored in the identity map.
getValueToPutInCache(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Return the value that should be stored in the identity map.
getValueToPutInCache(AbstractRecord, AbstractSession) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: Return the value that should be stored in the identity map.
getValueToWrite(Object, Object, XMLRecord, XMLField, XMLField, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
getValueToWrite(QName, Object, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
getValueToWrite(QName, Object, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
getValueToWrite(QName, Object, ConversionManager) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
getValueToWrite(QName, Object, ConversionManager) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
getValueToWrite(QName, Object, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
Return a string representation of a given value, based on a given schema type.
getValueType() - Method in class org.eclipse.persistence.mappings.TypedAssociation
PUBLIC: Return the class of the value.
getValueWrapper() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Name of the property to marshal/unmarshal as a wrapper on the text() mappings Ignored unmarshalling XML.
getValueWrapper() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Name of the property to marshal/unmarshal as a wrapper on the text() mappings Ignored marshalling XML.
getValueWrapper() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Name of the property to marshal/unmarshal as a wrapper on the text() mappings Ignored unmarshalling XML.
getVariableAttributeAccessor() - Method in interface org.eclipse.persistence.internal.oxm.mappings.VariableXPathObjectMapping
 
getVariableAttributeAccessor() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
getVariableAttributeAccessor() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
getVariableAttributeName() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
getVariableAttributeName() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
getVariableGetMethodName() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
getVariableGetMethodName() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
getVariables() - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The variables are the names of the declared variables used in the procedure.
getVariableSetMethodName() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
getVariableSetMethodName() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
getVectorOfFieldsToGenerate(int, DatabaseTable) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
getVendorConnectionMethod() - Method in class org.eclipse.persistence.platform.server.was.WebSpherePlatform
Return the method for the WebSphere JDBC connection wrapper vendorConnection.
getVendorConnectionMethod() - Method in class org.eclipse.persistence.platform.server.wls.WebLogic_10_Platform
Return the method for the WebLogic JDBC connection wrapper vendorConnection.
getVendorConnectionMethod() - Method in class org.eclipse.persistence.platform.server.wls.WebLogicPlatform
Return the method for the WebLogic JDBC connection wrapper vendorConnection.
getVersion() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
Gets the XML Version for this document.
getVersion() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
PUBLIC: Gets the XML Version for this document.
getVersion() - Method in class org.eclipse.persistence.internal.sessions.factories.model.SessionConfigs
 
getVersion() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
Gets the XML Version for this document.
getVersion() - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
getVersion() - Static method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Return the EclipseLink version.
getVersion() - Static method in class org.eclipse.persistence.Version
 
getVersionDifference(Object, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Return the number of version difference between the two states of the object.
getVersionDifference(Object, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: Return the number of versions different between these objects.
getVersionDifference(Object, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
PUBLIC: Return the number of versions different between these objects.
getVersionDifference(Object, Object, Object, AbstractSession) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
PUBLIC: Return the number of versions different between these objects.
getVersionMapping() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Returns the mapping that will be used to access the version value from an object.
getVersionString() - Static method in class org.eclipse.persistence.Version
Returns version String containing three part version number and build qualifier.
getViewTable() - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL:
getVirtualAttributeMethods() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return the list of virtual methods sets for this Entity.
getVisitedGrandparent() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Return the second-to-last object visited.
getVisitedObjects() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
getVisitedParent() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Return the last object visited.
getVisitedStack() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
getVPDClearIdentifierQuery(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Any platform that supports VPD should implement this method.
getVPDClearIdentifierQuery(String) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Return an Oracle defined VPD clear identifier query.
getVPDCreationFunctionString(String, String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Any platform that supports VPD should implement this method.
getVPDCreationFunctionString(String, String) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Return an Oracle defined VPD identifier function.
getVPDCreationPolicyString(String, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Any platform that supports VPD should implement this method.
getVPDCreationPolicyString(String, AbstractSession) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Return an Oracle defined VPD identifier policy.
getVPDDeletionString(String, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Any platform that supports VPD should implement this method.
getVPDDeletionString(String, AbstractSession) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Return an Oracle defined VPD identifier policy deletion.
getVPDIdentifier() - Method in class org.eclipse.persistence.descriptors.VPDMultitenantPolicy
INTERNAL: Return the single identifier.
getVPDIdentifier() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return the VPD identifier for this project.
getVPDLastIdentifierClassName() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return the name of the last class to set a VPD identifiers.
getVPDSetIdentifierQuery(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Any platform that supports VPD should implement this method.
getVPDSetIdentifierQuery(String) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Return an Oracle defined VPD set identifier query.
getWaitTimeout() - Method in class org.eclipse.persistence.internal.expressions.ForUpdateClause
 
getWaitTimeout() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Return the WAIT timeout value of pessimistic locking query.
getWaitTimeout() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Return the time in milliseconds to wait for a available connection.
getWaitTimeoutUnit() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
getWeavedGetMethodName(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return the set method name weaved for getting attribute value.
getWeavedSetMethodName(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return the set method name weaved for setting attribute value.
getWeavedValueHolderGetMethodName(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return the get method name weaved for a value-holder attribute.
getWeavedValueHolderSetMethodName(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return the set method name weaved for a value-holder attribute.
getWebLogicConnectionClass() - Method in class org.eclipse.persistence.platform.server.wls.WebLogicPlatform
Return the class (interface) for the WebLogic JDBC connection wrapper.
getWebsphereConnectionClass() - Method in class org.eclipse.persistence.platform.server.was.WebSpherePlatform
Return the class (interface) for the WebSphere JDBC connection wrapper.
getWebsphereUtilClass() - Method in class org.eclipse.persistence.platform.server.was.WebSpherePlatform
Return the class (interface) for the WebSphere JDBC connection wrapper.
getWeight() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return the weight of the mapping, used to sort mappings to ensure that DirectToField Mappings get merged first
getWeight() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Return the weight of the mapping, used to sort mappings to ensure that DirectToField Mappings get merged first
getWhereClause() - Method in class org.eclipse.persistence.internal.expressions.SQLStatement
 
getWithAllSubclassesExpression() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: Return the Expression which gets all subclasses.
getWorkingCopyMethod() - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Return the workingCopyClone method.
getWorkingCopyMethodName() - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Return the workingCopyClone method name.
getWrappedCacheKey() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
If a Wrapper subclasses this CacheKey this method will be used to unwrap the cache key.
getWrappedCacheKey() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
If a Wrapper subclasses this CacheKey this method will be used to unwrap the cache key.
getWrappedServerValueHolder() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Return the original value holder.
getWrappedType() - Method in class org.eclipse.persistence.internal.sessions.factories.ComplexPLSQLTypeWrapper
 
getWrappedType() - Method in class org.eclipse.persistence.internal.sessions.factories.DatabaseTypeWrapper
 
getWrappedType() - Method in class org.eclipse.persistence.internal.sessions.factories.JDBCTypeWrapper
 
getWrappedType() - Method in class org.eclipse.persistence.internal.sessions.factories.OracleArrayTypeWrapper
 
getWrappedType() - Method in class org.eclipse.persistence.internal.sessions.factories.OracleObjectTypeWrapper
 
getWrappedType() - Method in class org.eclipse.persistence.internal.sessions.factories.PLSQLCollectionWrapper
 
getWrappedType() - Method in class org.eclipse.persistence.internal.sessions.factories.PLSQLCursorWrapper
 
getWrappedType() - Method in class org.eclipse.persistence.internal.sessions.factories.PLSQLRecordWrapper
 
getWrappedType() - Method in class org.eclipse.persistence.internal.sessions.factories.SimplePLSQLTypeWrapper
 
getWrappedValueHolder() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
 
getWrappedValueHolder() - Method in class org.eclipse.persistence.internal.indirection.ProtectedValueHolder
 
getWrappedValueHolder() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
getWrappedValueHolder() - Method in interface org.eclipse.persistence.internal.indirection.WrappingValueHolder
Returns the valueholder that is wrapped by this ValueHolder
getWrappedValueHolderRemoteID() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
returns wrapped ValueHolder ObjID if available
getWrapper() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
getWrapper() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
getWrapper(Object) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Get the wrapper object from the cache key associated with the given primary key, this is used for EJB2.
getWrapper(Object) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Get the wrapper object from the cache key associated with the given primary key, this is used for EJB2.
getWrapper(Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Get the wrapper object from the cache key associated with the given primary key, this is used for EJB2.
getWrapper(Object, Class<?>) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Get the wrapper object from the cache key associated with the given primary key, this is used for EJB.
getWrapper(Object, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Get the wrapper object from the cache key associated with the given primary key, this is used for EJB.
getWrapper(Object, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Get the wrapper object from the cache key associated with the given primary key, this is used for EJB.
getWrapperClass(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns the wrapper class for the specified primitive.
getWrapperNullPolicy() - Method in interface org.eclipse.persistence.internal.oxm.mappings.XMLContainerMapping
Get the Wrapper NullPolicy from the Mapping.
getWrapperNullPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
getWrapperNullPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
getWrapperNullPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
getWrapperNullPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
 
getWrapperNullPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
getWrapperNullPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
getWrapperNullPolicy() - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
 
getWrapperPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Return the WrapperPolicy for this descriptor.
getWriteConnection() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Return the connection to be used for database modification.
getWriteConnectionPoolConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.PoolsConfig
 
getWriteConnections() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Return the map of write connections.
getWriteLockField() - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Return the write lock field.
getWriteLockField() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Return the write lock field.
getWriteLockField() - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: Return the write lock field.
getWriteLockFieldName() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
PUBLIC: Return the field name of the field that stores the write lock value.
getWriteLockManager() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Returns the single write Lock manager for this session
getWriteLockManager() - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Returns the single write Lock manager for this session
getWriteLockManager() - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Returns the single write Lock manager for this session
getWriteLockQueued() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTENRAL: Used to get the object that the merge manager is waiting on, in order to acquire locks
getWriteLockUpdateExpression(ExpressionBuilder, AbstractSession) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL:
getWriteLockUpdateExpression(ExpressionBuilder, AbstractSession) - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: Return an expression that updates the write lock
getWriteLockUpdateExpression(ExpressionBuilder, AbstractSession) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Retrun an expression that updates the write lock
getWriteLockUpdateExpression(ExpressionBuilder, AbstractSession) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: This method will return an expression that is used to update its optimistic locking field #see this method in VersionLockingPolicy
getWriteLockValue() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
getWriteLockValue() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: This method is used to return the lock value of the object this changeSet represents.
getWriteLockValue() - Method in class org.eclipse.persistence.internal.sessions.remote.ObjectDescriptor
Return the write lock value of an associated object
getWriteLockValue() - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCED: This method is used to return the lock value of the object this changeSet represents.
getWriteLockValue() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
getWriteLockValue(Object) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Get the write lock value from the cache key associated to the primarykey.
getWriteLockValue(Object) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Get the write lock value from the cache key associated to the primarykey.
getWriteLockValue(Object) - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Return null as no objects are cached.
getWriteLockValue(Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Extract the write lock value from the identity map.
getWriteLockValue(Object) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Extracts and returns the write lock value from the identity map through the given Object.
getWriteLockValue(Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Get the write lock value from the cache key associated to the primarykey.
getWriteLockValue(Object, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Extract the write lock value from the identity map.
getWriteLockValue(Object, Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Extracts the write lock value from the identity map through the passed in primaryKey and Class type.
getWriteLockValue(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Retrieve the write lock value of the cache key associated with the given primary key,
getWriteLockValue(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Extract the write lock value from the identity map.
getWriteLockValue(Object, Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
ADVANCED: Extract the write lock value from the identity map.
getWriteLockValue(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: This method will return the optimistic lock value for the object
getWriteLockValue(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: This method will return the optimistic lock value for the object.
getWriteLockValue(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: This method will return the optimistic lock value for the object
getWriteLockValue(Object, Object, AbstractSession) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: This method will return the optimistic lock value for the object #see this method in VersionLockingPolicy
getWriteObjectQuery() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Convenience method
getWriter() - Method in class org.eclipse.persistence.internal.expressions.ExpressionJavaPrinter
 
getWriter() - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
getWriter() - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
getWriter() - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Return the writer to which an accessor writes logged messages and SQL.
getWriter() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
Return the Writer that the object will be marshalled to.
getWriter() - Method in interface org.eclipse.persistence.oxm.record.JSONWriterRecord.Output
 
getWriter() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.OutputStreamOutput
 
getWriter() - Method in class org.eclipse.persistence.oxm.record.WriterRecord
Return the Writer that the object will be marshalled to.
getWriter() - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
 
getWriter(String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
getWriterFilename() - Method in class org.eclipse.persistence.logging.DefaultSessionLog
For the given writer, return it's associated filename.
getWriteStatementsCount() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return the number of write statements.
getXMLBinaryDataHelper() - Static method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
getXMLContext() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Return the instance of XMLContext that was used to create this instance of XMLUnmarshaller.
getXMLContext() - Method in class org.eclipse.persistence.oxm.XMLMarshaller
Return the instance of XMLContext that was used to create this instance of XMLMarshaller.
getXMLContext() - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
Return the instance of XMLContext that was used to create this instance of XMLUnmarshaller.
getXMLContextState() - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Return the XMLContextState that represents the XMLContexts stateful information.
getXmlEventReader() - Method in class org.eclipse.persistence.internal.oxm.record.XMLEventReaderInputSource
 
getXMLEventWriter() - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
getXmlField() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceFieldToClassAssociation
 
getXMLField() - Method in class org.eclipse.persistence.internal.oxm.FieldTransformerNodeValue
 
getXMLField() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getXMLField() - Method in class org.eclipse.persistence.oxm.record.XMLEntry
 
getXmlHeader() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Get this Marshaller's XML Header.
getXMLNode(Object) - Method in class org.eclipse.persistence.oxm.XMLBinder
Gets the XML Node associated with the provided object.
getXMLPlatform() - Method in class org.eclipse.persistence.platform.xml.XMLPlatformFactory
INTERNAL: Return the XMLPlatform based on the toplink.xml.platform System property.
getXMLPlatformClass() - Method in class org.eclipse.persistence.platform.xml.XMLPlatformFactory
INTERNAL: Return the implementation class for the XMLPlatform.
getXMLReader() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
getXMLReader() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getXMLReader() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getXMLReader() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getXMLSchema() - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
getXmlStreamReader() - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceContext
 
getXmlStreamReader() - Method in class org.eclipse.persistence.internal.oxm.record.XMLStreamReaderInputSource
 
getXMLStreamWriter() - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
getXmlType() - Method in class org.eclipse.persistence.internal.oxm.XMLConversionPair
 
getXMLType(Class<?>) - Method in class org.eclipse.persistence.oxm.XMLField
Return the qualified XML Schema type for a given class
getXMLType(Class<?>, ConversionManager) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Return the qualified XML Schema type for a given class
getXMLType(Class<?>, ConversionManager) - Method in class org.eclipse.persistence.oxm.XMLField
 
getXMLVersion() - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.LocatorImpl
 
getXMLVersion() - Method in class org.eclipse.persistence.internal.oxm.Root
Gets the XML version which will be set on the XMLRoot during unmarshal.
getXPath() - Method in class org.eclipse.persistence.eis.mappings.EISCompositeCollectionMapping
Get the XPath String
getXPath() - Method in class org.eclipse.persistence.eis.mappings.EISCompositeDirectCollectionMapping
Get the XPath String
getXPath() - Method in class org.eclipse.persistence.eis.mappings.EISCompositeObjectMapping
Get the XPath String
getXPath() - Method in class org.eclipse.persistence.eis.mappings.EISDirectMapping
Get the XPath String associated with this Mapping
getXPath() - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
Get the XPath String
getXPath() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
Get the XPath String
getXPath() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Returns the xpath statement associated with this XMLField
getXPath() - Method in interface org.eclipse.persistence.internal.oxm.mappings.FragmentMapping
 
getXPath() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
getXPath() - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
Get the XPath String
getXPath() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
Get the XPath String
getXPath() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
Get the XPath String
getXPath() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
Get the XPath String
getXPath() - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
Get the XPath String
getXPath() - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
Get the XPath String
getXPath() - Method in class org.eclipse.persistence.oxm.XMLField
Returns the xpath statement associated with this XMLField
getXPathFragment() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
INTERNAL: Maintain a direct pointer to the first XPathFragment.
getXPathFragment() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
getXPathFragment() - Method in class org.eclipse.persistence.internal.oxm.XPathPredicate
 
getXPathFragment() - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL: Maintain a direct pointer to the first XPathFragment.
getXPathFragmentForValue(Object, NamespaceResolver, boolean, char) - Method in interface org.eclipse.persistence.internal.oxm.mappings.VariableXPathObjectMapping
 
getXPathFragmentForValue(Object, NamespaceResolver, boolean, char) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
getXPathFragmentForValue(Object, NamespaceResolver, boolean, char) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
getXPathNode() - Method in class org.eclipse.persistence.internal.oxm.NodeValue
 
getXPathNode() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
getXPathNode() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
getXPathNode() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
getXQueryString() - Method in class org.eclipse.persistence.eis.interactions.XQueryInteraction
PUBLIC: Return the XQuery string.
Glassfish - Static variable in class org.eclipse.persistence.config.TargetServer
 
GlassfishPlatform - Class in org.eclipse.persistence.platform.server.glassfish
PUBLIC: This is the concrete subclass responsible for representing Glassfish server behavior.
GlassfishPlatform(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.glassfish.GlassfishPlatform
INTERNAL: Default Constructor: All behavior for the default constructor is inherited
GlassfishPlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL: The generic platform configuration for the Glassfish server.
GlassfishPlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.GlassfishPlatformConfig
 
GlassfishPlatformDetector - Class in org.eclipse.persistence.platform.server.glassfish
 
GlassfishPlatformDetector() - Constructor for class org.eclipse.persistence.platform.server.glassfish.GlassfishPlatformDetector
Default constructor.
GlassfishRuntimeServices - Class in org.eclipse.persistence.services.glassfish
Purpose: Provide a dynamic interface into the EclipseLink Session.
GlassfishRuntimeServices() - Constructor for class org.eclipse.persistence.services.glassfish.GlassfishRuntimeServices
PUBLIC: Default Constructor
GlassfishRuntimeServices(Locale) - Constructor for class org.eclipse.persistence.services.glassfish.GlassfishRuntimeServices
Create an instance of GlassfishRuntimeServices to be associated with the provided locale The user must call setSession(Session) afterwards to define the session.
GlassfishRuntimeServices(AbstractSession) - Constructor for class org.eclipse.persistence.services.glassfish.GlassfishRuntimeServices
PUBLIC: Create an instance of GlassfishRuntimeServices to be associated with the provided session
GlassfishTransactionController - Class in org.eclipse.persistence.transaction.glassfish
Purpose: TransactionController implementation for Glassfish JTA
GlassfishTransactionController() - Constructor for class org.eclipse.persistence.transaction.glassfish.GlassfishTransactionController
 
GlassfishTransactionController11 - Class in org.eclipse.persistence.transaction.glassfish
Purpose: TransactionController implementation for Glassfish JTA
GlassfishTransactionController11() - Constructor for class org.eclipse.persistence.transaction.glassfish.GlassfishTransactionController11
 
GLOBAL_PROPERTY_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
globalPropertyNotFound() - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when trying to find a global property during an unmarshal
GMT_ID - Static variable in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
GMT_SUFFIX - Static variable in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
greaterThan() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
greaterThan(boolean) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is equal to the other value.
greaterThan(byte) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is equal to the other value.
greaterThan(char) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is equal to the other value.
greaterThan(double) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is equal to the other value.
greaterThan(float) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is equal to the other value.
greaterThan(int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is equal to the other value.
greaterThan(long) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is equal to the other value.
greaterThan(short) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is equal to the other value.
greaterThan(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receiver's value is greater than the other value.
greaterThan(Expression) - Method in class org.eclipse.persistence.expressions.Expression
 
GreaterThan - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
greaterThanEqual() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
greaterThanEqual(boolean) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is greater and equal to the other value.
greaterThanEqual(byte) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is greater and equal to the other value.
greaterThanEqual(char) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is greater and equal to the other value.
greaterThanEqual(double) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is greater and equal to the other value.
greaterThanEqual(float) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is greater and equal to the other value.
greaterThanEqual(int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is greater and equal to the other value.
greaterThanEqual(long) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is greater and equal to the other value.
greaterThanEqual(short) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is greater and equal to the other value.
greaterThanEqual(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is greater and equal to the other value.
greaterThanEqual(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is greater and equal to the other value.
GreaterThanEqual - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
greaterThanEqualOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
DB2 z/OS requires that at least one argument be a known type
greaterThanEqualOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
greaterThanOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
DB2 z/OS requires that at least one argument be a known type
greaterThanOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
greatest() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
greatest() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
INTERNAL: Build FB equivalent to GREATEST(x, y) FB: CASE WHEN x >= y THEN x ELSE y END
greatest() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
INTERNAL: Build HSQL equivalent to GREATEST(x, y) HSQL: CASE WHEN x >= y THEN x ELSE y
greatest() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the greatest of two values.
Builds Symfoware equivalent to GREATEST(x, y).
Symfoware: CASE WHEN x >= y THEN x ELSE y END
Greatest - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
GREGORIAN_CALENDAR - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
group - Variable in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
Group - Class in org.eclipse.persistence.internal.oxm.schema.model
 
Group() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Group
 
GROUP - Static variable in interface org.eclipse.persistence.platform.xml.XMLSchemaReference
 
groupByExpressions - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Group by clause for report queries.
groupByExpressions - Variable in class org.eclipse.persistence.queries.ReportQuery
Expressions representing fields to be used in the GROUP BY clause.
GROUPING_ELEMENT_REQUIRED - Static variable in exception org.eclipse.persistence.eis.EISException
 
groupingElementRequired() - Static method in exception org.eclipse.persistence.eis.EISException
 
GT - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
gte(JavaSEPlatform) - Method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Check if this platform is equal or greater to specified platform.

H

H2Platform - Class in org.eclipse.persistence.platform.database
 
H2Platform() - Constructor for class org.eclipse.persistence.platform.database.H2Platform
 
HANA - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
HANAPlatform - Class in org.eclipse.persistence.platform.database
Database Platform for SAP HANA
HANAPlatform() - Constructor for class org.eclipse.persistence.platform.database.HANAPlatform
 
handleAttributes(Attributes) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
handleAttributes(Attributes) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
handleAttributes(Attributes) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
handleAttributes(Attributes) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
handleChildNodes(NodeList) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
handleCommunicationException(RemoteConnection, CommunicationException) - Method in class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
INTERNAL: We received the specified CommunicationException trying to execute the command over the specified connection.
handleError(RuntimeException) - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
INTERNAL: This method handles all the Descriptor Exceptions.
handleException(RuntimeException) - Method in interface org.eclipse.persistence.exceptions.ExceptionHandler
To re-throwing the exception,throwing a different exception or re-trying the query or database operation.
handleException(RuntimeException) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Allow any WARNING level exceptions that occur within EclipseLink to be logged and handled by the exception handler.
handleException(RuntimeException) - Method in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
PUBLIC: Allow the implementation class to handle an exception thrown in in the remote command service.
handleException(RuntimeException) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
INTERNAL: Delegate to the command procesor to handle the exception.
handleException(RuntimeException) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Allow any WARNING level exceptions that occur within EclipseLink to be logged and handled by the exception handler.
handleException(RuntimeException) - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
INTERNAL: Do the appropriate thing for when an exception occurs during SQL issuance.
handleExceptionFromRemoteExecution(RemoteConnection, String) - Method in class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
INTERNAL: We received the specified exception String while executing the command over the specified connection.
handleFragNamespace(XPathFragment, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties, Element, String) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
This method will generate a global element if required (based in URI and elementFormDefault) and set a reference to it on a given element accordingly.
handleFragNamespace(XPathFragment, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties, Element, ComplexType, Descriptor) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
This method will generate a global element if required (based in URI and elementFormDefault) and set a reference to it on a given element accordingly, or set an anonymous complex type on a given element.
handleNewNamespaceDeclaration(Element, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
handleNewNamespaceDeclaration(Element, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
 
handlePrefixedAttribute(Element) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
Handle prefixed attribute - may need to declare the namespace URI locally.
handlePrefixedAttribute(Element) - Method in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
Handle prefixed attribute - may need to declare the namespace URI locally.
handleSevere(RuntimeException) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Allow any SEVERE level exceptions that occur within EclipseLink to be logged and handled by the exception handler.
handleSevere(RuntimeException) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Allow any SEVERE level exceptions that occur within EclipseLink to be logged and handled by the exception handler.
handleTransactionsManuallyForSybaseJConnect() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Force EclipseLink to manually begin transactions instead of using autoCommit.
handleXsiTypeAttribute(Attr) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
handleXsiTypeAttribute(Attr) - Method in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
 
HARD - org.eclipse.persistence.config.ReferenceMode
References to Objects will be through hard references.
HARD_WEAK - org.eclipse.persistence.annotations.CacheType
Identical to the soft cache weak (SOFT_WEAK) identity map except that it uses hard references in the sub-cache.
HardCacheWeakIdentityMap - Class in org.eclipse.persistence.internal.identitymaps
Purpose: A HardCacheWeakIdentityMap is identical to the weak identity map, however the weak reference can be a performance problem for some types of apps because it can cause too much garbage collection of objects read causing them to be re-read and re-built (this defeats the purpose of the cache).
HardCacheWeakIdentityMap(int, ClassDescriptor, AbstractSession, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap
 
HardCacheWeakIdentityMap_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
HardCacheWeakIdentityMap.ReferenceCacheKey - Class in org.eclipse.persistence.internal.identitymaps
Inner class to define the specialized weak cache key.
HardWeak - Static variable in class org.eclipse.persistence.config.CacheType
A HardWeak cache holds all objects in use by the application, and a fixed size sub-cache of MRU objects using normal (hard) references.
hasAccessor() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: returns true if the accessor has already been set.
hasActiveUnitOfWork() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return true if there is a unit of work associated with the active external transaction.
hasAddedElements() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Return if any elements that have been added before instantiation.
hasAddedElements() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Return if any elements that have been added before instantiation.
hasAdditionalCriteria() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Return true if an additional criteria has been set on this query manager.
hasAdditionalFieldExpressions() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return if there are additional field expressions.
hasAdditionalFields() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return if additional field.
hasAdditionalJoinExpressions() - Method in class org.eclipse.persistence.internal.expressions.OuterJoinExpressionHolder
 
hasAliasForTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
hasAllocatedConnection - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Indicates whether the call has allocated connection.
hasAllocatedConnection() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL:
hasAlreadyVisited(Expression) - Method in class org.eclipse.persistence.internal.expressions.ExpressionIterator
Answers if this expression has already been visited.
hasAny() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
hasAny() - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
hasAny() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
hasAnyEventListeners - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
PERF: Cache if any events listener exist.
hasAnyEventListeners() - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptorEventManager
 
hasAnyEventListeners() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: Return if the event manager has any event listeners, or event methods.
hasAnyListeners() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
hasArguments() - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
Return if argumented.
hasArguments() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return if any arguments exist in the query.
hasArray - Variable in class org.eclipse.persistence.internal.identitymaps.CacheId
Indicates whether at least one element of primaryKey is array.
hasArray() - Method in class org.eclipse.persistence.internal.identitymaps.CacheId
 
hasAsOfClause() - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Answers true if this is to be queried as of a past time.
hasAsOfClause() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
hasAsOfClause() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
hasAsOfClause() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Answers if the domain objects are to be read as of a past time.
hasAttribute - Variable in class org.eclipse.persistence.internal.oxm.XPathFragment
 
hasAttributes() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Return true is this query has batching
hasBatchFetchedAttributes() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return is any mappings are always batch fetched.
hasBatchReadAttributes() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return true is this query has batching
hasBeenAliased - Variable in class org.eclipse.persistence.internal.expressions.ObjectExpression
Allow hasBeenAliased to be marked independently from the existence of the tableAliases collection.
hasBeenAliased() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Answers if the database tables associated with this expression have been aliased.
hasBeenAliased() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
hasBeenAliased() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
hasBeenLogged - Variable in exception org.eclipse.persistence.exceptions.EclipseLinkException
 
hasBeenLogged() - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL: Return if this exception has been logged to avoid being logged more than once.
hasBeenNormalized - Variable in class org.eclipse.persistence.internal.expressions.DataExpression
 
hasBeenNormalized - Variable in class org.eclipse.persistence.internal.expressions.SubSelectExpression
 
hasBeenNormalized() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL: Did the normalizer already add additional joins to the where clause due to this query key representing a foreign reference mapping? This insures that join criteria (for any query key expression) is not added twice.
hasBeenRegistered() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: return whether this IndirectList has been registered with the UnitOfWork
hasBeenRegistered() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Return whether this IndirectSet has been registered in a UnitOfWork
hasBeenVisited() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
hasBroker() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Allow the session to be used from a session broker.
hasCacheIndexes() - Method in class org.eclipse.persistence.descriptors.CachePolicy
 
hasCacheIndexesInSopObject - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: is there an cache index field that's would not be selected by SOP query.
hasCacheIndexesInSopObject() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
hasCascadeDeleteObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if any objects have been deleted through database cascade delete constraints.
hasCascadeLockingPolicies() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL:
hasChangeFor(String) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
ADVANCED: This method will return true if the specified attribute has been changed.
hasChangeFor(String) - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCED: This method will return true if the specified attribute has been changed.
hasChanges - Variable in class org.eclipse.persistence.internal.descriptors.changetracking.ObjectChangeListener
 
hasChanges - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
This attribute is set to true if a changeSet with changes has been added
hasChanges() - Method in class org.eclipse.persistence.eis.EISCollectionChangeRecord
Return whether any changes have been recorded with the change record.
hasChanges() - Method in class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
Return whether any changes have been recorded with the change record.
hasChanges() - Method in class org.eclipse.persistence.internal.descriptors.changetracking.ObjectChangeListener
INTERNAL: This method should return true if the object has been changed and false otherwise.
hasChanges() - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
PUBLIC: Returns true if the change set has changes.
hasChanges() - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
Returns true if the change set has changes.
hasChanges() - Method in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
Returns true if the change set has changes.
hasChanges() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
ADVANCED: Returns true if this particular changeSet has changes.
hasChanges() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Returns true if the Unit Of Work change Set has changes
hasChanges() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: The Unit of work is capable of preprocessing to determine if any on the clone have been changed.
hasChanges() - Method in interface org.eclipse.persistence.sessions.changesets.CollectionChangeRecord
ADVANCED: This method returns true if the change set has changes
hasChanges() - Method in interface org.eclipse.persistence.sessions.changesets.EISCollectionChangeRecord
ADVANCED: Return whether any changes have been recorded with the change record.
hasChanges() - Method in interface org.eclipse.persistence.sessions.changesets.EISOrderedCollectionChangeRecord
ADVANCED: Return whether any changes have been recorded with the change record.
hasChanges() - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCED: Returns true if this particular changeSet has changes.
hasChanges() - Method in interface org.eclipse.persistence.sessions.changesets.UnitOfWorkChangeSet
ADVANCED: Returns true if the Unit Of Work change Set has changes
hasChanges() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: The Unit of work is capable of preprocessing to determine if any on the clone have been changed.
hasChangesFromCascadeLocking - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
hasChild() - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Return if there are any child descriptors.
hasChildren() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Check if descriptor has children
hasClassExtractor() - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL:
hasClassExtractor() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL:
hasClassIndicator() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Checks if the class is involved in inheritance
hasCloneMapping() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if the unit of work has any clones.
hasCloneToOriginals() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
hasCMPPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if the descriptor has a CMP policy.
hasCmpPolicyForcedUpdate - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
For CMP only: indicates that the object should be force updated (whether it has OptimisticLocking or not): getCmpPolicy().getForcedUpdate()==true
hasCmpPolicyForcedUpdate() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL:
hasCommitManager() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return if the commit manager has been set.
hasCompatibleType() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
hasConnectByExpression() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
hasConnectionAvailable() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: Wait until a connection is avaiable and allocate the connection for the client.
hasConnectionAvailable() - Method in class org.eclipse.persistence.sessions.server.ExternalConnectionPool
INTERNAL: Assume true as the driver is responsible for blocking.
hasConnectionAvailable() - Method in class org.eclipse.persistence.sessions.server.ReadConnectionPool
INTERNAL: Concurrent reads are supported.
hasConstraintDependency() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: The returns if the mapping has any constraint dependencies, such as foreign keys and join tables.
hasConstraintDependency() - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: The returns if the mapping has any constraint dependencies, such as foreign keys and join tables.
hasConstraintDependency() - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: The returns if the mapping has any constraint dependencies, such as foreign keys and join tables.
hasConstraintDependency() - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: The returns if the mapping has any constraint dependencies, such as foreign keys and join tables.
hasContainerBeans() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if any container beans exist.
hasContextTenant() - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL: Return true if the tenant has been set for this policy.
hasConverter() - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
 
hasConverter() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
 
hasConverter() - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
Indicates if the mapping has a converter set on it.
hasConverter() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
PUBLIC: Indicates if there is a converter on the mapping.
hasConverter() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
PUBLIC: Indicates if there is a converter on the mapping.
hasCorrespondingDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Checks if the descriptor exists or not.
hasCustomAddTargetQuery - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
 
hasCustomDeleteAllQuery - Variable in class org.eclipse.persistence.mappings.CollectionMapping
 
hasCustomDeleteAllQuery() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
 
hasCustomDeleteAllQuery() - Method in class org.eclipse.persistence.mappings.CollectionMapping
 
hasCustomDeleteAtIndexQuery - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
hasCustomDeleteAtIndexQuery() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
hasCustomDeleteQuery - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
hasCustomDeleteQuery - Variable in class org.eclipse.persistence.mappings.RelationTableMechanism
 
hasCustomDeleteQuery() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
hasCustomDeleteQuery() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
 
hasCustomDeleteQuery() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
 
hasCustomInsertQuery - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
hasCustomInsertQuery - Variable in class org.eclipse.persistence.mappings.RelationTableMechanism
 
hasCustomInsertQuery() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
hasCustomInsertQuery() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
 
hasCustomInsertQuery() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
 
hasCustomMultipleTableJoinExpression - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
hasCustomMultipleTableJoinExpression() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Return if a custom join expression is used.
hasCustomNamespaceMapper - Variable in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
hasCustomNamespaceMapper - Variable in class org.eclipse.persistence.oxm.record.XMLRecord
 
hasCustomNamespaceMapper() - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
hasCustomNamespaceMapper() - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
hasCustomNamespaceMapper() - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
hasCustomNamespaceMapper() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
hasCustomRemoveAllTargetsQuery - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
 
hasCustomRemoveTargetQuery - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
 
hasCustomSelectionQuery - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Indicates whether the selection query is TopLink generated or defined by the user.
hasCustomSelectionQuery() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Indicates whether the selection query is TopLink generated or defined by the user.
hasCustomSQLArguments - Variable in class org.eclipse.persistence.queries.SQLCall
 
hasCustomSQLArguments() - Method in class org.eclipse.persistence.queries.SQLCall
INTERNAL: Used to avoid misinterpreting the # in custom SQL.
hasCustomUpdateAtIndexQuery - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
hasCustomUpdateAtIndexQuery() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
hasDatabaseSchema() - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Return true is this database object definition has a schema definition.
hasDataModifications() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
 
hasDefaultBuilder() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Checks to see if a builder has been set on the query.
hasDefaultEventListeners() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: This method will return true, if this event manager has default listeners and does not exclude them.
hasDefaultNullValues() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL
hasDefaultReadOnlyClasses - Variable in class org.eclipse.persistence.sessions.remote.DistributedSession
Cache if default classes have been read from server.
hasDefaultSequence() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Get default sequence
hasDeferredAttributes() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Check to see if there are any attributes that must be calculated at commit time.
hasDeferredCalls() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
 
hasDeferredChanges() - Method in interface org.eclipse.persistence.indirection.IndirectCollection
INTERNAL: Return if the collection has any changes that have been deferred to instantiation.
hasDeferredChanges() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Return if any elements that have been added or removed before instantiation.
hasDeferredChanges() - Method in class org.eclipse.persistence.indirection.IndirectMap
INTERNAL: Return if any elements that have been added or removed before instantiation.
hasDeferredChanges() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Return if any elements that have been added or removed before instantiation.
hasDeferredLock() - Method in class org.eclipse.persistence.internal.helper.DeferredLockManager
Return if there are any deferred locks.
hasDeferredModifyAllQueries() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
hasDelegateSequence() - Method in class org.eclipse.persistence.sequencing.NativeSequence
Return if the sequence should be replaced by another sequence implementation.
hasDeletedObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Returns true if any deleted objects.
hasDeletedObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The deleted objects stores any objects removed during the unit of work.
hasDeleteQuery() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Flag that specifies if a delete query is available
hasDependency() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return if the mapping has any ownership or other dependency over its target object(s).
hasDependency() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return if the mapping has any ownership or other dependency over its target object(s).
hasDependency() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return if the mapping has any ownership or other dependency over its target object(s).
hasDependency() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: The join table is a dependency if not read-only.
hasDependencyOnParts() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Checks if the class has any private owned parts or other dependencies, (i.e.
hasDerivedExpressions() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
hasDerivedFields() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
hasDerivedId() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: returns true if users have designated one or more mappings as IDs.
hasDerivedTables() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
hasDescriptor(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Return true if a descriptor exists for the given class.
hasDescriptor(Class<?>) - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: Return true if a descriptor exists for the given class.
hasDocumentPreservation() - Method in class org.eclipse.persistence.internal.oxm.Context
INTERNAL: Return true if any session held onto by this context has a document preservation policy that requires unmarshalling from a Node.
hasDocumentPreservation() - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Return true if any session held onto by this context has a document preservation policy that requires unmarshalling from a Node.
hasDoesExistQuery() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Flag that specifies if a does exist query is available
hasElementDescriptor() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Used for wrapping and unwrapping with the wrapper policy.
hasEntityEventListener() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: EJB 3.0 support.
hasEntityListenerEventListeners() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: EJB 3.0 support.
hasEqualFieldInfos(List<ReturningPolicy.Info>) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL: Used for testing only
hasEqualFieldInfos(ReturningPolicy) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL: Used for testing only
hasEqualMains(ReturningPolicy) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL: Both ReturningPolicies should be initialized
hasEqualNamespaceResolvers() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Login
 
hasEqualNamespaceResolvers() - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
hasEqualNamespaceResolvers() - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
hasEqualNamespaceResolvers() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
hasEqualNamespaceResolvers() - Method in class org.eclipse.persistence.oxm.XMLLogin
 
hasErrors() - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
INTERNAL: Return if any errors occurred.
hasEventManager() - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
INTERNAL: returns true if a DescriptorEventManager has been set.
hasEventManager() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: returns true if a DescriptorEventManager has been set.
hasEventManager() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return if an event manager has been set.
hasException() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Return if any exception that was throw from concurrent population thread.
hasException() - Method in class org.eclipse.persistence.logging.SessionLogEntry
 
hasExceptionHandler() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if an exception handler is present.
hasExceptionHandler() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if an exception handler is present.
hasExecutionFetchGroup() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Indicates whether a FetchGroup will be applied to the query.
hasExecutionFetchGroup() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Indicates whether a FetchGroup will be applied to the query.
hasExternalTransactionController() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Used for JTA integration.
hasExternalTransactionController() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Used for JTS integration.
hasFetchGroup() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Return if a fetch group is set in the query.
hasFetchGroup(String) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
Return true if a fetch group exists for the given group name.
hasFetchGroupManager() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if the descriptor has a fetch group manager associated with.
hasForcedChanges - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
 
hasForcedChanges() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Returns true if this particular changeSet has forced SQL changes.
hasForcedChanges() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Returns true if this uowChangeSet contains an objectChangeSet that has forced SQL changes.
hasForcedChangesFromCascadeLocking() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Returns true if this particular changeSet has forced SQL changes because of a cascade optimistic locking policy.
hasForeignKeyConstraints() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
hasForeignKeyDefinition() - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
hasGenericHistorySupport - Variable in class org.eclipse.persistence.sessions.Project
Cache if any descriptor has history.
hasGenericHistorySupport() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Answers if at least one Descriptor or Mapping had a HistoryPolicy at initialize time.
hasGroupByExpressions() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
hasGroupByExpressions() - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Return if any group bys exist, allow lazy initialization.
hash - Variable in class org.eclipse.persistence.internal.identitymaps.CacheId
Cached hashcode.
Hash - Static variable in class org.eclipse.persistence.config.ParameterDelimiterType
 
hasHavingExpression() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
hashCode - Variable in class org.eclipse.persistence.expressions.Expression
PERF: Cache the hashCode.
hashCode() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
hashCode() - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
hashCode() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
hashCode() - Method in class org.eclipse.persistence.eis.EISSequence
 
hashCode() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Return a consistent hash-code for the expression.
hashCode() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Return the hash-code based on the unique selector.
hashCode() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL:
hashCode() - Method in class org.eclipse.persistence.indirection.IndirectMap
 
hashCode() - Method in class org.eclipse.persistence.indirection.IndirectSet
 
hashCode() - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
hashCode() - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
hashCode() - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeMethodInfo
 
hashCode() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Return the hashcode of the name, because it is fairly unique.
hashCode() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Return the hashcode of the name, because it is fairly unique.
hashCode() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
hashCode() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
hashCode() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
hashCode() - Method in class org.eclipse.persistence.internal.helper.type.ReadLockAcquisitionMetadata
 
hashCode() - Method in class org.eclipse.persistence.internal.identitymaps.CacheId
Return the precomputed hashcode.
hashCode() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Overrides hashCode() in Object to use the primaryKey's hashCode for storage in data structures.
hashCode() - Method in class org.eclipse.persistence.internal.oxm.Root
 
hashCode() - Method in class org.eclipse.persistence.internal.oxm.WeakObjectWrapper
 
hashCode() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
hashCode() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
hashCode() - Method in class org.eclipse.persistence.internal.oxm.XPathPredicate
 
hashCode() - Method in class org.eclipse.persistence.internal.oxm.XPathQName
 
hashCode() - Method in class org.eclipse.persistence.internal.queries.AttributeItem
 
hashCode() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
hashCode() - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
 
hashCode() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordEntry
 
hashCode() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
This method overrides the hashcode method.
hashCode() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Return the hashcode for id, because it is unqiue.
hashCode() - Method in class org.eclipse.persistence.oxm.XMLField
 
hashCode() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Compute a consistent hash-code for the expression.
hashCode() - Method in class org.eclipse.persistence.queries.ReportQueryResult
 
hashCode() - Method in class org.eclipse.persistence.queries.ReportQueryResult.RecordEntry
 
hashCode() - Method in class org.eclipse.persistence.sequencing.DefaultSequence
 
hashCode() - Method in class org.eclipse.persistence.sequencing.NativeSequence
 
hashCode() - Method in class org.eclipse.persistence.sequencing.QuerySequence
 
hashCode() - Method in class org.eclipse.persistence.sequencing.Sequence
 
hashCode() - Method in class org.eclipse.persistence.sequencing.TableSequence
 
hashCode() - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
hashCode() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
hasHierarchicalExpressions() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Verify that we have hierarchical query expressions
hasHierarchicalQueryExpressions() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
HashPartitioning - Annotation Type in org.eclipse.persistence.annotations
HashPartitioning partitions access to a database cluster by the hash of a field value from the object, such as the object's location, or tenant.
HashPartitioningPolicy - Class in org.eclipse.persistence.descriptors.partitioning
PUBLIC: HashPartitioningPolicy partitions access to a database cluster by the hash of a field value from the object, such as the object's location, or tenant.
HashPartitioningPolicy() - Constructor for class org.eclipse.persistence.descriptors.partitioning.HashPartitioningPolicy
 
HashPartitioningPolicy(String) - Constructor for class org.eclipse.persistence.descriptors.partitioning.HashPartitioningPolicy
 
HashPartitioningPolicy(String, boolean) - Constructor for class org.eclipse.persistence.descriptors.partitioning.HashPartitioningPolicy
 
HashSet_class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
Hashtable_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
hasInBatchFetchedAttribute - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Cache mapping that use batch fetching.
hasInBatchFetchedAttribute() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return is any mappings are always batch fetched using IN.
hasIndexes() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
hasInheritance() - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
INTERNAL: Return if this descriptor is involved in inheritance, (is child or parent).
hasInheritance() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Indicates whether this group is part of an inheritance hierarchy
hasInheritance() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if this descriptor is involved in inheritance, (is child or parent).
hasInheritance() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: Return if this descriptor is involved in inheritance, (is child or parent).
hasInsertQuery() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Flag that specifies if a insert query is available
hasInterfacePolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if this descriptor is involved in interface, (is child or parent).
hasInternalEventListeners() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: Internal event support.
hasInternalExceptions() - Method in exception org.eclipse.persistence.exceptions.JPQLException
INTERNAL Does this exception have any internal errors?
hasInverseConstraintDependency() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Return whether the mapping has any inverse constraint dependencies, such as foreign keys.
hasInverseConstraintDependency() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: The returns if the mapping has any inverse constraint dependencies, such as foreign keys and join tables.
hasInverseConstraintDependency() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Return whether the mapping has any inverse constraint dependencies, such as foreign keys and join tables.
hasIsolatedCacheClassWithoutUOWIsolation() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return whether this project has a descriptor that is both Isolated and has a cache isolation level other than ISOLATE_CACHE_ALWAYS
hasIsolatedClasses - Variable in class org.eclipse.persistence.sessions.Project
Cache if any descriptor is isolated.
hasIsolatedClasses() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return if any descriptors are isolated.
hasItems() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Indicates whether the group has at least one attribute.
hasJoinedAttributeExpressions() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return the attributes that must be joined.
hasJoinedAttributes() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Answers if any attributes are to be joined / returned in the same select statement.
hasJoinedAttributes() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return if any attributes are joined.
hasJoinedExpressions() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
This method checks both attribute expressions and mapping expressions and determines if there are any joins to be made.
hasJoinedMappingExpressions() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return the attributes that must be joined.
hasJoining() - Method in class org.eclipse.persistence.internal.queries.ReportItem
INTERNAL: Return if any attributes are joined.
hasJoining() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return if any attributes are joined.
hasKeys() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Returns true if this particular changeSet has a Key.
hasLastChild - Variable in class org.eclipse.persistence.internal.expressions.ArgumentListFunctionExpression
 
hasLastXPathFragment() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
INTERNAL:
hasLastXPathFragment() - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL:
hasLeafElementType() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
hasListeners() - Method in class org.eclipse.persistence.sessions.SessionEventManager
PUBLIC: Check if there are any event listeners.
hasLob(Collection<DatabaseField>) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
hasLogin() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Return if a login is used, only one of login and pool can be used.
hasMapKeyHolder() - Method in class org.eclipse.persistence.internal.expressions.OuterJoinExpressionHolder
 
hasMappedSuperclass(String) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return whether the given class is mapped as superclass.
hasMappedSuperclasses() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return whether there any mappings that are mapped superclasses.
hasMapping - Variable in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
hasMappingsPostCalculateChanges() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Are there any mappings that require postCalculateChanges method to be called.
hasMappingsPostCalculateChangesOnDeleted - Variable in class org.eclipse.persistence.sessions.Project
Indicates whether there is at least one descriptor that has at least on mapping that require a call on deleted objects to update change sets.
hasMappingsPostCalculateChangesOnDeleted() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Are there any mappings that require mappingsPostCalculateChangesOnDeleted method to be called.
hasMappingsPostCalculateChangesOnDeleted() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Indicates whether there is at least one descriptor that has at least on mapping that require a call on deleted objects to update change sets.
hasMapsIdValue() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: Set the mapped by id value
hasMessage() - Method in class org.eclipse.persistence.logging.SessionLogEntry
 
hasModifications() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Does this unit of work have any changes or anything that requires a write to the database and a transaction to be started.
hasModifyAllQueries() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
hasModifyRow - Variable in class org.eclipse.persistence.queries.DataModifyQuery
Used to distinguish query that have a different modify row than translation row.
hasModifyRow() - Method in class org.eclipse.persistence.queries.DataModifyQuery
Return if a modify row has been set.
hasMoreElements() - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMapEnumeration
Check whether this enumeration contains more elements.
hasMoreElements() - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Return whether the cursored stream has any more elements.
hasMoreElements() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Indicates whether the cursor can move to the the next row
hasMoreNodes() - Method in class org.eclipse.persistence.internal.sessions.factories.NodeListElementEnumerator
 
hasMultipleCalls() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Normally only a single call is used, however multiple table may require multiple calls on write.
hasMultipleResultSets - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Support multiple result sets.
hasMultipleResultSets() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Return if the call returns multiple result sets.
hasMultipleStatements() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Normally only a single statement is used, however multiple table may require multiple statements on write.
hasMultipleTableChild() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return if any children of this descriptor require information from another table not specified at the parent level.
hasMultipleTableConstraintDependecy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
Defines if any mapping reference a field in a secondary table.
hasMultipleTableConstraintDependecy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return if any mapping reference a field in a secondary table.
hasMultipleTables() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Check if descriptor has multiple tables
hasMultitenantPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return true if the descriptor has a multitenant policy
hasName() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Determine whether the receiver has any identification information.
hasNamespace() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
hasNestedIdentityReference - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Indicates whether the mapping (or at least one of its nested mappings, at any nested depth) references an entity.
hasNestedIdentityReference - Variable in class org.eclipse.persistence.mappings.AggregateMapping
Indicates whether the mapping (or at least one of its nested mappings, at any nested depth) references an entity.
hasNestedIdentityReference() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Indicates whether the mapping (or at least one of its nested mappings, at any nested depth) references an entity.
hasNestedIdentityReference() - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Indicates whether the mapping (or at least one of its nested mappings, at any nested depth) references an entity.
hasNestedIdentityReference() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Indicates whether the mapping (or at least one of its nested mappings, at any nested depth) references an entity.
hasNestedIdentityReference() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Indicates whether the mapping (or at least one of its nested mappings, at any nested depth) references an entity.
hasNestedIdentityReference() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Indicates whether the mapping (or at least one of its nested mappings, at any nested depth) references an entity.
hasNestedIdentityReference(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Calculates whether descriptor references an entity (directly or through a nested mapping).
hasNewObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if there are any registered new objects.
hasNewObjectsInParentOriginalToClone() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
hasNext() - Method in class org.eclipse.persistence.internal.mappings.converters.AttributeNameTokenizer.TokensIterator
INTERNAL: Returns true if the iteration has more elements.
hasNext() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy.MapContainerPolicyIterator
 
hasNext() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordEntryIterator
 
hasNext() - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Return whether the cursored stream has any more elements.
hasNext() - Method in class org.eclipse.persistence.queries.ReportQueryResult.EntryIterator
 
hasNext() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Indicates whether the cursor can move to the the next row
hasNext(Object) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Return whether the iterator has more objects.
hasNext(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return whether the iterator has more objects.
hasNext(Object) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Return whether the iterator has more objects,
hasNext(Object) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return whether the iterator has more objects.
hasNext(Object) - Method in class org.eclipse.persistence.queries.CursorPolicy
INTERNAL: Return whether the iterator has more objects.
hasNextElement() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Indicates whether the cursor can move to the the next row
hasNoncacheableMappings - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
caches if this descriptor has any non cacheable mappings
hasNoncacheableMappings() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
 
hasNonDefaultFetchGroup() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Return if the query has an non-default fetch group defined for itself.
hasNonFetchJoinedAttributeExpressions() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the attributes that must be joined.
hasNonIsolatedUOWClasses - Variable in class org.eclipse.persistence.sessions.Project
Cache if all descriptors are isolated in the unit of work.
hasNonIsolatedUOWClasses() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return if any descriptors are not isolated to the unit of work.
hasNonSelectFields() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
hasNotBeenVisited() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
hasNullableArguments() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return if the query has any nullable arguments.
hasNullValueInFields() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: Return true if the AbstractRecord has been marked as valid to check the update call cache with, false otherwise.
hasObjectsDeletedDuringCommit() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
hasObjectsToDelete() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
 
hasOptimisticLock - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
hasOptimisticLock() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
This check is needed only when doing batch writing.
hasOptimisticReadLockObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if there are any optimistic read locks.
hasOptionalArguments() - Method in class org.eclipse.persistence.queries.StoredProcedureCall
INTERNAL: Return if there are any optional arguments.
hasOrder() - Method in class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
INTERNAL: Return whether the collection has order.
hasOrder() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Returns true if the collection has order
hasOrder() - Method in class org.eclipse.persistence.internal.queries.ListContainerPolicy
INTERNAL: Returns true if the collection has order
hasOrderBy - Variable in class org.eclipse.persistence.mappings.CollectionMapping
 
hasOrderBy() - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Return true if ascending or descending ordering has been set on this mapping via the @OrderBy annotation.
hasOrderByExpressions() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
hasOrderByExpressions() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return if there are orderBy expressions.
hasOrderByExpressions() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: The order bys are lazy initialized to conserve space.
hasOrderSiblingsByExpressions() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
hasOuterJoinedAttribute - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
PERF: Used to avoid null checks for inner attribute joining.
hasOuterJoinedAttributeQuery() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
PERF: Return if the query uses any outer attribute joins, used to avoid null checks in building objects.
hasOuterJoinExpressions() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
hasOutputArguments() - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
Return if argumented.
hasOutputCursors() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Return true if there are output cursors on this call.
hasParameters() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The parameters are the values in order of occurrence in call.
hasParameters() - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
The parameters are the values in order of occurance in call.
hasPartialAttributeExpressions() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Return if partial attributes.
hasPartialAttributeExpressions() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return if partial attributes.
hasPartitioningCallback() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Check if has callback.
hasPassword() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL:
hasPessimisticLockedObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return true if there are any pessimistic locked objects in this unit of work, false otherwise.
hasPessimisticLockingPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL:
hasPessimisticLockingPolicy() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
PUBLIC: Return true if bean pessimistic locking is configured
hasPreallocationSize() - Method in class org.eclipse.persistence.sequencing.DefaultSequence
 
hasPreDeleteMappings() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
 
hasPredicateSiblings() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
hasPrefix(String) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
Indicates whether given prefix is assigned to a name-space.
hasPrefixesToNamespaces() - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
 
hasPrevious() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Indicates whether the cursor can move to the the previous row
hasPrivatelyOwnedParts() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Checks if the class has any private owned parts are not
hasPrivateOwnedObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return true if privateOwnedObjects is not null and not empty, false otherwise.
hasProperties() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Allow to check for user defined properties.
hasProperties() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return if any properties exist in the query.
hasProperties() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Returns true if properties are available on the Connection Policy
hasProtectedForeignKeys() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Returns true if the protectedForeignKeys record is non-null and non-empty, false otherwise.
hasProtectedForeignKeys() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
hasProxyIndirection - Variable in class org.eclipse.persistence.sessions.Project
Cache if any descriptor is using ProxyIndirection.
hasProxyIndirection() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return if any descriptors use ProxyIndirection.
hasQueryKey - Variable in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
hasQueryKeyOrMapping(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Checks to see if it has a query key or mapping with the specified name or not.
hasQueryMechanism() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Check if the mechanism has been set yet, used for lazy init.
hasReadAllQuery() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Flag that specifies if a read all query is available
hasReadObjectQuery() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Flag that specifies if a read object query is available
hasReference(Object) - Method in class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap
Checks if the object is null, or reference's object is null.
hasReference(Object) - Method in class org.eclipse.persistence.internal.identitymaps.SoftCacheWeakIdentityMap
Checks if the object is null, or reference's object is null.
hasReferenceMappings() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Returns true if any of the mappings on this descriptor are key-based reference mappings.
hasRelationships - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
whether this descriptor has any relationships through its mappings, through inheritance, or through aggregates
hasRelationships() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: return whether this descriptor has any relationships through its mappings, through inheritance, or through aggregates
hasRelationshipsExceptBackpointer(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: This method returns true if this descriptor has either a ForeignReferenceMapping to an object aside from the one described by descriptor or more than one ForeignReferenceMapping to descriptor.
hasRelationTable() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Indicates whether the mapping has RelationTable.
hasRelationTable() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Indicates whether the mechanism has relation table.
hasRelationTableMechanism() - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
PUBLIC: Indicates whether the mapping has RelationTableMechanism.
hasRelationTableMechanism() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Indicates whether the mapping has RelationTableMechanism.
hasRemovedElements() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Return if any elements that have been removed before instantiation.
hasRemovedElements() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Return if any elements that have been removed before instantiation.
hasRemovedObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
hasResult() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
Indicates if a Result has been set for this Schema.
hasResultSet() - Method in class org.eclipse.persistence.internal.sessions.ResultSetRecord
Indicates whether resultSet is still here.
hasResultSetMappings() - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: Return true if there are results set mappings associated with this query.
hasResultType() - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
hasReturningPolicies() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if this descriptor or descriptors from mappings has Returning policy.
hasReturningPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if this descriptor has Returning policy.
hasRootExpressionThatShouldUseOuterJoin(List) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: If there is root expression in the list then indicates whether it shouldUseOuterJoin, otherwise return false.
hasRuntimeExceptions() - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
INTERNAL: Return if any runtime errors occurred.
hasSecurableObject() - Method in class org.eclipse.persistence.internal.security.SecurableObjectHolder
 
hasSerializedObjectPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL:
hasSessionName() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return if a name of the session that the query should be executed under has been specified.
hasSimplePrimaryKey - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
PERF: Compute and store if the primary key is simple (direct-mapped) to allow fast extraction.
hasSimplePrimaryKey() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: PERF: Return if the primary key is simple (direct-mapped) to allow fast extraction.
hasSizeQuery() - Method in class org.eclipse.persistence.queries.CursoredStreamPolicy
INTERNAL: Return if a custom size query is defined.
hasSopObject() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL:
hasSQLResultSetMapping(String) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return true if the sql result set mapping name exists.
hasStartWithExpression() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
hasStatementCache() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return if the accessor has any cached statements.
hasSystemId() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
Indicates if this Schema has a Result, and that Result has a non-null systemID.
hasTableName() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
hasTablePerClassPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if this descriptor is involved in a table per class inheritance.
hasTablePerMultitenantPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC
hasTablePerTenantDescriptors() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return list of table per tenant multitenant descriptors.
hasTablePerTenantQueries() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return a list of table per tenant multitenant queries.
hasTargetForeignKeyMapping(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Indicates whether descriptor has at least one target foreign key mapping
hasTargetInterfaces() - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Return if targetInterfaces is not empty.
hasTenantDiscriminatorFields() - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL: Return if this descriptor has specified some tenant discriminator fields.
hasTrackedPropertyChangeListener() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Return if the collection has a property change listener for change tracking.
hasTrackedPropertyChangeListener() - Method in class org.eclipse.persistence.indirection.IndirectMap
INTERNAL: Return if the collection has a property change listener for change tracking.
hasTrackedPropertyChangeListener() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Return if the collection has a property change listener for change tracking.
hasTypeChild() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
hasUnconvertedProperties() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Used to store un-converted properties, which are subsequenctly converted at runtime (through the convertClassNamesToClasses method.
hasUnconvertedProperties() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Used to store un-converted properties, which are subsequenctly converted at runtime (through the convertClassNamesToClasses method.
hasUnionExpressions() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
hasUnionExpressions() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: The unions are lazy initialized to conserve space.
hasUniqueConstraints() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
hasUnregisteredNewObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if there are any unregistered new objects.
hasUpdateQuery() - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Flag that specifies if a update query is available
hasUsedMethodAccess - Variable in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
indicates whether the mapping has originally used method access
hasUsedMethodAccess() - Method in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
 
hasUserDefinedForeignKeyConstraints - Variable in class org.eclipse.persistence.tools.schemaframework.TableDefinition
 
hasValueConverter() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
PUBLIC: Indicates if there is a converter on the mapping.
hasValues() - Method in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
 
hasVersionChange - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
hasVersionChange() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
hasView() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return if a view is used for inheritance reads.
hasViewTable() - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL:
hasVPDIdentifier(AbstractSession) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Return true if there is a VPD identifier for this project.
hasWrapperPolicy - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Cache if has a wrapper policy.
hasWrapperPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if a wrapper policy is used.
hasWrapperPolicy() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return if the descriptor has a wrapper policy.
hasWriteConnection() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Return if this session has been connected.
haveBeenAddedToStatement - Variable in class org.eclipse.persistence.internal.expressions.TableAliasLookup
 
haveBeenAddedToStatement() - Method in class org.eclipse.persistence.internal.expressions.TableAliasLookup
INTERNAL: Answers if the aliases have already been added to a statement.
havingExpression - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Having clause for report queries.
havingExpression - Variable in class org.eclipse.persistence.queries.ReportQuery
Expression representing the HAVING clause.
HEAVY - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
Helper - Class in org.eclipse.persistence.internal.helper
INTERNAL:
Helper() - Constructor for class org.eclipse.persistence.internal.helper.Helper
 
Hermes - Static variable in class org.eclipse.persistence.config.ParserType
 
HermesParser - Class in org.eclipse.persistence.internal.jpa.jpql
This class compiles a JPQL query into a DatabaseQuery.
HermesParser() - Constructor for class org.eclipse.persistence.internal.jpa.jpql.HermesParser
Creates a new HermesParser.
HEX_BINARY - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
HEX_BINARY_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
hexToRaw() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns binary array value for the hex string.
hexToRaw() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
HexToRaw - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
HierarchyNode - Class in org.eclipse.persistence.internal.codegen
INTERNAL:
HierarchyNode(String) - Constructor for class org.eclipse.persistence.internal.codegen.HierarchyNode
 
HINT - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.sql.hint"
HINT_END - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
HINT_START - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
hints() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredFunctionQuery
(Optional) Query hints.
hints() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredProcedureQuery
(Optional) Query hints.
hints() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredFunctionQuery
(Optional) Query hints.
hints() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredProcedureQuery
(Optional) Query hints.
hintString - Variable in class org.eclipse.persistence.internal.expressions.SQLStatement
 
hintString - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Used for adding hints to the query string in oracle
HintValues - Class in org.eclipse.persistence.config
Hint values.
HintValues() - Constructor for class org.eclipse.persistence.config.HintValues
 
HISTORICAL_QUERIES_MUST_PRESERVE_GLOBAL_CACHE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
HISTORICAL_QUERIES_ONLY_SUPPORTED_ON_ORACLE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
HISTORICAL_SESSION_ONLY_SUPPORTED_ON_ORACLE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
historicalQueriesMustPreserveGlobalCache() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
historicalQueriesOnlySupportedOnOracle() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
historicalSessionOnlySupportedOnOracle() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
historicalTables - Variable in class org.eclipse.persistence.history.HistoryPolicy
 
historyPolicy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
historyPolicy - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
historyPolicy - Variable in class org.eclipse.persistence.mappings.ManyToManyMapping
 
HistoryPolicy - Class in org.eclipse.persistence.history
Purpose:Expresses how historical data is saved on the data store.
HistoryPolicy() - Constructor for class org.eclipse.persistence.history.HistoryPolicy
 
HOST_TOKEN - Static variable in class org.eclipse.persistence.sessions.coordination.ServiceId
This $HOST token indicate that the host ip of the URL should be replaced at runtime by user input
hour() - Method in annotation type org.eclipse.persistence.annotations.TimeOfDay
(Optional) Hour of the day.
howManySequencingCallbacks() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Returns a number of member sessions that require sequencing callback.
HSQL - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
HSQLPlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides HSQL specific behavior.
HSQLPlatform() - Constructor for class org.eclipse.persistence.platform.database.HSQLPlatform
 

I

ICONST - Static variable in class org.eclipse.persistence.dynamic.DynamicClassWriter
 
id - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
id - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteCursoredStream
This is a unique id for remote cursored stream
id - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
This is a unique id for remote cursored stream
id - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
 
Id - Static variable in class org.eclipse.persistence.config.CommitOrderType
Updates and deletes are ordered by the object's id.
ID - org.eclipse.persistence.sessions.UnitOfWork.CommitOrderType
Updates and deletes are ordered by the object's id.
ID - Static variable in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
 
ID_ALREADY_SET - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
ID_VALIDATION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.id-validation" property defines which primary key components values are considered invalid.
ID_VALUE - org.eclipse.persistence.annotations.CacheKeyType
This can only be used for simple singleton Ids, such as long/int/String.
idAlreadySet(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception should be used when an attempt is made to set an ID property when one has already been set.
IDENTITY_MAP_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
IdentityHashSet - Class in org.eclipse.persistence.internal.helper
 
IdentityHashSet() - Constructor for class org.eclipse.persistence.internal.helper.IdentityHashSet
Constructs a new IdentityHashSet with a default initial capacity of 32 and a loadfactor of 0.75.
IdentityHashSet(int) - Constructor for class org.eclipse.persistence.internal.helper.IdentityHashSet
Constructs a new IdentityHashSet with the given initial capacity and a default loadFactor of 0.75.
IdentityHashSet(int, float) - Constructor for class org.eclipse.persistence.internal.helper.IdentityHashSet
Constructs a new IdentityHashSet with the given initial capacity and the given loadFactor.
IdentityHashSet(Collection) - Constructor for class org.eclipse.persistence.internal.helper.IdentityHashSet
Constructs a new IdentityHashSet with the same contents as the given Collection.
IdentityMap - Interface in org.eclipse.persistence.internal.identitymaps
Purpose: Provides the interface for IdentityMap interaction.
identityMapAccessor - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Manages the live object cache.
IdentityMapAccessor - Class in org.eclipse.persistence.internal.sessions
INTERNAL: Internal subclass that provides access to identity maps through the session.
IdentityMapAccessor - Interface in org.eclipse.persistence.sessions
PUBLIC: IdentityMapAccessor provides the public interface into all functionality associated with EclipseLink's cache.
IdentityMapAccessor() - Constructor for class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL:
IdentityMapAccessor(AbstractSession) - Constructor for class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: An IdentityMapAccessor sits between the session and the identityMapManager It needs references in both directions.
IdentityMapAccessor(AbstractSession, IdentityMapManager) - Constructor for class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: An IdentityMapAccessor sits between the session and the identityMapManager It needs references in both directions.
identityMapClass - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
IdentityMapEnumeration - Class in org.eclipse.persistence.internal.identitymaps
Allows to iterate over Object instances stored in CacheKey instances in the IdentityMap.
IdentityMapEnumeration(Collection<CacheKey>) - Constructor for class org.eclipse.persistence.internal.identitymaps.IdentityMapEnumeration
Creates an instance of CacheKey instances enumeration.
IdentityMapKeyEnumeration - Class in org.eclipse.persistence.internal.identitymaps
Allows to iterate over CacheKey instances stored in the IdentityMap.
IdentityMapKeyEnumeration(Collection<CacheKey>) - Constructor for class org.eclipse.persistence.internal.identitymaps.IdentityMapKeyEnumeration
Creates an instance of CacheKey instances enumeration.
IdentityMapKeyEnumeration(Collection<CacheKey>, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.IdentityMapKeyEnumeration
Creates an instance of CacheKey instances enumeration.
identityMapManager - Variable in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
This is the identity map manager for this accessor.
IdentityMapManager - Class in org.eclipse.persistence.internal.identitymaps
Purpose: Maintain identity maps for domain classes mapped with EclipseLink.
IdentityMapManager() - Constructor for class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
 
IdentityMapManager(AbstractSession) - Constructor for class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
 
identityMapNotSpecified(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
identityMaps - Variable in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
A table of identity maps with the key being the domain Class.
identityMapSize - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
IdentityWeakHashMap<K,​V> - Class in org.eclipse.persistence.internal.helper
 
IdentityWeakHashMap() - Constructor for class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Constructs a new IdentityWeakHashMap with a default initial capacity of 32 and a loadfactor of 0.75.
IdentityWeakHashMap(int) - Constructor for class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Constructs a new IdentityWeakHashMap with the given initial capacity and a default loadFactor of 0.75.
IdentityWeakHashMap(int, float) - Constructor for class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Constructs a new IdentityWeakHashMap with the given initial capacity and the given loadFactor.
IdentityWeakHashMap(Map) - Constructor for class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Constructs a new IdentityWeakHashMap with the same mappings as the given map.
IDREF - Static variable in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
 
idRelationshipCircularReference(HashSet) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
IDResolver - Class in org.eclipse.persistence.internal.oxm
IDResolver can be subclassed to allow customization of the ID/IDREF processing of Unmarshaller.
IDResolver - Class in org.eclipse.persistence.oxm
IDResolver can be subclassed to allow customization of the ID/IDREF processing of XMLUnmarshaller.
IDResolver() - Constructor for class org.eclipse.persistence.internal.oxm.IDResolver
Default constructor.
IDResolver() - Constructor for class org.eclipse.persistence.oxm.IDResolver
Default constructor.
idValidation - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
Allow zero primary key validation to be configured.
IdValidation - Enum in org.eclipse.persistence.annotations
IdValidation configures which id values are considered valid when loading from the database.
ifNull() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
ifNull(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function return a specific value if item returned from the query is null.
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.record.UnmappedContentHandlerWrapper
 
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.internal.oxm.unmapped.DefaultUnmappedContentHandler
 
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
ignorableWhitespace(char[], int, int) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
IGNORE - Static variable in class org.eclipse.persistence.internal.sessions.CommitManager
This object should be ignored.
ignoreAttributesForNil - Variable in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
This state flag determines how we unmarshal xsi:nil nodes when there are other attributes (other than xsi:nil) present.
ignoreAttributesForNil() - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
 
ignoreBindAllParameters() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Session's shouldBindAllParameters() defines whether to bind or not (default setting)
ignoreCacheStatement() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Session's shouldCacheAllStatements() defines whether to cache or not (default setting)
ignoreDatabaseException - Variable in class org.eclipse.persistence.tools.schemaframework.TableCreator
 
ignoreDepth - Variable in class org.eclipse.persistence.internal.descriptors.changetracking.ObjectChangeListener
 
ignoreEvents - Variable in class org.eclipse.persistence.internal.descriptors.changetracking.ObjectChangeListener
 
ignoreEvents() - Method in class org.eclipse.persistence.internal.descriptors.changetracking.ObjectChangeListener
INTERNAL: This method will set this listener to ignore events not issues by EclipseLink
ignoreFirstRowSetting - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Indicates if the FirstRow value in this call object is to be ignored.
ignoreIndirectionExceptionReturnConformed() - Method in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
ignoreIndirectionExceptionReturnNotConformed() - Method in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
ignoreMaxResultsSetting - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Indicates if the MaxResults value in this call object is to be ignored.
IgnoreNewElementsOrderingPolicy - Class in org.eclipse.persistence.oxm.documentpreservation
INTERNAL:
IgnoreNewElementsOrderingPolicy() - Constructor for class org.eclipse.persistence.oxm.documentpreservation.IgnoreNewElementsOrderingPolicy
 
IgnoreNewElementsOrderingPolicyConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.login
 
IgnoreNewElementsOrderingPolicyConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.login.IgnoreNewElementsOrderingPolicyConfig
 
ILL_FORMED_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
ILLEGAL_ACCESS_WHILE_CLONING - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_CONSTRUCTOR_INSTANTIATION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_CONSTRUCTOR_INSTANTIATION_OF_FACTORY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_EVENT_EXECUTION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_GETTING_VALUE_THRU_INSTANCE_VARIABLE_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_GETTING_VALUE_THRU_METHOD_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_INSTANTIATING_METHOD_BASED_PROXY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_INVOKING_ATTRIBUTE_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_INVOKING_FIELD_TO_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_INVOKING_ROW_EXTRACTION_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_METHOD_INSTANTIATION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_METHOD_INSTANTIATION_OF_FACTORY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_OBSOLETE_EVENT_EXECUTION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_SETTING_VALUE_THRU_INSTANCE_VARIABLE_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ACCESS_WHILE_SETTING_VALUE_THRU_METHOD_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ARGUMENT_WHILE_GETTING_VALUE_THRU_INSTANCE_VARIABLE_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ARGUMENT_WHILE_GETTING_VALUE_THRU_METHOD_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ARGUMENT_WHILE_INSTANTIATING_METHOD_BASED_PROXY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ARGUMENT_WHILE_INVOKING_ATTRIBUTE_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ARGUMENT_WHILE_INVOKING_FIELD_TO_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ARGUMENT_WHILE_OBSOLETE_EVENT_EXECUTION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ARGUMENT_WHILE_SETTING_VALUE_THRU_INSTANCE_VARIABLE_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_ARGUMENT_WHILE_SETTING_VALUE_THRU_METHOD_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_CONTAINER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ILLEGAL_DYNAMIC_CLASSWRITER - Static variable in exception org.eclipse.persistence.exceptions.DynamicException
 
ILLEGAL_PARENT_CLASSNAME - Static variable in exception org.eclipse.persistence.exceptions.DynamicException
 
ILLEGAL_STATE_XML_UNMARSHALLER_HANDLER - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
ILLEGAL_TABLE_NAME_IN_MULTIPLE_TABLE_FOREIGN_KEY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ILLEGAL_USE_OF_GETFIELD - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
ILLEGAL_USE_OF_GETTABLE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
ILLEGAL_USE_OF_MAP_IN_DIRECTCOLLECTION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ILLEGAL_VALIDATION_MODE - Static variable in exception org.eclipse.persistence.exceptions.BeanValidationException
 
illegalAccesstWhileGettingValueThruInstanceVaraibleAccessor(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileCloning(Object, String, ClassDescriptor, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileConstructorInstantiation(ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileConstructorInstantiationOfFactory(ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileEventExecution(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileGettingValueThruMethodAccessor(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileInstantiatingMethodBasedProxy(Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileInvokingAttributeMethod(DatabaseMapping, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileInvokingFieldToMethod(String, DatabaseMapping, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileInvokingRowExtractionMethod(AbstractRecord, Method, ClassDescriptor, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileMethodInstantiation(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileMethodInstantiationOfFactory(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileObsoleteEventExecute(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileSettingValueThruInstanceVariableAccessor(String, String, Object, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalAccessWhileSettingValueThruMethodAccessor(String, Object, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalArgumentWhileGettingValueThruInstanceVariableAccessor(String, String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalArgumentWhileGettingValueThruMethodAccessor(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalArgumentWhileInstantiatingMethodBasedProxy(Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalArgumentWhileInvokingAttributeMethod(DatabaseMapping, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalArgumentWhileInvokingFieldToMethod(String, DatabaseMapping, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalArgumentWhileObsoleteEventExecute(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalArgumentWhileSettingValueThruInstanceVariableAccessor(String, String, Object, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalArgumentWhileSettingValueThruMethodAccessor(String, Object, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalContainerClass(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
illegalDynamicClassWriter(DynamicClassLoader, String) - Static method in exception org.eclipse.persistence.exceptions.DynamicException
A DynamicClassWriter was attempted to be instantiated with a null loader or invalid parentClassName.
illegalLoggingLevel(String) - Static method in exception org.eclipse.persistence.exceptions.StaticWeaveException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
illegalOperationForUnitOfWorkLifecycle(int, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
illegalParentClassName(String) - Static method in exception org.eclipse.persistence.exceptions.DynamicException
A null or empty string was provided as the parent class for a dynamic class being registered for creation.
illegalStateXMLUnmarshallerHandler() - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
illegalTableNameInMultipleTableForeignKeyField(ClassDescriptor, DatabaseTable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
illegalUseOfGetField(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
illegalUseOfGetTable(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
illegalUseOfMapInDirectCollection(DirectCollectionMapping, Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
illegalValidationMode(String, String) - Static method in exception org.eclipse.persistence.exceptions.BeanValidationException
 
illFormedExpression(Expression) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
IMAGE - Variable in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
implementorDescriptor - Variable in class org.eclipse.persistence.descriptors.InterfacePolicy
 
implementorDescriptorClassName - Variable in class org.eclipse.persistence.descriptors.InterfacePolicy
 
Import - Class in org.eclipse.persistence.internal.oxm.schema.model
 
Import() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Import
 
importExists(Schema, String) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Determines if a given schema contains an import for a given schema name.
imports - Variable in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
in() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the IN operator.
in(boolean[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
in(byte[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
in(char[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
in(double[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
in(float[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
in(int[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
in(long[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
in(short[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
in(Object[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
in(Collection) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
in(Expression) - Method in class org.eclipse.persistence.expressions.Expression
 
in(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
 
In - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
IN - org.eclipse.persistence.annotations.BatchFetchType
This uses an SQL IN clause in the batch query passing in the source object Ids.
IN - org.eclipse.persistence.annotations.Direction
Input parameter
IN - org.eclipse.persistence.internal.databaseaccess.DatasourceCall.ParameterType
 
IN - Static variable in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
 
IN_CACHE - Static variable in class org.eclipse.persistence.descriptors.VersionLockingPolicy
 
IN_CANNOT_BE_PARAMETERIZED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
IN_OBJECT - Static variable in class org.eclipse.persistence.descriptors.VersionLockingPolicy
 
IN_OUT - org.eclipse.persistence.annotations.Direction
Input and output parameter
INACTIVE_UNIT_OF_WORK - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
inactiveUnitOfWork(UnitOfWorkImpl) - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
inActiveUnitOfWork(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
inCannotBeParameterized(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
Include - Class in org.eclipse.persistence.internal.oxm.schema.model
 
Include() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Include
 
INCLUDE_DESCRIPTOR_QUERIES - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.session.include.descriptor.queries" property configures whether to enable the copying of all descriptor named queries to the session to be usable from the entity manager.
includeAllValues() - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: Considers all mapped attributes in the example object as meaningful in a Query By Example.
includeCriteria() - Method in annotation type org.eclipse.persistence.annotations.Multitenant
(Optional) Indicate if the database requires the tenant criteria to be added to the SELECT, UPDATE, and DELETE queries.
includeTenantCriteria - Variable in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
 
INCOMPATIBLE_DYNAMIC_CLASSWRITERS - Static variable in exception org.eclipse.persistence.exceptions.DynamicException
 
incompatibleDuplicateWriters(String, EclipseLinkClassWriter, EclipseLinkClassWriter) - Static method in exception org.eclipse.persistence.exceptions.DynamicException
INCOMPLETE_JOIN_COLUMNS_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INCOMPLETE_PRIMARY_KEY_JOIN_COLUMNS_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
incompleteJoinColumnsSpecified(Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
incompletePrimaryKeyJoinColumnsSpecified(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
INCORRECT_CLASS_FOR_OBJECT_COMPARISON - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INCORRECT_COLLECTION_POLICY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INCORRECT_DATE_FORMAT - Static variable in exception org.eclipse.persistence.exceptions.ConversionException
 
INCORRECT_DATE_TIME_FORMAT - Static variable in exception org.eclipse.persistence.exceptions.ConversionException
 
INCORRECT_G_DAY_FORMAT - Static variable in exception org.eclipse.persistence.exceptions.XMLConversionException
 
INCORRECT_G_MONTH_DAY_FORMAT - Static variable in exception org.eclipse.persistence.exceptions.XMLConversionException
 
INCORRECT_G_MONTH_FORMAT - Static variable in exception org.eclipse.persistence.exceptions.XMLConversionException
 
INCORRECT_G_YEAR_FORMAT - Static variable in exception org.eclipse.persistence.exceptions.XMLConversionException
 
INCORRECT_G_YEAR_MONTH_FORMAT - Static variable in exception org.eclipse.persistence.exceptions.XMLConversionException
 
INCORRECT_LOGIN_INSTANCE_PROVIDED - Static variable in exception org.eclipse.persistence.eis.EISException
 
INCORRECT_LOGIN_INSTANCE_PROVIDED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INCORRECT_NUMBER_OF_XMLJOINNODES_ON_XMLELEMENTS - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INCORRECT_QUERY_FOUND - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INCORRECT_SIZE_QUERY_FOR_CURSOR_STREAM - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INCORRECT_TIME_FORMAT - Static variable in exception org.eclipse.persistence.exceptions.ConversionException
 
INCORRECT_TIMESTAMP_DATE_TIME_FORMAT - Static variable in exception org.eclipse.persistence.exceptions.XMLConversionException
 
INCORRECT_TIMESTAMP_FORMAT - Static variable in exception org.eclipse.persistence.exceptions.ConversionException
 
INCORRECT_TIMESTAMP_TIME_FORMAT - Static variable in exception org.eclipse.persistence.exceptions.XMLConversionException
 
incorrectClassForObjectComparison(Expression, Object, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
incorrectCollectionPolicy(DatabaseMapping, Class<?>, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
incorrectDateFormat(String) - Static method in exception org.eclipse.persistence.exceptions.ConversionException
 
incorrectDateTimeFormat(String) - Static method in exception org.eclipse.persistence.exceptions.ConversionException
 
incorrectDateTimeFormat(String, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.ConversionException
 
incorrectGDayFormat(String) - Static method in exception org.eclipse.persistence.exceptions.XMLConversionException
 
incorrectGMonthDayFormat(String) - Static method in exception org.eclipse.persistence.exceptions.XMLConversionException
 
incorrectGMonthFormat(String) - Static method in exception org.eclipse.persistence.exceptions.XMLConversionException
 
incorrectGYearFormat(String) - Static method in exception org.eclipse.persistence.exceptions.XMLConversionException
 
incorrectGYearMonthFormat(String) - Static method in exception org.eclipse.persistence.exceptions.XMLConversionException
 
incorrectKeyParameterType() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception would typically be used by JAXBContextFactory during externalized metadata processing (i.e.
incorrectLoginInstanceProvided() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
incorrectLoginInstanceProvided(Class<?>) - Static method in exception org.eclipse.persistence.eis.EISException
 
incorrectNumberOfXmlJoinNodesOnXmlElements(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: There is a different number of XmlElements and XmlJoinNodes entries in a given XmlElementsJoinNodes.
incorrectQueryObjectFound(DatabaseQuery, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
incorrectSizeQueryForCursorStream(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
incorrectTimeFormat(String) - Static method in exception org.eclipse.persistence.exceptions.ConversionException
 
incorrectTimestampDateTimeFormat(String) - Static method in exception org.eclipse.persistence.exceptions.XMLConversionException
 
incorrectTimestampFormat(String) - Static method in exception org.eclipse.persistence.exceptions.ConversionException
 
incorrectTimestampTimeFormat(String) - Static method in exception org.eclipse.persistence.exceptions.XMLConversionException
 
incorrectValueParameterType() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception would typically be used by JAXBContextFactory during externalized metadata processing (i.e.
incorrectValueParameterTypeForOxmXmlKey() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception would typically be used by JAXBContextFactory during externalized metadata processing (i.e.
incrementCallCount(AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Increment the number of calls in progress.
incrementCallCount(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Used for load balancing and external pooling.
incrementDatabaseCount(Object) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
Increment the count for object
incrementDelete(DeleteObjectQuery) - Static method in class org.eclipse.persistence.tools.profiler.QueryMonitor
 
incrementDepth() - Method in class org.eclipse.persistence.internal.helper.DeferredLockManager
increment the depth of the thread
incrementExpiry() - Method in class org.eclipse.persistence.descriptors.invalidation.DailyCacheInvalidationPolicy
INTERNAL: Update the expiry time to be the day after the current day.
incrementInsert(WriteObjectQuery) - Static method in class org.eclipse.persistence.tools.profiler.QueryMonitor
 
incrementProfile(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Updates the count of SessionProfiler event
incrementProfile(String) - Method in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
Log the profile event.
incrementProfile(String, DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Updates the count of SessionProfiler event
incrementReadAllHits(ReadAllQuery) - Static method in class org.eclipse.persistence.tools.profiler.QueryMonitor
 
incrementReadAllMisses(ReadAllQuery) - Static method in class org.eclipse.persistence.tools.profiler.QueryMonitor
 
incrementReadObjectHits(ReadObjectQuery) - Static method in class org.eclipse.persistence.tools.profiler.QueryMonitor
 
incrementReadObjectMisses(ReadObjectQuery) - Static method in class org.eclipse.persistence.tools.profiler.QueryMonitor
 
incrementUpdate(WriteObjectQuery) - Static method in class org.eclipse.persistence.tools.profiler.QueryMonitor
 
incrementWriteLockValue(Number) - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: Timestamp versioning should not be able to do this.
incrementWriteLockValue(Number) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Adds 1 to the value passed in.
INDENT - Static variable in class org.eclipse.persistence.internal.helper.Helper
 
indentationString - Variable in exception org.eclipse.persistence.exceptions.EclipseLinkException
 
index - Variable in class org.eclipse.persistence.descriptors.changetracking.CollectionChangeEvent
INTERNAL: index is the location of the change in the collection
index - Variable in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
index - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
Store normal index of field in result set to optimize performance.
index - Variable in class org.eclipse.persistence.internal.sessions.factories.NodeListElementEnumerator
 
index() - Method in class org.eclipse.persistence.expressions.Expression
 
index() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
Index - Annotation Type in org.eclipse.persistence.annotations
Allow a database INDEX to be define when generating DDL.
INDEX_REQUIRES_COLLECTION_MAPPING_WITH_LIST_ORDER_FIELD - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INDEX_REQUIRES_QUERY_KEY_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
IndexDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Allow for indexes to be created.
IndexDefinition() - Constructor for class org.eclipse.persistence.tools.schemaframework.IndexDefinition
 
INDEXED - Static variable in class org.eclipse.persistence.eis.EISDescriptor
 
IndexedAttributeList() - Constructor for class org.eclipse.persistence.internal.oxm.record.DOMReader.IndexedAttributeList
 
IndexedAttributeList() - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
IndexedInteraction - Class in org.eclipse.persistence.eis.interactions
Defines the specification for a call to a JCA interaction that uses indexed records.
IndexedInteraction() - Constructor for class org.eclipse.persistence.eis.interactions.IndexedInteraction
Default constructor.
IndexedObject - Class in org.eclipse.persistence.internal.helper
Purpose: A helper class for sorting index/object pairs.
IndexedObject(Integer, Object) - Constructor for class org.eclipse.persistence.internal.helper.IndexedObject
 
indexes - Variable in class org.eclipse.persistence.internal.helper.DatabaseTable
Store the set of indexes defined through meta-data for the table.
indexes - Variable in class org.eclipse.persistence.tools.schemaframework.TableDefinition
 
Indexes - Annotation Type in org.eclipse.persistence.annotations
Allow a set of database indexes to be define on an Entity.
IndexExpression - Class in org.eclipse.persistence.internal.expressions
Index expression may be created by QueryKeyExpression.index() method in case the QueryKeyExpression corresponds to a CollectionMapping with non-null listOrderField.
indexObjectInCache(CacheKey, Object, ClassDescriptor, AbstractSession, boolean) - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Index the object by index in the cache using the object.
indexObjectInCache(CacheKey, AbstractRecord, Object, ClassDescriptor, AbstractSession, boolean) - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Index the object by index in the cache using its row.
indexObjectInCache(ObjectChangeSet, Object, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Index the object by index in the cache using its changeSet.
indexOf(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the integer index of the substring within the source string.
indexOf(Object) - Method in class org.eclipse.persistence.indirection.IndirectList
 
indexOf(Object) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
Returns the index in this list of the first occurrence of the specified contents, or -1 if the List does not contain this contents.
indexOf(Object) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
If does not contain the object wait until complete.
indexOf(Object, int) - Method in class org.eclipse.persistence.indirection.IndirectList
 
indexOf(Object, int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
indexOf(Object, int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
indexOf(Object, int) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
If does not contain the object wait until complete.
indexOf(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ListContainerPolicy
INTERNAL: Returns the index in this list of the first occurrence of the specified element, or -1 if this list does not contain this element The session may be required to unwrap for the wrapper policy.
indexOfNullElement(Vector<?>, int) - Static method in class org.eclipse.persistence.internal.helper.Helper
Returns the index of the the first null element found in the specified Vector starting the search at the starting index specified.
indexOnlyAllowedOnVariable - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
indexOnlyAllowedOnVariable(String, int, int, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
indexRequiresCollectionMappingWithListOrderField(Expression, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
indexRequiresQueryKeyExpression(Expression) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
INDIRECT_CONTAINER_INSTANTIATION_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
IndirectCollection<E,​C> - Interface in org.eclipse.persistence.indirection
Purpose:
IndirectCollectionsFactory - Class in org.eclipse.persistence.indirection
Provides factory methods to create JDK specific implementation of particular type of IndirectCollection.
IndirectCollectionsFactory.IndirectCollectionsProvider - Interface in org.eclipse.persistence.indirection
Define API providers of IndirectCollection implementations must conform to.
IndirectContainer<C> - Interface in org.eclipse.persistence.indirection
Purpose:
IndirectContainer_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
indirectContainerInstantiationMismatch(Object, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
INDIRECTION_POLICY - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.cache-usage.indirection-policy"
indirectionPolicy - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Implements indirection behavior
indirectionPolicy - Variable in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
Implements indirection behaviour
IndirectionPolicy - Class in org.eclipse.persistence.internal.indirection
Purpose
IndirectionPolicy() - Constructor for class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Construct a new indirection policy.
IndirectList<E> - Class in org.eclipse.persistence.indirection
IndirectList allows a domain class to take advantage of TopLink indirection without having to declare its instance variable as a ValueHolderInterface.
IndirectList() - Constructor for class org.eclipse.persistence.indirection.IndirectList
PUBLIC: Construct an empty IndirectList so that its internal data array has size 10 and its standard capacity increment is zero.
IndirectList(int) - Constructor for class org.eclipse.persistence.indirection.IndirectList
PUBLIC: Construct an empty IndirectList with the specified initial capacity and with its capacity increment equal to zero.
IndirectList(int, int) - Constructor for class org.eclipse.persistence.indirection.IndirectList
PUBLIC: Construct an empty IndirectList with the specified initial capacity and capacity increment.
IndirectList(Collection<? extends E>) - Constructor for class org.eclipse.persistence.indirection.IndirectList
PUBLIC: Construct an IndirectList containing the elements of the specified collection, in the order they are returned by the collection's iterator.
IndirectList_Class - Static variable in class org.eclipse.persistence.indirection.IndirectCollectionsFactory
Class implementing IndirectList.
IndirectList_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
IndirectListContainerPolicy - Class in org.eclipse.persistence.internal.queries
PERF: Avoids reflection usage for IndirectList.
IndirectListContainerPolicy() - Constructor for class org.eclipse.persistence.internal.queries.IndirectListContainerPolicy
INTERNAL: Construct a new policy.
IndirectListContainerPolicy(Class<?>) - Constructor for class org.eclipse.persistence.internal.queries.IndirectListContainerPolicy
INTERNAL: Construct a new policy for the specified class.
IndirectMap<K,​V> - Class in org.eclipse.persistence.indirection
IndirectMap allows a domain class to take advantage of TopLink indirection without having to declare its instance variable as a ValueHolderInterface.
IndirectMap() - Constructor for class org.eclipse.persistence.indirection.IndirectMap
PUBLIC: Construct a new, empty IndirectMap with a default capacity and load factor.
IndirectMap(int) - Constructor for class org.eclipse.persistence.indirection.IndirectMap
PUBLIC: Construct a new, empty IndirectMap with the specified initial capacity and default load factor.
IndirectMap(int, float) - Constructor for class org.eclipse.persistence.indirection.IndirectMap
PUBLIC: Construct a new, empty IndirectMap with the specified initial capacity and load factor.
IndirectMap(Map<? extends K, ? extends V>) - Constructor for class org.eclipse.persistence.indirection.IndirectMap
PUBLIC: Construct a new IndirectMap with the same mappings as the given Map.
IndirectMap_Class - Static variable in class org.eclipse.persistence.indirection.IndirectCollectionsFactory
Class implementing IndirectMap.
IndirectMap_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
IndirectSet<E> - Class in org.eclipse.persistence.indirection
IndirectSet is an example implementation of the Set protocol that allows a domain class to take advantage of TopLink Indirection without having to declare its instance variable as a ValueHolderInterface.
IndirectSet() - Constructor for class org.eclipse.persistence.indirection.IndirectSet
Construct an empty IndirectSet.
IndirectSet(int) - Constructor for class org.eclipse.persistence.indirection.IndirectSet
Construct an empty IndirectSet with the specified initial capacity.
IndirectSet(int, float) - Constructor for class org.eclipse.persistence.indirection.IndirectSet
Construct an empty IndirectSet with the specified initial capacity and load factor.
IndirectSet(Collection<? extends E>) - Constructor for class org.eclipse.persistence.indirection.IndirectSet
Construct an IndirectSet containing the elements of the specified collection.
IndirectSet_Class - Static variable in class org.eclipse.persistence.indirection.IndirectCollectionsFactory
Class implementing IndirectSet.
IndirectSet_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
inField - Variable in class org.eclipse.persistence.internal.databaseaccess.InParameterForCallableStatement
 
info - Variable in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
 
info(String) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
info(String) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: This method is called when a info level message needs to be logged.
info(String, String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
INFO - org.eclipse.persistence.logging.LogLevel
Informational messages.
INFO - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
INFO_LABEL - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
INFO_PREFIX - Static variable in class org.eclipse.persistence.logging.AbstractSessionLog
Represents prefix to logged info
infoExt - Variable in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
 
Informix - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
Informix11 - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
Informix11Platform - Class in org.eclipse.persistence.platform.database
An InformixPlatform that fixes many EclipseLink bugs related to Informix support.
Informix11Platform() - Constructor for class org.eclipse.persistence.platform.database.Informix11Platform
Creates a new Informix11Platform.
InformixPlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides Informix specific behavior.
InformixPlatform() - Constructor for class org.eclipse.persistence.platform.database.InformixPlatform
Default constructor.
infos - Variable in class org.eclipse.persistence.descriptors.ReturningPolicy
Stores an object of type Info for every call to any of addField..
INHERITANCE_OUTER_JOIN - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.inheritance.outer-join"
INHERITANCE_WITH_MULTIPLE_TABLES_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
inheritanceExpression - Variable in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
InheritanceHierarchyBuilder - Class in org.eclipse.persistence.internal.codegen
INTERNAL:
inheritancePolicy - Variable in class org.eclipse.persistence.core.descriptors.CoreDescriptor
 
InheritancePolicy - Class in org.eclipse.persistence.descriptors
Purpose: Allows customization of an object's inheritance.
InheritancePolicy() - Constructor for class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Create a new policy.
InheritancePolicy(ClassDescriptor) - Constructor for class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Create a new policy.
inheritanceWithMultipleTablesNotSupported() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
inIndex - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
INIT - Static variable in class org.eclipse.persistence.dynamic.DynamicClassWriter
 
initCalendarCache() - Static method in class org.eclipse.persistence.internal.helper.Helper
PERF: Init the calendar cache use to avoid calendar creation for processing java.sql/util.Date/Time/Timestamp objects.
initcap() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
Initcap - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
initDDLFields() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Inits the DDL generation fields with our defaults.
INITIAL_CONNECTIONS - Static variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
INITIAL_CONTEXT_FACTORY_NAME_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
initialCapacity - Variable in class org.eclipse.persistence.indirection.IndirectList
Store initial size for lazy init.
initialCapacity - Variable in class org.eclipse.persistence.indirection.IndirectMap
Store initial size for lazy init.
initialCapacity - Variable in class org.eclipse.persistence.indirection.IndirectSet
Store initial size for lazy init.
initializationStage - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
initialize() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Initialize operators to avoid concurrency issues.
initialize() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Allow the platform to initialize itself after login/init.
initialize() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Allow the platform to initialize itself after login/init.
initialize() - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Ensure the container class implements IndirectContainer and that it has a constructor which can be used.
initialize() - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Initialize the indirection policy (Do nothing by default)
initialize() - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Nothing required.
initialize() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
 
initialize() - Method in class org.eclipse.persistence.logging.DefaultSessionLog
Initialize the log to be backward-compatible with the original TopLink log.
initialize() - Method in class org.eclipse.persistence.oxm.XMLField
 
initialize() - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
initialize() - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
PUBLIC: Initialize the remote command manager.
initialize() - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
INTERNAL: Initialize default properties.
initialize() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
PUBLIC: Initialize the remote command manager.
initialize() - Method in class org.eclipse.persistence.sessions.coordination.rmi.RMITransportManager
INTERNAL: Initialize default properties for RMI.
initialize() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Initialize default properties.
initialize() - Method in interface org.eclipse.persistence.sessions.SessionProfiler
INTERNAL: Initialize EclipseLink noun tree(DMS)
initialize() - Method in class org.eclipse.persistence.sessions.SessionProfilerAdapter
INTERNAL: Initialize EclipseLink noun tree(DMS)
initialize() - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
initialize() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
initialize(int, float) - Method in class org.eclipse.persistence.indirection.IndirectMap
Initialize the instance.
initialize(Writer) - Method in class org.eclipse.persistence.logging.DefaultSessionLog
Initialize the log.
initialize(Class<?>, String, Session) - Method in class org.eclipse.persistence.sessions.serializers.AbstractSerializer
 
initialize(Class<?>, String, Session) - Method in interface org.eclipse.persistence.sessions.serializers.Serializer
 
initialize(Class<?>, String, Session) - Method in class org.eclipse.persistence.sessions.serializers.XMLSerializer
 
initialize(String, String, String) - Method in class org.eclipse.persistence.sessions.DefaultConnector
INTERNAL: Initialize the connector with the specified settings.
initialize(Map<? extends K, ? extends V>) - Method in class org.eclipse.persistence.indirection.IndirectMap
Initialize the instance.
initialize(Map<String, Boolean>) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
initialize(Map<String, Boolean>) - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
 
initialize(MAPPING, SESSION) - Method in interface org.eclipse.persistence.core.mappings.converters.CoreConverter
PUBLIC: Allow for any initialization.
initialize(OBJECT_BUILDER) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
initialize(ClassDescriptor) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
initialize(ClassDescriptor) - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
initialize(ClassDescriptor) - Method in class org.eclipse.persistence.mappings.querykeys.DirectQueryKey
INTERNAL: Initialize any information in the receiver that requires its descriptor.
initialize(ClassDescriptor) - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
INTERNAL: Initialize any information in the receiver that requires its descriptor.
initialize(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Allow the inheritance properties of the descriptor to be initialized.
initialize(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: Initialize the CMPPolicy settings.
initialize(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
INTERNAL: Allow initialization with the descriptor.
initialize(ClassDescriptor, AbstractSession) - Method in interface org.eclipse.persistence.platform.database.events.DatabaseEventListener
Initialize the descriptor to receive database change events.
initialize(ClassDescriptor, Session) - Method in class org.eclipse.persistence.descriptors.ClassExtractor
Allow for any initialization.
initialize(ClassDescriptor, Session) - Method in class org.eclipse.persistence.descriptors.MethodClassExtractor
INTERNAL: Setup the default classExtractionMethod, or if one was specified by the user make sure it is valid.
initialize(DescriptorQueryManager, AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Initialize the query manager specific to the descriptor type.
initialize(DescriptorQueryManager, AbstractSession) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: Initialize the query manager specific to the descriptor type.
initialize(CoreAbstractSession) - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaClassPathReference
 
initialize(CoreAbstractSession) - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
Allow subclasses to perform initialization if required.
initialize(Context) - Method in class org.eclipse.persistence.oxm.documentpreservation.DocumentPreservationPolicy
INTERNAL
initialize(ObjectBuilder) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
initialize(TreeObjectBuilder) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
INTERNAL
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Initialize the mappings as a separate step.
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: Configure inherited selectors.
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Post initialize the mappings
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Initialize the fetch groups.
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: It is responsible for initializing the policy;
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Initialize the inheritance properties of the descriptor once the mappings are initialized.
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Set the vector to store parent interfaces.
initialize(AbstractSession) - Method in interface org.eclipse.persistence.descriptors.MultitenantPolicy
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.partitioning.CustomPartitioningPolicy
INTERNAL: Initialize the policy.
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.partitioning.HashPartitioningPolicy
INTERNAL: Default the connection pools to all pools if unset.
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.partitioning.PartitioningPolicy
INTERNAL: Initialize the policy.
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.partitioning.ReplicationPartitioningPolicy
INTERNAL: Default the connection pools to all pools if unset.
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
INTERNAL:
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.SelectedFieldsLockingPolicy
INTERNAL: It is responsible for initializing the policy;
initialize(AbstractSession) - Method in interface org.eclipse.persistence.descriptors.SerializedObjectPolicy
initialize the policy
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL: Initialize the mappings as a separate step.
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL:
initialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: It is responsible for initializing the policy;
initialize(AbstractSession) - Method in interface org.eclipse.persistence.descriptors.WrapperPolicy
PUBLIC: Required: Lets the policy perform initialization.
initialize(AbstractSession) - Method in class org.eclipse.persistence.eis.EISDescriptor
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeCollectionMapping
INTERNAL: The mapping is initialized with the given session.
initialize(AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeDirectCollectionMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL: Initialize a HistoryPolicy.
initialize(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
INTERNAL: Allow initialization with the session after login.
initialize(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
If necessary, initialize the factory and the method.
initialize(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Cache all the mappings by their attribute and fields.
initialize(AbstractSession) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: It is responsible for initializing the policy.
initialize(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.SerializedObjectPolicyWrapper
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.QNameInheritancePolicy
INTERNAL: Initialized the inheritance properties of the descriptor once the mappings are initialized.
initialize(AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLSequencedDescriptor
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Initialize this RemoteSessionController with a session.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: For aggregate collection mapping the reference descriptor is cloned.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Initialize the reference descriptor.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: For an aggregate mapping the reference descriptor is cloned.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Initialize the state of mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Allow for initialization of properties and validation.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Initialize and validate the mapping properties.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Initialize and validate the mapping properties.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Initialize the state of mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: The mapping is initialized with the given session.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: The mapping is initialized with the given session.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: The mapping is initialized with the given session.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Initialize mappings
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL: The mapping is initialized with the given session.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ArrayMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ObjectArrayMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Auto-Default orderedFields to fields
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.StructureMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.xdb.DirectToXMLTypeMapping
INTERNAL: The mapping is initialized with the given session.
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
INTERNAL: The mapping is initialized with the given session.
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
INTERNAL: The mapping is initialized with the given session.
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
INTERNAL: The mapping is initialized with the given session.
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
INTERNAL: Initialize the mapping.
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
INTERNAL: Register a ReferenceResolver as an event listener on the session, if one doesn't already exist.
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
initialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Initialize the mappings as a separate step.
initialize(AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: initialize the Policy
initialize(AbstractSession, ClassDescriptor) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: initialize the Policy
initialize(AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.changetracking.ObjectChangeTrackingPolicy
INTERNAL: initialize the Policy
initialize(AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Provide a hook to allow initialization of Container Policy parts
initialize(AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Initialize the key mapping
initialize(AbstractSession, ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Initialize
initialize(RemoteSessionController) - Method in class org.eclipse.persistence.internal.sessions.remote.ReplaceValueHoldersIterator
initialize instance
initialize(DatabaseMapping, Session) - Method in class org.eclipse.persistence.mappings.converters.ClassInstanceConverter
INTERNAL: Set the mapping.
initialize(DatabaseMapping, Session) - Method in interface org.eclipse.persistence.mappings.converters.Converter
PUBLIC: Allow for any initialization.
initialize(DatabaseMapping, Session) - Method in class org.eclipse.persistence.mappings.converters.ConverterClass
INTERNAL:
initialize(DatabaseMapping, Session) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Set the mapping.
initialize(DatabaseMapping, Session) - Method in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
INTERNAL: Set the mapping.
initialize(DatabaseMapping, Session) - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
INTERNAL: Set the mapping.
initialize(DatabaseMapping, Session) - Method in class org.eclipse.persistence.mappings.converters.UUIDConverter
Initialize mapping for JDBC data type.
initialize(DatabaseMapping, Session) - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLListConverter
 
initialize(DatabaseMapping, Session) - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLRootConverter
 
initialize(AbstractTransformationMapping) - Method in interface org.eclipse.persistence.mappings.transformers.AttributeTransformer
 
initialize(AbstractTransformationMapping) - Method in class org.eclipse.persistence.mappings.transformers.AttributeTransformerAdapter
 
initialize(AbstractTransformationMapping) - Method in interface org.eclipse.persistence.mappings.transformers.FieldTransformer
Initialize this transformer.
initialize(AbstractTransformationMapping) - Method in class org.eclipse.persistence.mappings.transformers.FieldTransformerAdapter
 
initialize(AbstractTransformationMapping) - Method in class org.eclipse.persistence.mappings.transformers.MethodBasedAttributeTransformer
INTERNAL: Initilizes the transformer.
initialize(AbstractTransformationMapping) - Method in class org.eclipse.persistence.mappings.transformers.MethodBasedFieldTransformer
 
initialize(ReportQuery) - Method in class org.eclipse.persistence.internal.queries.ReportItem
INTERNAL: Looks up mapping for attribute during preExecute of ReportQuery
initialize(ReportQuery) - Method in class org.eclipse.persistence.queries.ConstructorReportItem
INTERNAL: Looks up mapping for attribute during preExecute of ReportQuery
initialize(DatabaseRecord, ResultSetMappingQuery) - Method in class org.eclipse.persistence.queries.ConstructorResult
INTERNAL:
initialize(DistributedSession) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Allow the connection to initialize an setting in the session.
initialize(Session) - Method in class org.eclipse.persistence.descriptors.copying.AbstractCopyPolicy
Do nothing by default.
initialize(Session) - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Validate and build the methods.
initialize(Session) - Method in interface org.eclipse.persistence.descriptors.copying.CopyPolicy
Allow for any initialization or validation required.
initializeAddTargetQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Initialize addTargetQuery.
initializeAggregateFunctionOperators() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL:
initializeAggregateInheritancePolicy(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: This initialized method is used exclusively for inheritance.
initializeAggregateInheritancePolicy(AbstractSession) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: This is needed by regular aggregate descriptors * but not by EIS aggregate descriptors.
initializeAggregateInheritancePolicy(AbstractSession) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: This is needed by regular aggregate descriptors (because they require review); but not by XML aggregate descriptors.
initializeAliasedField() - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
INTERNAL: Alias the database field for our current environment
initializeAliasedField() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Alias the database field for our current environment
initializeAllIdentityMaps() - Method in class org.eclipse.persistence.internal.sessions.ClientSessionIdentityMapAccessor
INTERNAL: Was PUBLIC: customer will be redirected to Session.
initializeAllIdentityMaps() - Method in class org.eclipse.persistence.internal.sessions.DistributedSessionIdentityMapAccessor
Reset the entire object cache.
initializeAllIdentityMaps() - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
PUBLIC: Reset the entire object cache.
initializeAllIdentityMaps() - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
PUBLIC: Reset the entire object cache.
initializeAllIdentityMaps() - Method in class org.eclipse.persistence.internal.sessions.SessionBrokerIdentityMapAccessor
INTERNAL: Reset the entire object cache.
initializeAllIdentityMaps() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
INTERNAL: Reset the entire object cache, ** be careful using this.
initializeAllIdentityMaps() - Method in class org.eclipse.persistence.services.DevelopmentServices
This method is used to clear the contents of all identity maps.
initializeAllIdentityMaps() - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method is used to clear the contents of all identity maps.
initializeAllIdentityMaps() - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to initialize the identity maps in the session.
initializeAllIdentityMaps() - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
PUBLIC: Resets the entire Object cache.
initializeApplicationNameAndModuleName() - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
INTERNAL: Get the applicationName and moduleName from the application server.
initializeApplicationNameAndModuleName() - Method in class org.eclipse.persistence.platform.server.wls.WebLogic_10_Platform
Deprecated. 
initializeAttributes(Class<?>) - Method in interface org.eclipse.persistence.core.mappings.CoreAttributeAccessor
Allow any initialization to be performed with the descriptor class.
initializeAttributes(Class<?>) - Method in class org.eclipse.persistence.internal.descriptors.InstanceVariableAttributeAccessor
instanceVariableName is converted to Field type.
initializeAttributes(Class<?>) - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Set get and set method after creating these methods by using get and set method names
initializeAttributes(Class<?>) - Method in class org.eclipse.persistence.internal.descriptors.MultitenantPrimaryKeyAccessor
 
initializeAttributes(Class<?>) - Method in class org.eclipse.persistence.internal.descriptors.PersistenceObjectAttributeAccessor
Allow any initialization to be performed with the descriptor class.
initializeAttributes(Class<?>) - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeAccessor
Set get and set method after creating these methods by using get and set method names
initializeAttributes(Class<?>) - Method in class org.eclipse.persistence.mappings.AttributeAccessor
Allow any initialization to be performed with the descriptor class.
initializeAttributes(Class<?>, Class<?>[]) - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Set get and set method after creating these methods by using get and set method names
initializeAttributeTransformer(AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Convert the attribute transformer class name into an AttributeTransformer If the old-style method name in set, then use a MethodBasedAttributeTRansformer
initializeBatchFetchedAttributes() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Iterates through all one to one mappings and checks if any of them use batch fetching.
initializeCacheInvalidationPolicy() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Potentially override the cache invalidation behavior
initializeChangeOrderTargetQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Initialize changeOrderTargetQuery.
initializeChangeOrderTargetQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Initialize changeOrderTargetQuery.
initializeChangeOrderTargetQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Initialize changeOrderTargetQuery.
initializeChildInheritance(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: For an aggregate mapping the reference descriptor is cloned.
initializeChildInheritance(ClassDescriptor, AbstractSession, HashMap<DatabaseField, DatabaseField>, HashMap<DatabaseTable, DatabaseTable>) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: For aggregate mapping the reference descriptor is cloned.
initializeClassExtractor(AbstractSession) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Setup the default classExtractionMethod, or if one was specified by the user make sure it is valid.
initializeCommitOrder() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Reset the commit order from the session's descriptors.
initializeComparisonOperators() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL:
initializeConnectedTime() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Initialize the time that this session got connected.
initializeConnectionData(Connection) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Allow initialization from the connection.
initializeConnectionData(Connection) - Method in class org.eclipse.persistence.platform.database.DB2Platform
 
initializeConnectionData(Connection) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL:
initializeConnectionData(Connection) - Method in class org.eclipse.persistence.platform.database.InformixPlatform
 
initializeConnectionData(Connection) - Method in class org.eclipse.persistence.platform.database.MariaDBPlatform
 
initializeConnectionData(Connection) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
 
initializeConnectionData(Connection) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
 
initializeConnectionData(Connection) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
 
initializeConnectionData(Connection) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
initializeConstructor() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Find the size constructor.
initializeConversions(Class) - Method in class org.eclipse.persistence.mappings.converters.EnumTypeConverter
 
initializeCountSubQuery() - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
INTERNAL: This method creates a report query that counts the number of values in baseExpression.anyOf(attribute) For most queries, a ReportQuery will be created that does a simple count using an anonymous query.
INITIALIZED - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
initializeDataTypes() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
initializeDefaultBuilder() - Method in class org.eclipse.persistence.queries.ModifyAllQuery
INTERNAL: Initialize the expression builder which should be used for this query.
initializeDefaultBuilder() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Initialize the expression builder which should be used for this query.
initializeDefaultQueries(DescriptorQueryManager, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Allow the platform to initialize the CRUD queries to defaults.
initializeDeferredLockManagers() - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Init the deferred lock managers (thread - DeferredLockManager).
initializeDeleteAllQuery() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
Initialize the delete all query.
initializeDeleteAllQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Initialize delete all query.
initializeDeleteAllQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
Initialize delete all query.
initializeDeleteAllQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
Initialize delete all query.
initializeDeleteAllQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
Initialize the delete all query.
initializeDeleteAtIndexQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
initializeDeleteNullQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
initializeDeleteQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
initializeDeleteQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
 
initializeDeleteQuery(AbstractSession, ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Initialize delete query.
initializeDescriptorIfSessionAlive(ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: A descriptor may have been added after the session is logged in.
initializeDescriptors() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Allow each descriptor to initialize any dependencies on this session.
initializeDescriptors() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Allow each descriptor to initialize any dependencies on this session.
initializeDescriptors(Collection) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
 
initializeDescriptors(Collection, boolean) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
 
initializeDescriptors(Map) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Allow each descriptor to initialize any dependencies on this session.
initializeDescriptors(Map, boolean) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Allow each descriptor to initialize any dependencies on this session.
initializeDirectField(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
The field name on the reference table is initialized and cached.
initializeEJB30EventManagers() - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: EJB 3.0 support.
initializeExtendPessimisticLockScope(AbstractSession, ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Initialize extendPessimisticLockeScope and lockRelationTableQuery (if required).
initializeExternalTransactionController() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: initializeExternalTransactionController(): Populate the DatabaseSession's external transaction controller with an instance of my transaction controller class.
initializeExternalTransactionController() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: initializeExternalTransactionController(): Populate the DatabaseSession's external transaction controller with an instance of my transaction controller class.
initializeField(AbstractSession) - Method in interface org.eclipse.persistence.descriptors.SerializedObjectPolicy
unless the field is already initialized by parent descriptor, add the field to the owning descriptor and set field's type
initializeField(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.AbstractSerializedObjectPolicy
 
initializeField(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.SerializedObjectPolicyWrapper
 
initializeFieldClassification(Session) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Set the field classification through searching the fields map.
initializeFieldToTransformers(AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Convert the field names and their corresponding method names to DatabaseFields and Methods.
initializeForeignKeys(AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: The foreign keys primary keys are stored as database fields in the hashtable.
initializeForeignKeys(AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: The foreign keys primary keys are stored as database fields in the map.
initializeForeignKeys(AbstractSession) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: The foreign key names and their primary keys are converted to DatabaseField and stored.
initializeForeignKeysWithDefaults(AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: The foreign keys primary keys are stored as database fields in the map.
initializeFromParent(CachePolicy, ClassDescriptor, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Allow the inheritance properties of the descriptor to be initialized.
initializeFunctionOperators() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL:
initializeIdentityMap(Class<?>) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Reset the identity map for only the instances of the class.
initializeIdentityMap(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.ClientSessionIdentityMapAccessor
INTERNAL: The client session does not have a local identity map, so this has no effect and should not be used.
initializeIdentityMap(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
PUBLIC: Reset the identity map for only the instances of the class.
initializeIdentityMap(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
PUBLIC: Reset the identity map for only the instances of the class.
initializeIdentityMap(Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
PUBLIC: Resets the identity map for only the instances of the given Class type.
initializeIdentityMap(String) - Method in class org.eclipse.persistence.services.DevelopmentServices
This method is used to clear the contents of a particular identity map.
initializeIdentityMap(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method is used to clear the contents of a particular identity map.
initializeIdentityMap(String) - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to initialize the identity maps specified by className.
initializeIdentityMapAccessor() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Set up the IdentityMapManager.
initializeIdentityMapAccessor() - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSession
INTERNAL: Set up the IdentityMapManager.
initializeIdentityMapAccessor() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Set up the IdentityMapManager.
initializeIdentityMapAccessor() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Set up the IdentityMapManager.
initializeIdentityMapAccessor() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Set up the IdentityMapManager.
initializeIdentityMapAccessor() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Set up the IdentityMapManager.
initializeIdentityMaps() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
 
initializeIdentityMaps() - Method in class org.eclipse.persistence.internal.sessions.ClientSessionIdentityMapAccessor
INTERNAL: The client session does not have a local identity map, so this has no effect and should not be used.
initializeIdentityMaps() - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
PUBLIC: Reset the entire local object cache.
initializeIdentityMaps() - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
PUBLIC: Reset the entire local object cache.
initializeIdentityMaps() - Method in class org.eclipse.persistence.internal.sessions.SessionBrokerIdentityMapAccessor
INTERNAL: Reset the entire local object caches.
initializeIdentityMaps() - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
PUBLIC: Resets the entire local Object cache.
initializeIdentityMaps(String[]) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to initialize the identity maps specified by the Vector of classNames.
initializeIdentityMaps(String[]) - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to initialize the identity maps specified by the Vector of classNames.
initializeIdentityMapsOnServerSession() - Method in class org.eclipse.persistence.internal.sessions.DistributedSessionIdentityMapAccessor
INTERNAL: Flushes the server side cache, because the server cache may be shared, caution should be used in calling this.
initializeIdentityMapsOnServerSession() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
 
initializeIdentityMapsOnServerSession() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Initalize all the server side identity maps.
initializeIdentityMapsOnServerSession() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Reset the cache on the server-side session.
initializeIdentityMapsOnServerSession() - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
 
initializeIdentityMapsOnServerSession() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
 
initializeInsertQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
Initialize insert query.
initializeInsertQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
Initialize insert query.
initializeInsertQuery(AbstractSession, ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Initialize insert query.
initializeIsUsedToSetPrimaryKey() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
 
initializeJoinedAttributes() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Iterates through all one to one mappings and checks if any of them use joining.
initializeKey() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Set the keyMethod or keyField based on the keyName.
initializeListOrderField(AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Initializes listOrderField.
initializeListOrderField(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Initializes listOrderField.
initializeListOrderFieldTable(AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Initializes listOrderField's table, does nothing by default.
initializeListOrderFieldTable(AbstractSession) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Initializes listOrderField's table.
initializeLockRelationTableQuery(AbstractSession, ForeignReferenceMapping, Expression) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Initialize lockRelationTableQuery.
initializeLogicalOperators() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL:
initializeManager() - Static method in class org.eclipse.persistence.sessions.factories.SessionManager
INTERNAL: Initialize the singleton session manager.
initializeMapContainerPolicy(AbstractSession, MapContainerPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
initializeMapContainerPolicy(AbstractSession, MapContainerPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
initializeMethod() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Initialize the method.
initializeMethod(DatabaseQuery) - Method in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
INTERNAL: Set the method.
initializeMultipleTablePrimaryKeyFields() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Rebuild the multiple table primary key map.
initializeNamespaceMaps() - Method in class org.eclipse.persistence.internal.oxm.record.XMLTransformationRecord
 
initializeNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceObjectMappingNodeValue
 
initializeOnlyInstancesExpression() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Initialize the expression to use to check the specific type field.
initializeOperators() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL:
initializeOptimisticLocking() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Potentially override the optimistic locking behavior
initializeOrderOperators() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL:
initializeParentInheritance(ClassDescriptor, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: For an aggregate mapping the reference descriptor is cloned.
initializeParentInheritance(ClassDescriptor, ClassDescriptor, AbstractSession, HashMap<DatabaseField, DatabaseField>, HashMap<DatabaseTable, DatabaseTable>) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: For aggregate mapping the reference descriptor is cloned.
initializePlatformOperator(DatabasePlatform) - Method in class org.eclipse.persistence.internal.expressions.ArgumentListFunctionExpression
INTERNAL:
initializePlatformOperator(DatabasePlatform) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL:
initializePlatformOperator(DatabasePlatform) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL:
initializePlatformOperatorNames() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Initialize a mapping to the platform operator names for usage with exceptions.
initializePlatformOperators() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Initialize any platform-specific operators
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.AccessPlatform
Initialize any platform-specific operators
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.AttunityPlatform
Initialize any platform-specific operators
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.DB2MainframePlatform
Initialize any platform-specific operators
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Initialize any platform-specific operators
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
INTERNAL: Initialize any platform-specific operators
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Initialize any platform-specific operators
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
 
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.H2Platform
 
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
 
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.Informix11Platform
Fixes EclipseLink bug 402600 by making sure that the Distinct ExpressionOperator is set to print as DISTINCT&nbsp; (no parentheses, one trailing space), and fixes EclipseLink bug 402953 by adding platform operators for current date and current time.
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
INTERNAL: Initialize any platform-specific operators
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
Initialize any platform-specific operators.
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Initialize any platform-specific operators
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
 
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.PointBasePlatform
 
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Initialize any platform-specific operators
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Initialize any platform-specific operators
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Initialize any platform-specific operators
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Initialize Symfoware platform-specific operators.
initializePlatformOperators() - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
Initialize any platform-specific operators
initializePlatformOperatorSelectors() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Initialize a mapping to the platform operator names for usage with exceptions.
initializePreallocated() - Method in interface org.eclipse.persistence.sequencing.SequencingControl
ADVANCED: Removes all preallocated sequencing objects.
initializePreallocated(String) - Method in interface org.eclipse.persistence.sequencing.SequencingControl
ADVANCED: Removes all preallocated sequencing objects for the given sequence name.
initializePrimaryKey(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Cache primary key and non primary key mappings.
initializePrivateOwnedCriteria() - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: Selection criteria is created with source foreign keys and target keys.
initializePrivateOwnedCriteria() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Selection criteria is created with source foreign keys and target keys.
initializeProperties() - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: It is responsible for initializing the policy;
initializeProperties() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: It is responsible for initializing the policy properties;
initializeProperties() - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: Responsible for pre-initializing.
initializeProperties(DynamicTypeImpl, DynamicEntityImpl) - Method in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesInitializatonPolicy
After entity is created, initialize all required attributes.
initializeProperties(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Initialize the descriptor properties such as write lock and sequencing.
initializeQuerySpecificDefaultBuilder() - Method in class org.eclipse.persistence.queries.ModifyAllQuery
INTERNAL: Initialize the expression builder which should be used for this query.
initializeQuerySpecificDefaultBuilder() - Method in class org.eclipse.persistence.queries.UpdateAllQuery
INTERNAL: Initialize the expression builder which should be used for this query.
initializeQueryTimeout(AbstractSession) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Initialize the queryTimeout to: NoTimeout: If queryTimeout is DefaultTimeout, either directly or via inheritance.
initializeRecord(Mapping) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
initializeRecord(Mapping) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
initializeRecord(Mapping) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
initializeRecord(Mapping) - Method in class org.eclipse.persistence.oxm.record.XMLRootRecord
 
initializeReferenceDescriptor(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Initialize the cloned reference descriptor with table names and primary keys
initializeReferenceDescriptor(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Initialize and set the descriptor for the referenced class in this mapping.
initializeReferenceDescriptor(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
There is no reference descriptor
initializeReferenceDescriptor(AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Initialize and set the descriptor for the referenced class in this mapping.
initializeReferenceDescriptor(AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
Initialize and set the descriptor for the referenced class in this mapping.
initializeReferenceDescriptorAndField(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
initializeReferenceDescriptorAndField(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
initializeReferenceDescriptorAndField(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
initializeReferenceDescriptorAndField(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
initializeReferenceKeys(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
The reference keys on the reference table are initialized
initializeReferenceTable(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
Set the table qualifier on the reference table if required
initializeRelationOperators() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL:
initializeRelationTable(AbstractSession, ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Set the table qualifier on the relation table if required
initializeRemoveAllTargetsQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Initialize removeAllTargetsQuery.
initializeRemoveTargetQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Initialize removeTargetQuery.
initializeSelectionCriteria(AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Selection criteria is created with source foreign keys and target keys.
initializeSelectionCriteria(AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: Selection criteria is created with source foreign keys and target keys.
initializeSelectionCriteria(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Selection criteria is created with target foreign keys and source keys.
initializeSelectionCriteria(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
initializeSelectionCriteria(AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: Selection criteria is created to read target records (nested table) from the table.
initializeSelectionCriteria(AbstractSession) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Selection criteria is created with source foreign keys and target keys.
initializeSelectionCriteriaAndAddFieldsToQuery(Expression) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Selection criteria is created to read target records from the table.
initializeSelectionQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
The selection query is initialized
initializeSelectionQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
A subclass should implement this method if it wants non default behavior.
initializeSelectionStatement(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
initializeSelectionStatement(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
 
initializeSequencing() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Creates sequencing object
initializeSequencing() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
ADVANCED: Creates sequencing object for the session broker.
initializeSequencing() - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
ADVANCED: Creates sequencing object for the session.
initializeSequencing() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: was ADVANCED: Creates sequencing object for the session.
initializeSequencingListeners() - Method in interface org.eclipse.persistence.sessions.ExternalTransactionController
INTERNAL: Initializes sequencing listeners.
initializeSequencingListeners() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Initializes sequencing listeners.
initializeServerNameAndVersion() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: initializeServerNameAndVersion(): Talk to the relevant server class library, and get the server name and version Default is "unknown"
initializeServerNameAndVersion() - Method in class org.eclipse.persistence.platform.server.wls.WebLogicPlatform
INTERNAL: Set the WLS version number through reflection.
initializeSlotValues(DynamicEntityImpl) - Method in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
 
initializeSourceForeignKeysToTargetKeys() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
 
initializeSourceKeys(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
The source keys are initialized
initializeSourceKeys(ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: All the source key field names are converted to DatabaseField and stored.
initializeSourceKeysWithDefaults(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: If a user does not specify the source key then the primary keys of the source table are used.
initializeSourceKeysWithDefaults(DatabaseMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: If a user does not specify the source key then the primary keys of the source table are used.
initializeSourceRelationKeys(ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: All the source relation key field names are converted to DatabaseField and stored.
initializeTables(AbstractSession) - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
INTERNAL: This method is used to get all the database tables and add them into a vector.
initializeTargetForeignKeysToSourceKeys() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
Verify, munge, and hash the target foreign keys and source keys.
initializeTargetForeignKeyToSourceKeys(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: The foreign keys and the primary key names are converted to DatabaseFields and stored.
initializeTargetForeignKeyToSourceKeysWithDefaults(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: The foreign keys and the primary key names are converted to DatabaseFields and stored.
initializeTargetKeys(AbstractSession, ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: All the target key field names are converted to DatabaseField and stored.
initializeTargetKeysWithDefaults(AbstractSession, ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: If a user does not specify the target key then the primary keys of the target table are used.
initializeTargetPrimaryKeyFields() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Initialize targetForeignKeyTable and initializeTargetPrimaryKeyFields.
initializeTargetRelationKeys(ForeignReferenceMapping) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: All the target relation key field names are converted to DatabaseField and stored.
initializeTypeStrings() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
initializeUpdateAtIndexQuery(AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
initializeUpdateListOrderQuery(AbstractSession, String) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
 
initializeWithAllSubclassesExpression() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Initialize the expression to use for queries to the class and its subclasses.
initiallyConformingIndex - Variable in class org.eclipse.persistence.queries.Cursor
Conforming instances found in memory when building the result.
initialNumberOfConnections - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
initialReadSize - Variable in class org.eclipse.persistence.queries.CursoredStreamPolicy
 
initialValue - Variable in class org.eclipse.persistence.internal.codegen.AttributeDefinition
 
initialValue - Variable in class org.eclipse.persistence.sequencing.Sequence
 
initialWriteLockValue - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
initIdentitySequences(Session, String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Initialize platform specific identity sequences.
initIdentitySequences(Session, String) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
INTERNAL: Initialize platform specific identity sequences.
initNonReferenceEntityFetchGroup() - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
 
initObject(Class<T>, String) - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartition
INTERNAL: TODO: clean up the exception handling.
initOrRebuildSelectQuery() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Used by DirectMapMapping to rebuild select query.
initOrRebuildSelectQuery() - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Rebuild select query.
initTableSchema(ClassDescriptor) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Build tables/fields information into the table creator object from a EclipseLink descriptor.
initUnmappedFields(UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
INTERNAL: Identify mapped and not mapped fields (should be done once).
initUnmappedFieldsQuery(UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
INTERNAL: This method called in case there are m_unmappedQueryKeyFields.
injectionManager - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Allow CDI injection of entity listeners
InjectionManager<T> - Interface in org.eclipse.persistence.internal.sessions.cdi
Interface to control CDI-based injection in EntityListeners Any references to CDI specific classes should be reserved for implementers to allow this interface to load in an environment that does not include CDI.
InjectionManagerImpl<T> - Class in org.eclipse.persistence.internal.sessions.cdi
Manages calls to CDI to inject into managed beans This class will be created reflectively to avoid dependencies on CDI classes in environments that do not support CDI
InjectionManagerImpl(Object) - Constructor for class org.eclipse.persistence.internal.sessions.cdi.InjectionManagerImpl
 
injectionTargets - Variable in class org.eclipse.persistence.internal.sessions.cdi.InjectionManagerImpl
 
INLINE - org.eclipse.persistence.internal.databaseaccess.DatasourceCall.ParameterType
 
inMemoryQueryIndirectionPolicy - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Used to determine behavior of indirection in in-memory querying and conforming.
InMemoryQueryIndirectionPolicy - Class in org.eclipse.persistence.queries
Purpose: Provide a means of controlling the behavior of in-memory and conforming queries that access un-instantiated indirection objects in processing the query against cached objects.
InMemoryQueryIndirectionPolicy() - Constructor for class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
InMemoryQueryIndirectionPolicy(int) - Constructor for class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
InMemoryQueryIndirectionPolicy(int, ObjectLevelReadQuery) - Constructor for class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
INNER - org.eclipse.persistence.annotations.JoinFetchType
An inner join is used to fetch the related object.
INNER_JOIN - Static variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Specify any INNER join on a join fetch.
INNER_JOIN_IN_WHERE_CLAUSE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.inner-join-in-where-clause"
innerClasses - Variable in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
inOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
DB2 z/OS requires that at least one argument be a known type
inOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
INOUT - org.eclipse.persistence.internal.databaseaccess.DatasourceCall.ParameterType
 
INOUT - Static variable in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
 
INOUT_CURSOR_ARGUMENTS_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.DBWSException
 
inoutCursorArgumentsNotSupported() - Static method in exception org.eclipse.persistence.exceptions.DBWSException
INTERNAL: Exception when processing DBWS metadata and the descriptor cannot be located for the operation
InOutputParameterForCallableStatement - Class in org.eclipse.persistence.internal.databaseaccess
 
InOutputParameterForCallableStatement(Object, OutputParameterForCallableStatement) - Constructor for class org.eclipse.persistence.internal.databaseaccess.InOutputParameterForCallableStatement
 
InOutputParameterForCallableStatement(Object, DatabaseField, AbstractSession) - Constructor for class org.eclipse.persistence.internal.databaseaccess.InOutputParameterForCallableStatement
 
inParameter - Variable in class org.eclipse.persistence.internal.databaseaccess.InOutputParameterForCallableStatement
 
inParameter - Variable in class org.eclipse.persistence.internal.databaseaccess.InParameterForCallableStatement
 
InParameterForCallableStatement - Class in org.eclipse.persistence.internal.databaseaccess
 
InParameterForCallableStatement(Object, DatabaseField) - Constructor for class org.eclipse.persistence.internal.databaseaccess.InParameterForCallableStatement
 
InProgress - Static variable in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
INPUT_UNSUPPORTED_MSG_TYPE - Static variable in exception org.eclipse.persistence.eis.EISException
 
inputRecordName - Variable in class org.eclipse.persistence.eis.interactions.EISInteraction
Name to pass to the input record creation.
inputResultPath - Variable in class org.eclipse.persistence.eis.interactions.MappedInteraction
 
inputRootElementName - Variable in class org.eclipse.persistence.eis.interactions.XMLInteraction
The root element name to use for the input DOM.
inputRow - Variable in class org.eclipse.persistence.eis.interactions.EISInteraction
Holds database row of input values.
insert() - Method in annotation type org.eclipse.persistence.annotations.QueryRedirectors
A Default Insert Query Redirector will be applied to any executing InsertObjectQuery that does not have a redirector set directly on the query.
insert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Insert privately owned parts
Insert - org.eclipse.persistence.mappings.OneToOneMapping.ShallowMode
 
Insert - Static variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
INSERT - org.eclipse.persistence.mappings.DatabaseMapping.WriteType
 
INSERT - Static variable in class org.eclipse.persistence.descriptors.ReturningPolicy
 
INSERT_INTO_TEMP_TABLE - Static variable in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
INSERT_ORDER_CHILD_BEFORE_PARENT - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INSERT_ORDER_CONFLICTS_WITH_MULTIPLE_TABLE_FOREIGN_KEYS - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INSERT_ORDER_CYCLICAL_DEPENDENCY_BETWEEN_THREE_OR_MORE_TABLES - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INSERT_ORDER_CYCLICAL_DEPENDENCY_BETWEEN_TWO_TABLES - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
insertableFields - Variable in class org.eclipse.persistence.mappings.OneToOneMapping
Keep track of which fields are insertable and updatable.
insertAddedObjectEntry(ObjectLevelModifyQuery, Object, Map) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: An object was added to the collection during an update, insert it.
insertElementAt(E, int) - Method in class org.eclipse.persistence.indirection.IndirectList
 
insertElementAt(E, int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
insertElementAt(E, int) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Add the element a notify any waiters that there are new elements.
insertIntoRelationTable(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Insert into relation table.
insertLink(LinkedCacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.CacheIdentityMap
Insert a new element into the linked list of LinkedCacheKeys.
insertObject() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Insert an object.
insertObject() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Insert the object.
insertObject() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Insert the object
insertObject(boolean) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Insert an object and provide the opportunity to reprepare prior to the insert.
insertObject(boolean) - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Insert the object if the reprepare flag is set, first reprepare the query.
insertObject(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Insert the object and all of its privately owned parts into the database.
insertObject(Object) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Insert the object and all of its privately owned parts into the database.
insertObjectForWrite() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Insert an object in the database.
InsertObjectQuery - Class in org.eclipse.persistence.queries
Purpose: Used for inserting new objects into the database.
InsertObjectQuery() - Constructor for class org.eclipse.persistence.queries.InsertObjectQuery
PUBLIC: Default constructor.
InsertObjectQuery(Object) - Constructor for class org.eclipse.persistence.queries.InsertObjectQuery
PUBLIC: Create an insert query with the object being inserted.
InsertObjectQuery(Call) - Constructor for class org.eclipse.persistence.queries.InsertObjectQuery
PUBLIC: Create an insert query with the custom call.
insertOrderChildBeforeParent(ClassDescriptor, DatabaseTable, DatabaseTable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
insertOrderConflictsWithMultipleTableForeignKeys(ClassDescriptor, DatabaseTable, DatabaseTable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
insertOrderCyclicalDependencyBetweenThreeOrMoreTables(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
insertOrderCyclicalDependencyBetweenTwoTables(ClassDescriptor, DatabaseTable, DatabaseTable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
insertQuery - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
insertQuery - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
Used for insertion for m-m and dc, not used in 1-m.
insertQuery - Variable in class org.eclipse.persistence.mappings.RelationTableMechanism
Used for insertion.
insertSubClass(CoreAttributeGroup) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL: This method will insert the group into the entity hierarchy just below this AttributeGroup.
insertTargetObjects(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Write the target objects if the cascade policy requires them to be written first.
instance - Static variable in class org.eclipse.persistence.internal.helper.InvalidObject
 
instance - Static variable in class org.eclipse.persistence.sessions.serializers.JavaSerializer
 
instance() - Static method in class org.eclipse.persistence.internal.helper.InvalidObject
 
InstanceVariableAttributeAccessor - Class in org.eclipse.persistence.internal.descriptors
Purpose: A wrapper class for handling cases when the domain object has instance variable to map to the database field.
InstanceVariableAttributeAccessor() - Constructor for class org.eclipse.persistence.internal.descriptors.InstanceVariableAttributeAccessor
 
instantiate() - Method in class org.eclipse.persistence.internal.indirection.BackupValueHolder
If the original value holder was not instantiated, then first instantiate it to obtain the backup value.
instantiate() - Method in class org.eclipse.persistence.internal.indirection.CacheBasedValueHolder
 
instantiate() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Instantiate the object.
instantiate() - Method in class org.eclipse.persistence.internal.indirection.ProtectedValueHolder
 
instantiate() - Method in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
 
instantiate() - Method in class org.eclipse.persistence.internal.indirection.TransformerBasedValueHolder
Instantiate the object by executing the method on the transformer.
instantiate() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
Get the value from the wrapped value holder, instantiating it if necessary, and clone it.
instantiate() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Return the object.
instantiate(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.TransformerBasedValueHolder
 
instantiate(AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.BatchValueHolder
Instantiate the object by having the mapping extract its value from the query.
instantiate(AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.CacheBasedValueHolder
 
instantiate(AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.EISOneToManyQueryBasedValueHolder
 
instantiate(AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
Instantiate the object by executing the query on the session.
instantiateAttribute(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Trigger the instantiation of the attribute if lazy.
instantiateAttribute(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Trigger the instantiation of the attribute if lazy.
instantiateAttribute(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Trigger the instantiation of the attribute if lazy.
instantiateChild() - Method in interface org.eclipse.persistence.descriptors.SerializedObjectPolicy
instantiate policy for child descriptor
instantiateChild() - Method in class org.eclipse.persistence.internal.descriptors.SerializedObjectPolicyWrapper
 
instantiateClone(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Returns the clone of the specified object.
instantiateDriver() - Method in class org.eclipse.persistence.sessions.DefaultConnector
INTERNAL: Instantiate the Driver.
instantiateEagerMappings(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Force instantiation to any eager mappings.
instantiateForUnitOfWorkValueHolder(UnitOfWorkValueHolder<T>) - Method in class org.eclipse.persistence.internal.indirection.BackupValueHolder
 
instantiateForUnitOfWorkValueHolder(UnitOfWorkValueHolder<T>) - Method in class org.eclipse.persistence.internal.indirection.BatchValueHolder
Triggers UnitOfWork valueholders directly without triggering the wrapped valueholder (this).
instantiateForUnitOfWorkValueHolder(UnitOfWorkValueHolder<T>) - Method in class org.eclipse.persistence.internal.indirection.CacheBasedValueHolder
Triggers UnitOfWork valueholders directly without triggering the wrapped valueholder (this).
instantiateForUnitOfWorkValueHolder(UnitOfWorkValueHolder<T>) - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Triggers UnitOfWork valueholders directly without triggering the wrapped valueholder (this).
instantiateForUnitOfWorkValueHolder(UnitOfWorkValueHolder<T>) - Method in class org.eclipse.persistence.internal.indirection.ProtectedValueHolder
 
instantiateForUnitOfWorkValueHolder(UnitOfWorkValueHolder<T>) - Method in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
Triggers UnitOfWork valueholders directly without triggering the wrapped valueholder (this).
instantiateForUnitOfWorkValueHolder(UnitOfWorkValueHolder<T>) - Method in class org.eclipse.persistence.internal.indirection.TransformerBasedValueHolder
Triggers UnitOfWork valueholders directly without triggering the wrapped valueholder (this).
instantiateForUnitOfWorkValueHolder(UnitOfWorkValueHolder<T>) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
Triggers UnitOfWork valueholders directly without triggering the wrapped valueholder (this).
instantiateForUnitOfWorkValueHolder(UnitOfWorkValueHolder<T>) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Triggers UnitOfWork valueholders directly without triggering the wrapped valueholder (this).
instantiateImpl() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
a.k.a getValueFromWrappedValueholder.
instantiateObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Trigger the instantiation of the value.
instantiateObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Trigger the instantiation of the value.
instantiateRemoteValueHolderOnServer(RemoteValueHolder) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Instantiated remote value holder.
instantiateRemoteValueHolderOnServer(RemoteValueHolder) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: This will instantiate value holder on the server.
instantiateRemoteValueHolderOnServer(RemoteValueHolder) - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
INTERNAL: This will instantiate value holder on the server.
instantiateRemoteValueHolderOnServer(RemoteValueHolder) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Instantiate remote value holder on the server
instantiateRemoteValueHolderOnServer(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
The corresponding original value holder is instantiated.
instantiateRemoteValueHolderOnServer(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
To instantiate remote value holder on the server side.
instantiateRemoteValueHolderOnServer(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
The corresponding original value holder is instantiated.
instantiateWorkingCopyClone(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Returns the clone of the specified object.
instantiateWorkingCopyCloneFromRow(AbstractRecord, ObjectBuildingQuery, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
It is now possible to build working copy clones directly from rows.
INSTANTIATING_VALUEHOLDER_WITH_NULL_SESSION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
instantiatingValueholderWithNullSession() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
INSTANTIATION_WHILE_CONSTRUCTOR_INSTANTIATION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INSTANTIATION_WHILE_CONSTRUCTOR_INSTANTIATION_OF_FACTORY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
InstantiationCopyPolicy - Class in org.eclipse.persistence.descriptors.copying
Purpose: This is the default copy policy.
InstantiationCopyPolicy - Annotation Type in org.eclipse.persistence.annotations
An InstantiationCopyPolicy is used to set an org.eclipse.persistence.descriptors.copying.InstantiationCopyPolicy on an Entity.
InstantiationCopyPolicy() - Constructor for class org.eclipse.persistence.descriptors.copying.InstantiationCopyPolicy
 
instantiationPolicy - Variable in class org.eclipse.persistence.core.descriptors.CoreDescriptor
 
InstantiationPolicy - Class in org.eclipse.persistence.internal.descriptors
Purpose: Allows customization of how an object is created/instantiated.
InstantiationPolicy() - Constructor for class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
Default constructor
instantiationWhileConstructorInstantiation(ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
instantiationWhileConstructorInstantiationOfFactory(ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
instring() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
instring() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Evaluates the location of the "tofind" text within the string_exp text.
Builds Symfoware equivalent to Instring(string_exp, tofind).
Symfoware: POSITION(tofind In string_exp)
Instring - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
inStringOperator() - Static method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Build instring operator
inSubQuery() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the IN operator taking a subquery.
InSubQuery - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
Int - org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
INT - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
INT_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
INTEGER - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
INTEGER - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
INTEGER_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
INTEGER_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
integerToHexString(Integer) - Static method in class org.eclipse.persistence.internal.helper.Helper
Convert Integer to hexadecimal String.
integrityChecker - Variable in exception org.eclipse.persistence.exceptions.IntegrityException
 
integrityChecker - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
IntegrityChecker catch all the descriptor Exceptions.
IntegrityChecker - Class in org.eclipse.persistence.exceptions
Purpose: IntegrityChecker is used for catching all the descriptor exceptions, and checking database tables.
IntegrityChecker() - Constructor for class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: IntegrityChecker is used for catching all the Descriptor Exceptions, and check database tables.
IntegrityException - Exception in org.eclipse.persistence.exceptions
Purpose: IntegrityExceptions is used to throw all the Descriptors exceptions.
IntegrityException() - Constructor for exception org.eclipse.persistence.exceptions.IntegrityException
INTERNAL: IntegrityExceptions is used to throw all the descriptor exceptions.
IntegrityException(IntegrityChecker) - Constructor for exception org.eclipse.persistence.exceptions.IntegrityException
INTERNAL: To throw all the descriptor exceptions.
InteractionArgument - Class in org.eclipse.persistence.internal.descriptors
Purpose: Used to define the interaction argument mapping.
InteractionArgument() - Constructor for class org.eclipse.persistence.internal.descriptors.InteractionArgument
Default constructor.
InteractionArgument(String, String, Object) - Constructor for class org.eclipse.persistence.internal.descriptors.InteractionArgument
 
interactionSpec - Variable in class org.eclipse.persistence.eis.interactions.EISInteraction
Adapter specific interaction spec.
interceptedSession - Variable in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
 
INTERFACE - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
INTERFACE_TYPE - Static variable in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
InterfaceContainerPolicy - Class in org.eclipse.persistence.internal.queries
Purpose: The abstract class for ContainerPolicy's whose container class implements a container interface.
InterfaceContainerPolicy() - Constructor for class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Construct a new policy.
InterfaceContainerPolicy(Class<?>) - Constructor for class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Construct a new policy for the specified class.
InterfaceContainerPolicy(String) - Constructor for class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Construct a new policy for the specified class name.
interfaceInitialization(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Allow the descriptor to initialize any dependencies on this session.
interfaceInitializationStage - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
interfacePolicy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
InterfacePolicy - Class in org.eclipse.persistence.descriptors
Purpose: Allows for a descriptor's implemented interfaces to be configured.
InterfacePolicy() - Constructor for class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Create a new policy.
InterfacePolicy(ClassDescriptor) - Constructor for class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Create a new policy.
interfaces - Variable in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
INTERNAL_ERROR_ACCESSING_PKFIELD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INTERNAL_ERROR_SET_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
internalBuildChangeRecord(Object, Object, ObjectChangeSet) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Build a change record.
internalBuildChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Build a change record.
internalBuildChangeRecord(Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Directly build a change record based on the newValue without comparison
internalException - Variable in exception org.eclipse.persistence.exceptions.EclipseLinkException
 
internalExceptions - Variable in exception org.eclipse.persistence.exceptions.JPQLException
 
internalExecuteQuery(DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return the results from exeucting the database query.
internalExecuteQuery(DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
INTERNAL: Return the results from exeucting the database query.
internalExecuteQuery(DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the results from executing the database query.
internalExecuteQuery(DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Return the results from exeucting the database query.
internalGetForceUpdate() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: return internal tri-state value so we can decide whether to inherit or not at init time.
internalGetUpdateAllFields() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: return internal tri-state value so we can decide whether to inherit or not at init time.
internalIterateAggregateObject(Object) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Iterate an aggregate object (i.e.
internalIterateIndirectContainer(IndirectContainer) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Iterate an indirect container (IndirectList or IndirectMap).
internalIterateIndirectContainer(IndirectContainer) - Method in class org.eclipse.persistence.internal.sessions.remote.ReplaceValueHoldersIterator
Iterate an indirect container.
internalIteratePrimitive(Object) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Iterate a primitive object (String, Date, Integer, etc.).
internalIterateReferenceObject(Object) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Iterate a (a non-Aggregate) reference object.
internalIterateReferenceObjects(Object) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
internalIterateValueHolder(ValueHolderInterface) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Iterate a value holder.
internalIterateValueHolder(ValueHolderInterface) - Method in class org.eclipse.persistence.internal.sessions.remote.ReplaceValueHoldersIterator
Synchronously create a remote value holder.
internalListeners - Variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
Listeners that are fired after all other listeners are fired
internalLog(SessionLogEntry, Level, Logger) - Method in class org.eclipse.persistence.logging.JavaLog
INTERNAL:
internalPropertyChange(PropertyChangeEvent) - Method in class org.eclipse.persistence.internal.descriptors.changetracking.AggregateAttributeChangeListener
This method creates the object change set if necessary.
internalPropertyChange(PropertyChangeEvent) - Method in class org.eclipse.persistence.internal.descriptors.changetracking.AggregateObjectChangeListener
PUBLIC: This method turns marks the object as changed.
internalPropertyChange(PropertyChangeEvent) - Method in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
INTERNAL: This method marks the object as changed.
internalPropertyChange(PropertyChangeEvent) - Method in class org.eclipse.persistence.internal.descriptors.changetracking.ObjectChangeListener
INTERNAL: This method turns marks the object as changed.
internalProxyException(Exception) - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
internalPutInIdentityMap(Object, Object, Object, long, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Register the object with the cache.
internalPutInIdentityMap(Object, Object, Object, long, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
ADVANCED: Register the object with the identity map.
internalRecreateOriginalCollection(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Recreates the original state of currentCollection.
internalRecreateOriginalCollection(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
Recreates the original state of currentCollection.
internalRecreateOriginalCollection(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
Recreates the original state of the collection.
internalRecreateOriginalCollection(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
Recreates the original state of the collection.
internalRegisterObject(Object, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Register the object with the unit of work.
internalSetForceUpdate(Boolean) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: internal method to set the tri-state value.
internalSetUpdateAllFields(Boolean) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: internal method to set the tri-state value.
intersect() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the INTERSECT operator.
intersect(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a intersect expression with the subquery.
intersect(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a intersect expression with the subquery.
intersect(ReportQuery) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Intersect the query results with the other query.
Intersect - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
intersectAll() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the INTERSECT ALL operator.
intersectAll(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a intersect all expression with the subquery.
intersectAll(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a intersect all expression with the subquery.
IntersectAll - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
INVALID_ACCESSOR_FACTORY - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_ADAPTER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_AMENDMENT_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_AQ_INPUT - Static variable in exception org.eclipse.persistence.eis.EISException
 
INVALID_AQ_INTERACTION_SPEC_TYPE - Static variable in exception org.eclipse.persistence.eis.EISException
 
INVALID_AQ_RECORD_TYPE - Static variable in exception org.eclipse.persistence.eis.EISException
 
INVALID_ASSOCIATION_OVERRIDE_REFERENCE_COLUMN_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_ATTRIBUTE_GROUP_NAME - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
INVALID_ATTRIBUTE_OVERRIDE_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_ATTRIBUTE_REMOVAL_REQUEST - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
INVALID_ATTRIBUTE_TYPE_FOR_ORDER_COLUMN - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_ATTRIBUTE_TYPE_FOR_PROXY_INDIRECTION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_BOOLEAN_VALUE_FOR_ADDINGNAMEDQUERIES - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_BOOLEAN_VALUE_FOR_ENABLESTATMENTSCACHED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_BOOLEAN_VALUE_FOR_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_BOOLEAN_VALUE_FOR_SETTING_ALLOW_NATIVESQL_QUERIES - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_BOOLEAN_VALUE_FOR_SETTING_NATIVESQL - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_BUILDER_IN_QUERY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_CACHESTATEMENTS_SIZE_VALUE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_CALLBACK_METHOD - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_CALLBACK_METHOD_MODIFIER - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_CALLBACK_METHOD_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_CLASS_LOADER_FOR_DYNAMIC_PERSISTENCE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_CLASS_TYPE_FOR_BLOB_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_CLASS_TYPE_FOR_CLOB_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_COLLECTION_TYPE_FOR_RELATIONSHIP - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_COLUMN_ANNOTATION_ON_RELATIONSHIP - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_COMPARATOR_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_COMPOSITE_PK_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_COMPOSITE_PK_SPECIFICATION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_CONFIGURATION - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
INVALID_CONNECTOR - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_CONSISTENCY_PROPERTY_VALUE - Static variable in exception org.eclipse.persistence.eis.EISException
 
INVALID_CONTAINER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_CONTAINER_POLICY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_CONTAINER_POLICY_WITH_TRANSPARENT_INDIRECTION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_CUSTOMIZER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_DATA_MODIFICATION_EVENT - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_DATA_MODIFICATION_EVENT_CODE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_DATA_SOURCE_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_DATABASE_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_DATABASE_CALL - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_DERIVED_COMPOSITE_PK_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_DERIVED_ID_PRIMARY_KEY_FIELD - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_DESCRIPTOR_EVENT_CODE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_DURABILITY_PROPERTY_VALUE - Static variable in exception org.eclipse.persistence.eis.EISException
 
INVALID_EMBEDDABLE_ATTRIBUTE_FOR_ASSOCIATION_OVERRIDE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_EMBEDDABLE_ATTRIBUTE_FOR_ATTRIBUTE_OVERRIDE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_EMBEDDABLE_CLASS_FOR_ELEMENT_COLLECTION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_EMBEDDED_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_ENCRYPTION_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_ENTITY_CALLBACK_METHOD_ARGUMENTS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_ENTITY_LISTENER_CALLBACK_METHOD_ARGUMENTS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_ENTITY_MAPPINGS_DOCUMENT - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_ENUM_CLASS_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
INVALID_ENUM_VALUE - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_EXCEPTIONHANDLER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_EXPLICIT_ACCESS_TYPE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_FACTORY_ATTRIBUTES - Static variable in exception org.eclipse.persistence.eis.EISException
 
INVALID_FIELD_FOR_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_FILE_TYPE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_GET_RETURN_TYPE_FOR_PROXY_INDIRECTION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_ID - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_IDENTITY_MAP - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_IDREF - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_IDREF_CLASS - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_INDEX - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
INVALID_INDIRECTION_CONTAINER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_INDIRECTION_POLICY_OPERATION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_INPUT - Static variable in exception org.eclipse.persistence.eis.EISException
 
INVALID_INTERACTION_SPEC_TYPE - Static variable in exception org.eclipse.persistence.eis.EISException
 
INVALID_INTERFACE - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_LIST - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_LOGGING_FILE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_MAPPED_BY_ID_VALUE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_MAPPING_FOR_CONVERT - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_MAPPING_FOR_CONVERT_WITH_ATTRIBUTE_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_MAPPING_FOR_CONVERTER - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_MAPPING_FOR_EMBEDDED_ID - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_MAPPING_FOR_MAP_KEY_CONVERT - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_MAPPING_FOR_STRUCT_CONVERTER - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_MAPPING_OPERATION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_MAPPING_TYPE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_MERGE_POLICY - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_METHOD_ARGUMENTS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_METHOD_INVOCATION - Static variable in exception org.eclipse.persistence.eis.EISException
 
INVALID_NULL_METHOD_ARGUMENTS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_OPERATION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_OPERATOR - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_OPERATOR_FOR_OBJECT_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_ORDER_BY_VALUE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_PACKAGE_ADAPTER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_PAGING_REQUEST - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
INVALID_PARAMETER - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
INVALID_PERSISTENCE_ROOT_URL - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_PROFILER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_PROP - Static variable in exception org.eclipse.persistence.eis.EISException
 
INVALID_PROPERTY_ADAPTER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_PROPERTY_FOR_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_PROPERTY_GET_WRONG_TYPE - Static variable in exception org.eclipse.persistence.exceptions.DynamicException
 
INVALID_PROPERTY_INDEX - Static variable in exception org.eclipse.persistence.exceptions.DynamicException
 
INVALID_PROPERTY_NAME - Static variable in exception org.eclipse.persistence.exceptions.DynamicException
 
INVALID_PROPERTY_SET_WRONG_TYPE - Static variable in exception org.eclipse.persistence.exceptions.DynamicException
 
INVALID_PROPERTY_VALUE - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
INVALID_QUERY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_QUERY_ITEM - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_QUERY_KEY_IN_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_QUERY_ON_HISTORICAL_SESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_QUERY_ON_SERVER_SESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_READ_ONLY_CLASS_STRUCTURE_IN_UNIT_OF_WORK - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_RECORD_TYPE - Static variable in exception org.eclipse.persistence.eis.EISException
 
INVALID_REF_CLASS - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_REF_XML_PATH - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_SEQUENCING_LOGIN - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_SERVER_PLATFORM_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ServerPlatformException
 
INVALID_SERVICE_VERSION - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
INVALID_SESSION_XML - Static variable in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
INVALID_SESSIONEVENTLISTENER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_SET_PARAMETER_TYPE_FOR_PROXY_INDIRECTION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_SQL_RESULT_SET_MAPPING_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_SWA_REF_ATTRIBUTE_TYPE - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
INVALID_TABLE_FOR_FIELD_IN_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_TARGET_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_TYPE_ADAPTER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_TYPE_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_TYPE_FOR_BASIC_COLLECTION_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_TYPE_FOR_BASIC_MAP_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_TYPE_FOR_ENUMERATED_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_TYPE_FOR_LOB_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_TYPE_FOR_SERIALIZED_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_TYPE_FOR_TEMPORAL_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_TYPE_FOR_VARIABLE_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_TYPE_FOR_VERSION_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_TYPE_FOR_XMLATTRIBUTEREF_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_TYPE_FOR_XMLVALUE_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_USE_OF_ANY_OF_IN_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_USE_OF_NO_INDIRECTION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_USE_OF_TO_MANY_QUERY_KEY_IN_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
INVALID_USE_OF_TRANSPARENT_INDIRECTION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_VALUE_FOR_OBJECT_GRAPH - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_VALUE_FOR_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
INVALID_XML_ELEMENT_REF - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_XML_ELEMENT_WRAPPER - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_XML_PATH_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_XMLELEMENT_IN_XMLELEMENTS - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_XMLLOCATION - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
INVALID_XPATH_FOR_DIRECT_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
INVALID_XPATH_INDEX_STRING - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
INVALID_XPATH_STRING - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
invalidAccessorFactory(Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
invalidAdapterClass(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: The adapter class does not extend jakarta.xml.bind.annotation.adapters.XmlAdapter.
invalidAmendmentMethod(Class<?>, String, Exception, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidAQInput() - Static method in exception org.eclipse.persistence.eis.EISException
 
invalidAQInteractionSpecType() - Static method in exception org.eclipse.persistence.eis.EISException
 
invalidAQRecordType() - Static method in exception org.eclipse.persistence.eis.EISException
 
invalidAssociationOverrideReferenceColumnName(String, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
Invalidate - Static variable in class org.eclipse.persistence.config.CacheUsage
Configures a modify-all query to invalidate the cache.
INVALIDATE - org.eclipse.persistence.annotations.DatabaseChangeNotificationType
Invalidates the EclipseLink cache when a database change event is received for an object.
INVALIDATE_CACHE - Static variable in class org.eclipse.persistence.queries.ModifyAllQuery
 
INVALIDATE_CHANGED_OBJECTS - org.eclipse.persistence.annotations.CacheCoordinationType
Sends a list of the identities of the objects that have changed.
INVALIDATE_CHANGED_OBJECTS - Static variable in class org.eclipse.persistence.descriptors.CachePolicy
 
INVALIDATE_CHANGED_OBJECTS - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
invalidateAll() - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Set all of the objects from all identity maps to be invalid in the cache.
invalidateAll() - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Sets all of the Objects for all classes to be invalid in the cache.
invalidateAllIdentityMaps() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to invalidate the identity maps in the session.
invalidateAllIdentityMaps() - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to invalidate the identity maps in the session.
invalidateCache() - Method in class org.eclipse.persistence.queries.ModifyAllQuery
INTERNAL: Invalid the cache, that is, those objects in the cache that were affected by the query.
invalidateClass(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Set all of the objects of a specific class to be invalid in the cache.
invalidateClass(Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Sets all of the Objects of the specified Class type to be invalid in the cache.
invalidateClass(Class<?>, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Set all of the objects of a specific class to be invalid in the cache.
invalidateClass(Class<?>, boolean) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Sets all of the Objects of the specified Class type to be invalid in the cache.
invalidateIdentityMap(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to invalidate the identity maps specified by className.
invalidateIdentityMap(String) - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to invalidate the identity maps specified by className.
invalidateIdentityMap(String, Boolean) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to invalidate the identity maps specified by className.
invalidateIdentityMap(String, Boolean) - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to invalidate the identity maps specified by className.
invalidateIdentityMaps(String[], Boolean) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to invalidate the identity maps specified by the String[] of classNames.
invalidateIdentityMaps(String[], Boolean) - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to invalidate the identity maps specified by the String[] of classNames.
invalidateObject(Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Set an object to be invalid in the cache.
invalidateObject(Object) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Sets an Object to be invalid in the cache.
invalidateObject(Object, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Set an object to be invalid in the cache.
invalidateObject(Object, boolean) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Set an object to be invalid in the cache.
invalidateObject(Object, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Set an object to be invalid in the cache.
invalidateObject(Object, Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Sets an Object with the specified primary key and Class type to be invalid in the cache.
invalidateObject(Object, Class<?>, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Set an object to be invalid in the cache.
invalidateObject(Object, Class<?>, boolean) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Set an object to be invalid in the cache.
invalidateObject(DataRecord, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Set an object to be invalid in the cache.
invalidateObject(DataRecord, Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Sets an Object with the specified primary key of the passed in Row and Class type to be invalid in the cache.
invalidateObject(DataRecord, Class<?>, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Set an object to be invalid in the cache.
invalidateObject(DataRecord, Class<?>, boolean) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Set an object to be invalid in the cache.
invalidateObjects(Collection) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Set all of the objects in the given collection to be invalid in the cache.
invalidateObjects(Collection) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Sets all of the Objects in the given collection to be invalid in the TopLink identity maps.
invalidateObjects(Collection, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Set all of the objects in the given collection to be invalid in the cache.
invalidateObjects(Collection, boolean) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Set all of the objects in the given collection to be invalid in the cache.
invalidateObjects(Expression) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Set all of the objects from the given Expression to be invalid in the cache.
invalidateObjects(Expression) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Sets all of the Objects matching the given Expression to be invalid in the cache.
invalidateObjects(Expression, Class<?>, DataRecord, boolean) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Invalidate objects meeting selectionCriteria.
invalidateObjects(Expression, Class<?>, DataRecord, boolean) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Queries the cache in-memory with the passed in criteria and invalidates matching Objects.
invalidateObjects(Expression, Class<?>, DataRecord, boolean) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
ADVANCED: Queries the cache in-memory with the passed in criteria and invalidates matching Objects.
invalidateObjects(Expression, Class<?>, DataRecord, boolean) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Queries the cache in-memory with the passed in criteria and invalidates matching Objects.
invalidateOnChange - Variable in class org.eclipse.persistence.queries.QueryResultsCachePolicy
Allows the query cache to be invalidated when any object of any of the query classes is modified.
invalidateQueryCache(Class<?>) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Invalidate/remove any results for the class from the query cache.
invalidateQueryCache(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
Invalidate/remove any results for the class from the query cache.
invalidateQueryCache(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
Invalidate/remove any results for the class from the query cache.
invalidateQueryCache(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
Invalidate/remove any results for the class from the query cache.
invalidateQueryCache(Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Invalidate/remove any results for any query for the class from the query cache.
invalidationClasses - Variable in class org.eclipse.persistence.queries.QueryResultsCachePolicy
Stores the set of classes that should trigger the query cached results to be invalidated.
invalidationPolicy - Variable in class org.eclipse.persistence.queries.QueryResultsCachePolicy
Allows invalidation to be specified.
invalidationState - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
Invalidation State can be used to indicate whether this cache key is considered valid
invalidAttributeGroupName(String, String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
invalidAttributeOverrideName(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: A mapping for the attribute name specified in the attribute-override cannot be found in the descriptor for the embeddable class.
invalidAttributeRef(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception should be used when an @XmlAttributeRef or xml-attribute-ref appears on a non-DataHandler property.
invalidAttributeTypeForOrderColumn(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: An order column can only be applied to an attribute of type List.
invalidAttributeTypeForProxyIndirection(Class<?>, Class<?>[], DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidBooleanValueForAddingNamedQueries(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidBooleanValueForEnableStatmentsCached(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidBooleanValueForProperty(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidBooleanValueForSettingAllowNativeSQLQueries(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidBooleanValueForSettingNativeSQL(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidBuilderInQuery(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidCacheStatementsSize(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidCallbackMethod(Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidCallbackMethodModifier(Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidCallbackMethodName(Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidClassLoaderForDynamicPersistence() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidClassTypeForBLOBAttribute(Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidClassTypeForCLOBAttribute(Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidCollectionMemberDecl - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidCollectionMemberDecl(String, int, int, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidCollectionNavigation - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidCollectionNavigation(String, int, int, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidCollectionTypeForRelationship(Object, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidColumnAnnotationOnRelationship(Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidComparatorClass(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidCompositePKAttribute(String, String, String, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidCompositePKSpecification(Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidConnectionFactoryAttributes() - Static method in exception org.eclipse.persistence.eis.EISException
 
invalidConnector(Connector) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidConsistencyPropertyValue(String) - Static method in exception org.eclipse.persistence.eis.EISException
 
invalidContainerClass(Class<?>, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidContainerPolicy(ContainerPolicy, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidContainerPolicyWithTransparentIndirection(DatabaseMapping, ContainerPolicy) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidContextKeyException - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidContextKeyException(String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidCustomizerClass(Exception, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception would typically be thrown when a customizer class is set that is not an instance of DescriptorCustomizer.
invalidDatabaseAccessor(Accessor) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidDatabaseCall(Call) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidDataModificationEvent(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidDataModificationEventCode(Object, ForeignReferenceMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidDataSourceName(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidDerivedCompositePKAttribute(Object, String, String, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidDerivedIdPrimaryKeyField(String, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidDescriptorEventCode(DescriptorEvent, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidDurabilityPropertyValue(String) - Static method in exception org.eclipse.persistence.eis.EISException
 
invalidElementRef(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
invalidElementWrapper(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
invalidEmbeddableAttributeForAssociationOverride(Object, String, String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidEmbeddableAttributeForAttributeOverride(Object, String, Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidEmbeddableClassForElementCollection(Object, String, Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidEmbeddedAttribute(Object, String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidEncryptionClass(String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidEntityCallbackMethodArguments(Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidEntityListenerCallbackMethodArguments(Object, Object, Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidEntityMappingsDocument(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: Either the URL for the entity-mappings document is invalid, or there is an error in the document.
invalidEnumClassSpecified(Exception, String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
invalidEnumEqualExpression - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidEnumEqualExpression(String, int, int, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidEnumLiteral - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidEnumLiteral(String, int, int, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidEnumValue(Object, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
invalidExceptionHandlerClass(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidExplicitAccessTypeSpecified(Object, Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidExpression(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidExpressionArgument - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidExpressionArgument(String, int, int, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidExpressionForQueryItem(Expression, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidFieldForClass(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: An field name has been encountered that does not exist on the associated entity.
invalidFileName(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidFunctionArgument - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidFunctionArgument(String, int, int, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidGetMethodReturnTypeForProxyIndirection(Class<?>, Class<?>[], DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidGetPropertyType(DatabaseMapping, ClassCastException) - Static method in exception org.eclipse.persistence.exceptions.DynamicException
A request to get a persistent value from a DynamicEntity was made providing a propertyName that does exist but the provided return type failed when casting.
invalidHavingExpression - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidHavingExpression(String, int, int, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidId(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
invalidIdentityMap(ClassDescriptor, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidIdRef(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
invalidIDREFClass(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: The referenced class (i.e.
invalidIndex(IndexOutOfBoundsException, int) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to pass an invalid index to a method
invalidIndirectionContainerClass(ContainerIndirectionPolicy, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidIndirectionPolicyOperation(IndirectionPolicy, String) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidInput() - Static method in exception org.eclipse.persistence.eis.EISException
 
invalidInteractionSpecType() - Static method in exception org.eclipse.persistence.eis.EISException
 
invalidInterface(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
invalidList(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
invalidLoggingFile() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidLoggingFile(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidMappedByIdValue(String, String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidMapping(Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidMappingForConvert(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidMappingForConverter(Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidMappingForConvertWithAttributeName(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidMappingForEmbeddedId(String, Object, String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidMappingForMapKeyConvert(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidMappingForStructConverter(String, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidMappingOperation(DatabaseMapping, String) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidMappingType(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidMergePolicy() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidMethodArguments() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidMethodInvocation() - Static method in exception org.eclipse.persistence.eis.EISException
 
invalidMultipleUseOfSameParameter - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidMultipleUseOfSameParameter(String, int, int, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidNavigation - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidNavigation(String, int, int, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidNullMethodArguments() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
InvalidObject - Class in org.eclipse.persistence.internal.helper
Purpose:Indicates an object that should not be returned from query execution.
invalidOperation(String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidOperator(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidOperatorForObjectComparison(Expression) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidOrderByValue(String, Object, String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: The order-by value provided does not correspond to an attribute on the target entity.
invalidPackageAdapterClass(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: The package level adapter class set on XMLJavaTypeConverter could not be loaded.
invalidPersistenceRootUrl(URL, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidProfilerClass(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidProperty(String) - Static method in exception org.eclipse.persistence.eis.EISException
 
invalidPropertyAdapterClass(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: The field/property level adapter class set on XMLJavaTypeConverter could not be loaded.
invalidPropertyForClass(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: An property name has been encountered that does not exist on the associated entity.
invalidPropertyIndex(DynamicType, int) - Static method in exception org.eclipse.persistence.exceptions.DynamicException
Exception throw when attempting to access a dynamic property by index which does not have an associated mapping.
invalidPropertyName(DynamicType, String) - Static method in exception org.eclipse.persistence.exceptions.DynamicException
A request to get a persistent value from a DynamicEntity was made providing a propertyName that does not correspond to any mappings in the underlying descriptor.
invalidPropertyValue(String, String, String, String, ConversionException) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to call a method with a null input parameter
invalidQuery(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidQueryKeyInExpression(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidQueryOnHistoricalSession(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidQueryOnServerSession(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidRecordType() - Static method in exception org.eclipse.persistence.eis.EISException
 
invalidReferencedXmlPathOnJoin(String, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: No ID or Key property exists on the target class with an XPath == referencedXmlPath.
invalidReferenceToTransientClass(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: The reference class (i.e.
invalidSelectForGroupByQuery - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidSelectForGroupByQuery(String, int, int, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidSequencingLogin() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidServerPlatformClass(String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.ServerPlatformException
 
invalidSessionEventListenerClass(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
InvalidSessionXML() - Static method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
invalidSetClauseNavigation - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidSetClauseNavigation(String, int, int, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidSetClauseTarget - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidSetClauseTarget(String, int, int, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidSetMethodParameterTypeForProxyIndirection(Class<?>, Class<?>[], DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidSetPropertyType(DatabaseMapping, Object) - Static method in exception org.eclipse.persistence.exceptions.DynamicException
Invalid value attempted to be set into a DynamicEntity's property.
invalidSizeArgument - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidSizeArgument(String, int, int, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
invalidSQLResultSetMapping(String, String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidSwaRefAttribute(String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
invalidTableForFieldInExpression(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidTargetClass(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidTypeAdapterClass(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: The type level adapter class set on XMLJavaTypeConverter could not be loaded.
invalidTypeExpression(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidTypeForBasicCollectionAttribute(String, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidTypeForBasicMapAttribute(String, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidTypeForEnumeratedAttribute(String, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidTypeForLOBAttribute(String, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidTypeForSerializedAttribute(String, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidTypeForTemporalAttribute(String, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidTypeForVariableNode(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
invalidTypeForVersionAttribute(String, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidTypeForXmlValueField(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
invalidUseOfAnyOfInExpression(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidUseOfNoIndirection(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidUseOfToManyQueryKeyInExpression(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
invalidUseOfTransparentIndirection(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidValueForObjectGraph(Object) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
invalidValueForProperty(Object, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
invalidXmlElementInXmlElementsList(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception should be used when XmlElements and XmlIDREF are set on a property, but one or more of the XmlElement entries in the list has a type that does not have an XmlID property.
invalidXmlJoinNodeReferencedClass(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: The referenced class (i.e.
invalidXmlLocation(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
Cause: @XmlLocation is set on a non-Locator property.
invalidXmlPathWithAttribute(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
When the target of an XmlPaths -> XmlPath is an attribute, it must be nested, and not the root of the path.
invalidXpathForXMLDirectMapping(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
invalidXPathIndexString(String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
invalidXPathString(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
InverseReferenceMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​MAPPING extends CoreMapping,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
invoke(Object, Method, Object[]) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionHandler
INTERNAL: Handle the method calls on the proxy object.
invoke(Object, Method, Object[]) - Method in class org.eclipse.persistence.internal.oxm.CycleRecoverableContextProxy
 
invokeAttributeTransformer(AbstractRecord, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Invoke the buildAttributeValue method on the AttributeTransformer
invokeCloneMethodOn(Method, Object) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Invoke the specified clone method on the container, handling the necessary exceptions.
invokeConstructor(Constructor<T>, Object[]) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Construct an object with the given Constructor and the given array of arguments.
invokeFieldTransformer(DatabaseField, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
 
invokeFieldTransformer(DatabaseField, FieldTransformer, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Invoke the buildFieldValue on the appropriate FieldTransformer
invokeMethod(Method, Object) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Invoke the givenMethod on a givenObject.
invokeMethod(Method, Object, Object[]) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Invoke the givenMethod on a givenObject using the array of parameters given.
invokeQuery(DatabaseQuery, DataRecord, Session) - Method in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
INTERNAL: Call the static method to execute the query.
invokeQuery(DatabaseQuery, DataRecord, Session) - Method in interface org.eclipse.persistence.queries.QueryRedirector
REQUIRED: Perform the query.
IO_EXCEPTION_OCCURRED - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
ioExceptionOccurred(IOException) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when an ioException happens
is(JavaSEPlatform) - Static method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Check whether current Java SE is exactly matching provided platform.
IS_ASYNCHRONOUS_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
IS_PROPERTY_METHOD_PREFIX - Static variable in class org.eclipse.persistence.internal.helper.Helper
 
IS_VALID_TIMEOUT - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Timeout used is isValid() check for dead connections.
isAbstract - Variable in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isAbstract - Variable in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
isAbstract() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Convenience method to return true if the java class from this descriptor is abstract.
isAbstract() - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isAbstract() - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
isAbstractColumnMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL:
isAbstractColumnMapping() - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL:
isAbstractColumnMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
 
isAbstractColumnMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentMapping
 
isAbstractCompositeCollectionMapping() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Related mapping should implement this method to return true.
isAbstractCompositeCollectionMapping() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
Related mapping should implement this method to return true.
isAbstractCompositeCollectionMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isAbstractCompositeCollectionMapping() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL:
isAbstractCompositeCollectionMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
isAbstractCompositeDirectCollectionMapping() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Related mapping should implement this method to return true.
isAbstractCompositeDirectCollectionMapping() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
Related mapping should implement this method to return true.
isAbstractCompositeDirectCollectionMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isAbstractCompositeDirectCollectionMapping() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL:
isAbstractCompositeDirectCollectionMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
isAbstractCompositeDirectCollectionMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
 
isAbstractCompositeObjectMapping() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Related mapping should implement this method to return true.
isAbstractCompositeObjectMapping() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
Related mapping should implement this method to return true.
isAbstractCompositeObjectMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isAbstractCompositeObjectMapping() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL:
isAbstractCompositeObjectMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
isAbstractDirectMapping() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Related mapping should implement this method to return true.
isAbstractDirectMapping() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
Related mapping should implement this method to return true.
isAbstractDirectMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isAbstractDirectMapping() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL:
isAbstractDirectMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
 
isAbstractDirectMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentMapping
 
isAbstractQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
INTERNAL: return whether this query key is abstract
isAbstractValue() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
isAbstractValue() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
isAccess() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isAccess() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isAccess() - Method in class org.eclipse.persistence.platform.database.AccessPlatform
 
isAcquired() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Return if a thread has acquire this manager.
isAcquired() - Method in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
Avoid acquiring locks for unit of work.
isAcquired() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
isActive - Variable in class org.eclipse.persistence.internal.sessions.CommitManager
The commit manager is active while writing a set of objects (UOW), it is not active when writing a single object (DB session).
isActive - Variable in class org.eclipse.persistence.sessions.server.ClientSession
 
isActive() - Method in class org.eclipse.persistence.internal.databaseaccess.ConnectionCustomizer
INTERNAL: Indicated whether the connection is currently customized.
isActive() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Return if the commit manager is active.
isActive() - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: Connection is open for business.
isActive() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Return if the unit of work is active.
isActive() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Was PUBLIC: customer will be redirected to Session.
isActive() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Return if the unit of work is active (has not been released).
isAddAdditionalExpressionsWithinCurrrentExpressionContext() - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
 
isAfterLast() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
Indicates whether the cursor is after the last row in the result set.
isAfterLast() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Indicates whether the cursor is after the last row in the result set.
isAfterWriteChangesButBeforeCommit() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Has writeChanges() been attempted on this UnitOfWork? It may have either succeeded or failed but either way the UnitOfWork is in a highly restricted state.
isAfterWriteChangesButBeforeCommit() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Has writeChanges() been attempted on this UnitOfWork? It may have either succeeded or failed but either way the UnitOfWork is in a highly restricted state.
isAfterWriteChangesFailed() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Once writeChanges has failed all a user can do really is rollback.
isAggregate - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
isAggregate() - Method in class org.eclipse.persistence.internal.sessions.AggregateObjectChangeSet
 
isAggregate() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Used to determine if the object change set represents an aggregate object.
isAggregateCollectionDescriptor() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is an aggregate collection descriptor
isAggregateCollectionMapping() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL:
isAggregateCollectionMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isAggregateDescriptor() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is an aggregate descriptor
isAggregateMapping() - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Related mapping should implement this method to return true.
isAggregateMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isAggregateObjectMapping() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Related mapping should implement this method to return true.
isAggregateObjectMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isAggregateOperator() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
Aggregate functions are function in the select such as COUNT.
isAggregateSelect - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Used for report query or counts so we know how to treat distincts.
isAggregateSelect() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL:
isAll() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Indicates whether operator has selector All
isAllowConcurrencyExceptionToBeFiredUp() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
isAllowInterruptedExceptionFired() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
isAllowTakingStackTraceDuringReadLockAcquisition() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
isAlreadyMerged(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
isAlterSequenceObjectSupported() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Override this method if the platform supports sequence objects and it's possible to alter sequence object's increment in the database.
isAlterSequenceObjectSupported() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 added SEQUENCE support as of (I believe) v8.
isAlterSequenceObjectSupported() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
 
isAlterSequenceObjectSupported() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
 
isAlterSequenceObjectSupported() - Method in class org.eclipse.persistence.platform.database.H2Platform
 
isAlterSequenceObjectSupported() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
 
isAlterSequenceObjectSupported() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
INTERNAL: Override this method if the platform supports sequence objects and it's possible to alter sequence object's increment in the database.
isAlterSequenceObjectSupported() - Method in class org.eclipse.persistence.platform.database.MariaDBPlatform
INTERNAL: Override this method if the platform supports sequence objects and it's possible to alter sequence object's increment in the database.
isAlterSequenceObjectSupported() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Override this method if the platform supports sequence objects and it's possible to alter sequence object's increment in the database.
isAlterSequenceObjectSupported() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Override this method if the platform supports sequence objects and it's possible to alter sequence object's increment in the database.
isAlterSupported(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.SequenceDefinition
INTERNAL: Indicates whether alter is supported
isAlterSupported(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.SequenceObjectDefinition
INTERNAL: Indicates whether alterIncrement is supported
isAlwaysIncluded(Class<?>, String) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
INTERNAL: returns whether the attributeName is to be always included.
isAny() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Indicates whether operator has selector Any or Some
isAny() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
isAny() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
isAnyMappingNodeValue() - Method in class org.eclipse.persistence.internal.oxm.NodeValue
 
isAnyMappingNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
isAnyMappingNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyObjectMappingNodeValue
 
isAnyOracleJDBCDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether an Oracle JDBC driver is being used.
isAnyOrAll() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Indicates whether operator has selector Any, Some or All
isApplicationJSON() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
INTERNAL
isApplicationJSON() - Method in interface org.eclipse.persistence.internal.oxm.MediaType
 
isApplicationJSON() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
INTERNAL
isApplicationJSON() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
INTERNAL
isApplicationJSON() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
INTERNAL
isApplicationJSON() - Method in enum org.eclipse.persistence.oxm.MediaType
 
isApplicationXML() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
INTERNAL
isApplicationXML() - Method in interface org.eclipse.persistence.internal.oxm.MediaType
 
isApplicationXML() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
INTERNAL
isApplicationXML() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
INTERNAL
isApplicationXML() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
INTERNAL
isApplicationXML() - Method in enum org.eclipse.persistence.oxm.MediaType
 
isArray() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
isArray() - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
 
isAsOfSCNClause() - Method in class org.eclipse.persistence.history.AsOfClause
PUBLIC: Indicates that value is a system change number or an expression evaluating to one.
isAsOfSCNClause() - Method in class org.eclipse.persistence.history.AsOfSCNClause
PUBLIC:
isAssignableFrom(Object, Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
convenience method for java's isAssignableFrom that allows auto-boxing, taking java class or a descriptor as arguments.
isAsynchronous - Variable in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
Determines whether propagation should be synchronous or asynchronous
isAttribute() - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
INTERNAL:
isAttribute() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL:
isAttribute() - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL:
isAttribute() - Method in class org.eclipse.persistence.internal.expressions.ManualQueryKeyExpression
INTERNAL: We can never be an attribute, we're always a join
isAttribute() - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
INTERNAL: Return if the expression is for a direct mapped attribute.
isAttribute() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Return if the expression is for a direct mapped attribute.
isAttribute() - Method in interface org.eclipse.persistence.internal.oxm.mappings.VariableXPathObjectMapping
 
isAttribute() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
isAttribute() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
isAttribute() - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
isAttributeBatchRead(String) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Return if the attribute is specified for batch reading.
isAttributeBatchRead(ClassDescriptor, String) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Return if the attribute is specified for batch reading.
isAttributeBatchRead(ClassDescriptor, String) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return if the attribute is specified for batch reading.
isAttributeChangeTrackingPolicy() - Method in class org.eclipse.persistence.descriptors.changetracking.AttributeChangeTrackingPolicy
Used to track instances of the change policies without doing an instance of check
isAttributeChangeTrackingPolicy() - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
Used to track instances of the change policies without doing an instance of check
isAttributeChangeTrackingPolicy() - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
Used to track instances of the change policies without doing an instance of check
isAttributeEqual(Attr, Attr) - Method in class org.eclipse.persistence.platform.xml.XMLComparer
 
isAttributeExpression - Variable in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
PERF: Cache if the expression is an attribute expression.
isAttributeExpressionJoined(DatabaseMapping) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return if the attribute is specified for joining.
isAttributeFetched(Object, String) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
Return true if the attribute of the object has already been fetched
isAttributeFormDefault() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
isAttributeJoined(ClassDescriptor, String) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Return if the attribute is specified for joining.
isAttributeJoined(ClassDescriptor, DatabaseMapping) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return if the attribute is specified for joining.
isAttributeMappingJoined(DatabaseMapping) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return whether the given attribute is joined as a result of a join on a mapping
isAttributeNameInJoinedExpressionList(String, List) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Iterate through a list of expressions searching for the given attribute name.
isAttributeValueFromObjectInstantiated(Object) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return whether the specified object is instantiated.
isAttributeValueFromObjectInstantiated(Object) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return whether the specified object is instantiated.
isAttributeValueFromObjectInstantiated(Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Return whether the specified object is instantiated.
isAttributeValueFullyBuilt(Object) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: The method validateAttributeOfInstantiatedObject(Object attributeValue) fixes the value of the attributeValue in cases where it is null and indirection requires that it contain some specific data structure.
isAttributeValueFullyBuilt(Object) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: The method validateAttributeOfInstantiatedObject(Object attributeValue) fixes the value of the attributeValue in cases where it is null and indirection requires that it contain some specific data structure.
isAttributeValueFullyBuilt(Object) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: The method validateAttributeOfInstantiatedObject(Object attributeValue) fixes the value of the attributeValue in cases where it is null and indirection requires that it contain some specific data structure.
isAttributeValueFullyBuilt(Object) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: The method validateAttributeOfInstantiatedObject(Object attributeValue) fixes the value of the attributeValue in cases where it is null and indirection requires that it contain some specific data structure.
isAttributeValueFullyBuilt(Object) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: The method validateAttributeOfInstantiatedObject(Object attributeValue) fixes the value of the attributeValue in cases where it is null and indirection requires that it contain some specific data structure.
isAttributeValueFullyBuilt(Object) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: The method validateAttributeOfInstantiatedObject(Object attributeValue) fixes the value of the attributeValue in cases where it is null and indirection requires that it contain some specific data structure.
isAttributeValueInstantiated(Object) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: The referenced object is checked if it is instantiated or not
isAttributeValueInstantiatedOrChanged(Object) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: The referenced object is checked if it is instantiated or not, also check if it has been changed (as indirect collections avoid instantiation on add/remove.
isAttunity() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isAttunity() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isAttunity() - Method in class org.eclipse.persistence.platform.database.AttunityPlatform
 
isAutoDetectMediaType() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Return if this Unmarshaller should try to automatically determine the MediaType of the document (instead of using the MediaType set by setMediaType)
isAutoDetectMediaType() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Return if this XMLUnmarshaller should try to automatically determine the MediaType of the document (instead of using the MediaType set by setMediaType)
isBatchExecutionSupported - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Define if this query is compatible with batch writing.
isBatchExecutionSupported - Variable in class org.eclipse.persistence.queries.ModifyQuery
Define if this query is compatible with batch writing.
isBatchExecutionSupported() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Return if this query is compatible with batch writing.
isBatchExecutionSupported() - Method in class org.eclipse.persistence.queries.ModifyQuery
PUBLIC: Return if this query is compatible with batch writing.
isBeforeFirst() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
Indicates whether the cursor is before the first row in the result set.
isBeforeFirst() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Indicates whether the cursor is before the first row in the result set.
isBigDecimalType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
 
isBigIntegerType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
 
isBindingSupported - Variable in class org.eclipse.persistence.expressions.ExpressionOperator
Allow operator to disable/enable binding for the whole expression.
isBindingSupported() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
PUBLIC: Return if binding is compatible with this operator.
isBlank(String) - Static method in class org.eclipse.persistence.internal.helper.StringHelper
Checks if String is null, is empty ("") or contains white spaces only.
isBlob(int) - Static method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return if the JDBC type is a binary type such as blob.
isBlob(Class<?>) - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
INTERNAL: Used in writeLOB method only to identify a BLOB
isBooleanType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if type is the boolean primitive type or the Boolean wrapper class
isBroker() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Returns true if the session is a session Broker.
isBroker() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Returns true if the session is a session Broker.
isBufferCDATA() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
isBufferCDATA() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
isBufferCDATA() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
IsBuildObjectCompleteOutcome - Class in org.eclipse.persistence.internal.helper.type
Helper type that tells us for a given cache key what threads are having some sort of relationship to the cache key (e.g acquired the cache key as an active thread, have a deferred lock on the cache key or have incremented the counter of readers on the lock or simply are stuck waiting for the cache key to be available.
IsBuildObjectCompleteOutcome(Thread, ConcurrencyManager) - Constructor for class org.eclipse.persistence.internal.helper.type.IsBuildObjectCompleteOutcome
Create a new IsBuildObjectCompleteOutcome.
isBuildObjectOnThreadComplete(Thread, Map<Thread, Thread>, List<Thread>, boolean) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Check if the deferred locks of a thread are all released.
isBuildObjectOnThreadComplete(ConcurrencyManagerState, Thread, Map<Thread, Thread>) - Static method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
This method is nothing more than copy paste code from the algorithm ConcurrencyManager.isBuildObjectOnThreadComplete(Thread, Map, List, boolean) We re-write this code to instead of returning true/false return an actual DTO object that can allow our dead lock explanation algorithm to identify the next thread to expand to explain the dead lock.
isByteType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if type is the byte primitive type or the Byte wrapper class
isCacheable - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
 
isCacheable() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
Used to signal that this mapping references a protected/isolated entity and requires special merge/object building behaviour.
isCacheAccessPreCheckRequired - Variable in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
PERF: Used to avoid readLock and profiler checks to improve performance.
isCacheCheckComplete - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
was a check early return completed
isCacheCheckComplete() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Returns true if an early return cache check was completed
isCachedExpressionQuery - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Indicates whether the query is cached as an expression query in descriptor's query manager.
isCachedExpressionQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Indicates whether the query is cached as an expression query in descriptor's query manager.
isCallableStatementRequired - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
isCallableStatementRequired() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Callable statement is required if there is an output parameter.
isCallableStatementRequired() - Method in class org.eclipse.persistence.queries.StoredProcedureCall
Callable statements are used for StoredProcedures that have argument names (named parameters)
isCallbackRegistered - Variable in class org.eclipse.persistence.sessions.JNDIConnector
 
isCallQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this query uses SQL, a stored procedure, or SDK call.
isCallQueryMechanism() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Return true if this is a call query mechanism
isCallQueryMechanism() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Return true if this is a call query mechanism
isCallQueryMechanism() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Return true if this is a call query mechanism
isCandidateForPrivateOwnedRemoval() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: AggregateCollection contents should not be considered for addition to the UnitOfWork private owned objects list for removal.
isCandidateForPrivateOwnedRemoval() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Returns true if the mapping should be added to the UnitOfWork's list of private owned objects for private owned orphan removal.
isCandidateForPrivateOwnedRemoval() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: DirectCollectionMapping contents should not be considered for addition to the UnitOfWork private owned objects list for removal.
isCascaded - Variable in class org.eclipse.persistence.descriptors.VersionLockingPolicy
 
isCascaded() - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
PUBLIC: Return true if the policy uses cascade locking.
isCascaded() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
PUBLIC: Return true if the policy uses cascade locking.
isCascaded() - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: Specify if the policy cascade locks.
isCascadeDetach() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Check cascading value for the detach operation.
isCascadedLockingSupported() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL Return true if this mapping supports cascaded version optimistic locking.
isCascadedLockingSupported() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL Return true if this mapping supports cascaded version optimistic locking.
isCascadedLockingSupported() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Used when determining if a mapping supports cascaded version optimistic locking.
isCascadedLockingSupported() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL Return true if this mapping supports cascaded version optimistic locking.
isCascadedLockingSupported() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL Return true if this mapping supports cascaded version optimistic locking.
isCascadedLockingSupported() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL Return true if this mapping supports cascaded version optimistic locking.
isCascadeMerge() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Check cascading value for the MERGE operation.
isCascadeOfAggregateDelete() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Returns true if this query has been created as the result of cascading a delete of an aggregate collection in a UnitOfWork CR 2811
isCascadeOnDeleteSetOnDatabase - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Support delete cascading on the database relationship constraint.
isCascadeOnDeleteSetOnDatabase() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
ADVANCED: Return if delete cascading has been set on the database for the mapping's foreign key constraint.
isCascadeOnDeleteSetOnDatabaseOnSecondaryTables - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
Support delete cascading on the database for multiple and inheritance tables.
isCascadeOnDeleteSetOnDatabaseOnSecondaryTables() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Return if delete cascading has been set on the database for the descriptor's multiple tables.
isCascadePersist() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Check cascading value for the CREATE operation.
isCascadeRefresh() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Check cascading value for the REFRESH operation.
isCascadeRemove() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Check cascading value for the REMOVE operation.
isCaseInsensitive() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Return whether this Unmarshaller should perform case insensitive unmarshalling.
isCaseInsensitive() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Return if this Unmarshaller should perform case insensitive unmarshalling.
isCastRequired - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allow platform specific cast to be enabled.
isCastRequired() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return if casting is enabled for platforms that support it.
isCDATA - Variable in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
 
isCDATA() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
 
isCDATA() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
 
isCDATA() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
INTERNAL:
isCDATA() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
isCDATA() - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
 
isCDATA() - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL:
isChangeApplied - Variable in class org.eclipse.persistence.descriptors.changetracking.CollectionChangeEvent
INTERNAL: This flag will indicate if the object has already been removed or added to the collection before raising an event.
isChangeApplied() - Method in class org.eclipse.persistence.descriptors.changetracking.CollectionChangeEvent
INTERNAL: Return the value indicating if the object has been already added or removed from the collection.
isChangeSetFromOutsideUOW - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
Flag set when calling commitToDatabaseWithPreBuiltChangeSet so we are aware the UOW does not contain the changes from this change set.
isChangeSetFromOutsideUOW() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Get the internal flag that tells that this change set was built outside this UOW and the changes it contains cannot be calculated from the contents of this UOW
isChangeTrackingSupported(Project) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Return if this mapping supports change tracking.
isChangeTrackingSupported(Project) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return if this mapping supports change tracking.
isChangeTrackingSupported(Project) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Return if this mapping supports change tracking.
isChangeTrackingSupported(Project) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return if this mapping supports change tracking.
isChangeTrackingSupported(Project) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Return if this mapping supports change tracking.
isChangeTrackingSupported(Project) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Return if this mapping supports change tracking.
isChangeTrackingSupported(Project) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Return if this mapping supports change tracking.
isCharacterType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if type is the char primitive type or the Character wrapper class
isChildDescriptor() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return if the descriptor defines inheritance and is a child.
isChildDescriptor() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Check if it is a child descriptor.
isChildrenLookupTableFilled(boolean) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
isClassReadOnly(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if the class is defined as read-only.
isClassReadOnly(Class<?>) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Checks to see if the specified class is read-only or not in this UnitOfWork.
isClassReadOnly(Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return if the class is defined as read-only.
isClassReadOnly(Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Checks to see if the specified class or descriptor is read-only or not in this UnitOfWork.
isClassTypeExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isClassTypeExpression() - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
 
isClientSession() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if this session is a client session.
isClientSession() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Return if this session is a client session.
isClientSession() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if this session is a client session.
isClientSessionBroker() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Return if this session is a client session broker.
isClob(int) - Static method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return if the JDBC type is a large character type such as clob.
isClob(Class<?>) - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
INTERNAL: Used in writeLOB method only to identify a CLOB
isClonedForSubQuery - Variable in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
isCloneNewObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Check if the object is already registered.
isCloneNewObjectFromParent(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Check if the object is already registered in a parent Unit Of Work
isClonePessimisticLocked(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Helper method that checks if clone has been locked with uow.
isClonePessimisticLocked(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Helper method that checks if clone has been locked with uow.
isCloningRequired() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return if this mapping requires its attribute value to be cloned.
isCloningRequired() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Return if this mapping requires its attribute value to be cloned.
isCloningRequired() - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL: Return if this mapping requires its attribute value to be cloned.
isCloningRequired() - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
 
isClosed - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteCursoredStream
Return if the stream is closed.
isClosed - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
Return if the stream is closed
isClosed() - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: Connection is closed - all resources were freed.
isClosed() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteCursoredStream
INTERNAL: Return if the stream is closed.
isClosed() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
INTERNAL: Return if the stream is closed.
isClosed() - Method in class org.eclipse.persistence.queries.Cursor
PUBLIC: Return if the stream is closed.
isClosing() - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: close method has been called.
isCloudscape() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isCloudscape() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isCloudscape() - Method in class org.eclipse.persistence.platform.database.CloudscapePlatform
Answers whether platform is CloudScape
isCloudscapeJDBCDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether a Cloudscape JDBC driver is being used.
isCMP() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: isCMP(): Answer true if we're in the context of CMP (i.e.
isCMP3Policy() - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: Return if this policy is for CMP3.
isCollapsingStringValues() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
 
isCollapsingStringValues() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
PUBLIC: Returns true if this mapping should collapse all string values before adding them to the collection.
isCollapsingStringValues() - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
PUBLIC: Returns true if this mapping should collapse all string values before setting them in the object on unmarshal.
isCollection - Variable in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
isCollection() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
isCollection() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
isCollection() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
isCollection() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCollection
 
isCollectionMapping() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Related mapping should implement this method to return true.
isCollectionMapping() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
 
isCollectionMapping() - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Return whether this mapping is a Collection type.
isCollectionMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isCollectionMapping() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
 
isCollectionMapping() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
 
isCollectionMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
isCollectionMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
 
isCollectionPolicy() - Method in class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
 
isCollectionPolicy() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
isCollectionQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.DirectCollectionQueryKey
INTERNAL: override the isCollectionQueryKey() method in the superclass to return true.
isCollectionQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.ManyToManyQueryKey
INTERNAL: override the isCollectionQueryKey() method in the superclass to return true.
isCollectionQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.OneToManyQueryKey
INTERNAL: override the isCollectionQueryKey() method in the superclass to return true.
isCollectionQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
PUBLIC:: Related query key should implement this method to return true.
isColumnResult() - Method in class org.eclipse.persistence.queries.ColumnResult
 
isColumnResult() - Method in class org.eclipse.persistence.queries.SQLResult
Return true if this is a column result.
isCommandProcessorASession() - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
ADVANCE: Return whether this commandProcessor is a EclipseLink session or not.
isCommandProcessorASession() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
INTERNAL: Return whether this command manager should process profile commands
isCommitCompleted(Object) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Return if the object has been committed.
isCommitCompletedInPostOrIgnore(Object) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Return if the object has been committed.
isCommitInPostModify(Object) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Return if the object is being in progress of being post modify commit.
isCommitInPreModify(Object) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Return if the object is being in progress of being pre modify commit.
isCommitPending() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if the unit of work is waiting to be committed or in the process of being committed.
isCommunicationFailure - Variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
isCommunicationFailure() - Method in exception org.eclipse.persistence.exceptions.DatabaseException
 
isComparisonOperator() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
Comparison functions are functions such as = and >.
isCompatible(EclipseLinkClassWriter) - Method in class org.eclipse.persistence.dynamic.DynamicClassWriter
Verify that the provided writer is compatible with the current writer.
isCompatible(EclipseLinkClassWriter) - Method in interface org.eclipse.persistence.dynamic.EclipseLinkClassWriter
 
isComplete - Variable in class org.eclipse.persistence.expressions.ListExpressionOperator
 
isComplete - Variable in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Store if the list is fully populated.
isComplete() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: If we have all the required information, this operator is complete and can be used as is.
isComplete() - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
 
isComplete() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Return if the list is complete.
isComplex - Variable in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
isComplex() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
isComplexDatabaseType() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
isComplexDatabaseType() - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
isComplexDatabaseType() - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
isComplexDatabaseType() - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
 
isComplexDatabaseType() - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
isComplexDatabaseType() - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
isComplexTypeWithSimpleContentRequired(Descriptor) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Indicates if a complex type with simple content is to be generated.
isCompoundExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isCompoundExpression() - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
isConcurrent - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Allow a session to enable concurrent processing.
isConcurrent - Variable in class org.eclipse.persistence.queries.LoadGroup
 
isConcurrent() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL: Only LoadGroups allow concurrency.
isConcurrent() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Return if the session enables concurrent processing.
isConcurrent() - Method in class org.eclipse.persistence.queries.AttributeGroup
INTERNAL: Only LoadGroups allow concurrency.
isConcurrent() - Method in class org.eclipse.persistence.queries.LoadGroup
ADVANCED: Return if the load group should load its relationships concurrently.
isConnected - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Keep track of whether the accessor is "connected".
isConnected - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
isConnected() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return whether the accessor is connected to the data store.
isConnected() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return true if the accessor is currently connected to a data source.
isConnected() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if this session is connected to the database.
isConnected() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
 
isConnected() - Method in class org.eclipse.persistence.sequencing.DefaultSequence
PUBLIC: Indicates that Sequence is connected.
isConnected() - Method in class org.eclipse.persistence.sequencing.Sequence
PUBLIC: Indicates that Sequence is connected.
isConnected() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Return if all sessions are still connected to the database.
isConnected() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Return if this session is connected to the server.
isConnected() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Was PUBLIC: customer will be redirected to Session.
isConnected() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: Return if this pool has been connected to the database.
isConnected() - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Return if this session has been connected to the database.
isConnected() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if this session is connected to the database.
isConnectedUsingSeparateConnection() - Method in interface org.eclipse.persistence.sequencing.SequencingControl
PUBLIC: Indicates whether sequencing actually uses separate connection(s).
isConnectionDataInitialized - Variable in class org.eclipse.persistence.platform.database.DerbyPlatform
 
isConnectionHealthValidatedOnError() - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
isConnectionHealthValidatedOnError() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: On an SQL Exception EclipseLink will ping the database to determine if the connection used can continue to be used for queries.
isConnectionHealthValidatedOnError() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: This value defaults to false when not on a DatabaseLogin as the functionality has not been implemented for other datasource type.
isConnectionHealthValidatedOnError() - Method in interface org.eclipse.persistence.sessions.Login
PUBLIC: This value defaults to false when not on a DatabaseLogin as the functionality has not been implemented for other datasource type.
isConnectionHealthValidatedOnError(DatabaseCall, DatabaseAccessor) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
INTERNAL: Validate if set, or no timeout.
isConsideredInvalid(Object, CacheKey, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Check if the object is invalid and *should* be refreshed.
isConsideredInvalid(Object, CacheKey, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Check if the object is invalid and *should* be refreshed.
isConstantExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isConstantExpression() - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
 
isConstructor - Variable in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
isConstructor() - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
isConstructorItem() - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
isConstructorItem() - Method in class org.eclipse.persistence.queries.ConstructorReportItem
 
isConstructorQuery() - Method in class org.eclipse.persistence.internal.jpa.jpql.ConstructorQueryMappings
Determines whether the JPQL query is a constructor query, i.e.
isConstructorResult() - Method in class org.eclipse.persistence.queries.ConstructorResult
Return true if this is a constructor result.
isConstructorResult() - Method in class org.eclipse.persistence.queries.SQLResult
Return true if this is a constructor result.
isContainerValue() - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL:
isContainerValue() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
 
isContainerValue() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
isContainerValue() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
isContainerValue() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
isContainerValue() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
isContainerValue() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
 
isContainerValue() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
isContainerValue() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
isContainerValue() - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
 
isContainerValue() - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
isCoordinatedWithProperty - Variable in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
The variable below is used as part of the implementation of WeavedAttributeValueHolderInterface It is used to track whether a valueholder that has been weaved into a class is coordinated with the underlying property Set internally in EclipseLink when the state of coordination between a weaved valueholder and the underlying property is known
isCoordinatedWithProperty() - Method in class org.eclipse.persistence.indirection.ValueHolder
Used as part of the implementation of WeavedAttributeValueHolderInterface Used to track whether a valueholder that has been weaved into a class is coordinated with the underlying property
isCoordinatedWithProperty() - Method in interface org.eclipse.persistence.indirection.WeavedAttributeValueHolderInterface
When a valueholder is triggered, the weaved code will ensure its value is coordinated with the underlying property.
isCoordinatedWithProperty() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
This method is used as part of the implementation of WeavedAttributeValueHolderInterface It is used to check whether a valueholder that has been weaved into a class is coordinated with the underlying property
isCopyGroup() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL: This method is used internally when converting to a copy group.
isCopyGroup() - Method in class org.eclipse.persistence.queries.AttributeGroup
INTERNAL: This method is used internally when converting to a copy group.
isCopyGroup() - Method in class org.eclipse.persistence.sessions.CopyGroup
 
isCreatable - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
 
isCreatable() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
isCursor - Variable in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
isCursor() - Method in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
isCursor() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
Indicates if a given subclass represents a PL/SQL cursor.
isCursor() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCursor
 
isCursoredStreamPolicy() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
isCursoredStreamPolicy() - Method in class org.eclipse.persistence.queries.CursoredStreamPolicy
 
isCursorOutputProcedure - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Allow for a single cursored output parameter.
isCursorOutputProcedure() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Used for Oracle result sets through procedures.
isCursorPolicy() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
isCursorPolicy() - Method in class org.eclipse.persistence.queries.CursorPolicy
 
isCursorReturned() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
The return type is one of, NoReturn, ReturnOneRow or ReturnManyRows.
isCursorReturned() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The return type is one of, NoReturn, ReturnOneRow or ReturnManyRows.
isCustomQualifier - Variable in class org.eclipse.persistence.sequencing.Sequence
 
isCustomQualifier() - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL:
isCustomQueryUsed - Variable in class org.eclipse.persistence.queries.DatabaseQuery
PERF: Store if this query will use the descriptor custom query.
isCustomQueryUsed() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: PERF: Return if this query will use the descriptor custom query instead of executing itself.
isCustomSelectionQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: If the query mechanism is a call query mechanism and there are no arguments on the query then it must be a foreign reference custom selection query.
isDatabaseMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL:
isDatabaseSession() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if this session is a database session.
isDatabaseSession() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Return if this session is a database session.
isDatabaseSession() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if this session is a database session.
isDataExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isDataExpression() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
isDataModifyQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return if this is a data modify query.
isDataModifyQuery() - Method in class org.eclipse.persistence.queries.DataModifyQuery
PUBLIC: Return if this is a data modify query.
isDataReadQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return if this is a data read query.
isDataReadQuery() - Method in class org.eclipse.persistence.queries.DataReadQuery
PUBLIC: Return if this is a data read query.
isDatasourceConnected() - Method in class org.eclipse.persistence.eis.EISAccessor
Return if the connection to the "data source" is connected.
isDatasourceConnected() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return true if the receiver is currently connected to a data source.
isDatasourceConnected() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return if the driver level connection is connected.
isDatasourceConnected() - Method in class org.eclipse.persistence.internal.oxm.XMLAccessor
Return if the connection to the "data source" is connected.
isDateClass(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
 
isDB2() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isDB2() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isDB2() - Method in class org.eclipse.persistence.platform.database.DB2Platform
 
isDB2() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
 
isDB2JDBCDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether an IBM DB2 native client JDBC driver is being used.
isDB2Z() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isDB2Z() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isDB2Z() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
 
isDBase() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isDBase() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isDBase() - Method in class org.eclipse.persistence.platform.database.DBasePlatform
 
isDead - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
isDead() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if the unit of work is dead.
isDead() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
ADVANCED: Return if the connection pool's database is down, and failover should be used.
isDeadLockPotentiallyCausedByCacheKeyWithCorruptedActiveThread() - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
isDeadLockPotentiallyCausedByCacheKeyWithCorruptedNumberOfReaders() - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
isDecorated() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
INTERNAL: Is this decorated / has an AS OF (some past time) clause.
isDefaultEmptyContainer() - Method in interface org.eclipse.persistence.internal.oxm.ContainerValue
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in interface org.eclipse.persistence.internal.oxm.mappings.XMLContainerMapping
Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultEmptyContainer() - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
INTERNAL Return true if an empty container should be set on the object if there is no presence of the collection in the XML document.
isDefaultLock() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Helper method to determine the default mode.
isDefaultLock() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Helper method to determine the default mode.
isDefaultPropertiesQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return true if the query uses default properties.
isDefaultPropertiesQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return true if the query uses default properties.
isDefaultPropertiesQuery() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Return true if the query uses default properties.
isDefaultPropertiesQuery() - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: Return true if the query uses default properties.
isDeferred - Variable in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
Defines if this change should be calculated at commit time using the two collections.
isDeferred() - Method in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
Returns if this change should be calculated at commit time using the two collections.
isDeferredChangeDetectionPolicy() - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
Used to track instances of the change policies without doing an instance of check
isDeferredChangeDetectionPolicy() - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
Used to track instances of the change policies without doing an instance of check
isDeferredChangeDetectionPolicy() - Method in class org.eclipse.persistence.descriptors.changetracking.ObjectChangeTrackingPolicy
Used to track instances of the change policies without doing an instance of check
isDefinedAsOneToManyMapping - Variable in class org.eclipse.persistence.mappings.ManyToManyMapping
266912: Since: EclipseLink 2.0 for the Metamodel API For 1:1 and m:m mappings - track the original externally defined mapping if different Note: This field will provide differentiation for the following external to internal representations for mapping types
- A OneToManyMapping will be represented by a ManyToManyMapping if unidirectional
- A ManyToOneMapping will be represented by a OneToOneMapping (without a FK constraint)
isDefinedAsOneToManyMapping() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Return whether this mapping was originally defined as a OneToMany.
isDeleteAllQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return if this is a delete all query.
isDeleteAllQuery() - Method in class org.eclipse.persistence.queries.DeleteAllQuery
PUBLIC: Return if this is a delete all query.
isDeleteObjectQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return if this is a delete object query.
isDeleteObjectQuery() - Method in class org.eclipse.persistence.queries.DeleteObjectQuery
PUBLIC: Return if this is a delete object query.
isDerby() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isDerby() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isDerby() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL: Answers whether platform is Derby
isDescriptorForInterface() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return if the java class is an interface.
isDescriptorTypeAggregate() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC return true if this descriptor is any type of aggregate descriptor.
isDescriptorTypeNormal() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: return true if this descriptor is an entity.
isDirectCollection() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
Return false by default, only possible for QueryKeyExpression.
isDirectCollection() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Indicates whether this expression corresponds to DirectCollection.
isDirectCollectionMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isDirectCollectionMapping() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL:
isDirectCollectionQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.DirectCollectionQueryKey
INTERNAL: override the isDirectCollectionQueryKey() method in the superclass to return true.
isDirectCollectionQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
PUBLIC:: Related query key should implement this method to return true.
isDirectMapMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isDirectMapMapping() - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Related mapping should implement this method to return true.
isDirectMapPolicy() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
isDirectQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.DirectQueryKey
INTERNAL: override the isDirectQueryKey() method in the superclass to return true.
isDirectQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
PUBLIC:: Related query key should implement this method to return true.
isDirectReadQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return if this is a direct read query.
isDirectReadQuery() - Method in class org.eclipse.persistence.queries.DirectReadQuery
PUBLIC: Return if this is a direct read query.
isDirectToFieldMapping() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Related mapping should implement this method to return true.
isDirectToFieldMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isDirectToFieldMapping() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL:
isDirectToXMLTypeMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isDirectToXMLTypeMapping() - Method in class org.eclipse.persistence.mappings.xdb.DirectToXMLTypeMapping
 
isDisableForeignKey() - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
isDiscoveryStopped() - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
ADVANCED: Return true if discovery has been stopped at the time this method is called.
isDistinctComputed() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: return true if this query has computed its distinct value already
isDistinctComputed() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: return true if this query has computed its distinct value already
isDistributedSession() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if this session is a distributed session.
isDistributedSession() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Return if this session is a distributed session.
isDistributedSession() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if this session is a distributed session.
isDOMRecordSupported - Variable in class org.eclipse.persistence.eis.EISPlatform
 
isDOMRecordSupported() - Method in class org.eclipse.persistence.eis.EISPlatform
Return if this platform supports XML/DOM Records.
isDoubleType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if type is the double primitive type or the Double wrapper class
isDowncast - Variable in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
isDowncast() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
INTERNAL:
isDowncast(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL Return true if it uses a cast class and query is downcasting.
isDynamicCall(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Return if the call is dynamic SQL call.
isDynamicSQLRequiredForFunctions() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Some databases have issues with using parameters on certain functions and relations.
isDynamicSQLRequiredForFunctions() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL DB2 has some issues with using parameters on certain functions and relations.
isDynamicSQLRequiredForFunctions() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL Derby has some issues with using parameters on certain functions and relations.
isDynamicSQLRequiredForFunctions() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
INTERNAL Firebird has some issues with using parameters on certain functions and relations.
isDynamicSQLRequiredForFunctions() - Method in class org.eclipse.persistence.platform.database.H2Platform
INTERNAL H2 has some issues with using parameters on certain functions and relations.
isDynamicSQLRequiredForFunctions() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
INTERNAL HSQL has some issues with using parameters on certain functions and relations.
isDynamicSQLRequiredForFunctions() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Symfoware does not support the use of multiple parameters in certain functions.
This allows statements to disable binding only in these cases.
isDynamicStatementInUse - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
 
isDynamicStatementInUse() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return the cached statement for dynamic SQL execution is in use.
isEasilyInstantiated() - Method in class org.eclipse.persistence.internal.indirection.BatchValueHolder
INTERNAL: Answers if this valueholder is easy to instantiate.
isEasilyInstantiated() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
INTERNAL: Answers if this valueholder is easy to instantiate.
isEasilyInstantiated() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
INTERNAL: Answers if this valueholder is easy to instantiate.
isEasilyInstantiated() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
INTERNAL: Answers if this valueholder is easy to instantiate.
isEclipseLinkSession - Variable in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
Determines whether profiling command should be send
isEISDescriptor() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return if the descriptor maps to an EIS or NoSQL datasource.
isEISDescriptor() - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Return if the descriptor maps to an EIS or NoSQL datasource.
isEISInteraction() - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
 
isEISInteraction() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
isEISMapping() - Method in class org.eclipse.persistence.eis.mappings.EISCompositeCollectionMapping
INTERNAL:
isEISMapping() - Method in class org.eclipse.persistence.eis.mappings.EISCompositeDirectCollectionMapping
INTERNAL:
isEISMapping() - Method in class org.eclipse.persistence.eis.mappings.EISCompositeObjectMapping
INTERNAL:
isEISMapping() - Method in class org.eclipse.persistence.eis.mappings.EISDirectMapping
INTERNAL:
isEISMapping() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL:
isEISMapping() - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL:
isEISMapping() - Method in class org.eclipse.persistence.eis.mappings.EISTransformationMapping
INTERNAL:
isEISMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: All EIS mappings should implement this method to return true.
isElementCollectionMapping() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL:
isElementCollectionMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isElementCollectionMapping() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL:
isElementFormDefault() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
isEmpty() - Method in class org.eclipse.persistence.eis.EISMappedRecord
Return if the row is empty.
isEmpty() - Method in class org.eclipse.persistence.indirection.IndirectList
 
isEmpty() - Method in class org.eclipse.persistence.indirection.IndirectMap
 
isEmpty() - Method in class org.eclipse.persistence.indirection.IndirectSet
 
isEmpty() - Method in class org.eclipse.persistence.internal.expressions.TableAliasLookup
isEmpty method comment.
isEmpty() - Method in class org.eclipse.persistence.internal.helper.IdentityHashSet
 
isEmpty() - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
 
isEmpty() - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
isEmpty() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
isEmpty() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
isEmpty() - Method in class org.eclipse.persistence.internal.helper.ReadLockManager
True if the tracing the data on the object has been completely removed.
isEmpty() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
If empty wait until an element has been added or is complete.
isEmpty() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
isEmpty() - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
isEmpty() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
isEmpty() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Return if the row is empty.
isEmpty() - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Return if the result is empty.
isEmpty(Object) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Return whether the container is empty.
isEmpty(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return whether the container is empty.
isEmpty(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: A logical expression for the collection attributeName being empty.
isEmptyCollection() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
isEmptyCollection() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
isEmptyCollectionGenerated() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
isEntireObjectPK - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Indicates whether the entire target object is primary key - in that case the object can't be updated in the db, but rather deleted and then re-inserted.
isEntityFetchGroup() - Method in class org.eclipse.persistence.internal.queries.EntityFetchGroup
 
isEntityFetchGroup() - Method in class org.eclipse.persistence.queries.FetchGroup
 
isEntityResult() - Method in class org.eclipse.persistence.queries.EntityResult
 
isEntityResult() - Method in class org.eclipse.persistence.queries.SQLResult
Return true if this is an entity result.
isEnumType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
 
isEqualNull(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
Check if the expression is an equal null expression, these must be handle in a special way in SQL.
isEqualUsingIdenity() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
INTERNAL
isEquivalentToNull(Object) - Static method in class org.eclipse.persistence.internal.helper.Helper
Check if the value is 0 (int/long) for primitive ids.
isExcludedValue(Object) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
INTERNAL: returns if the value is in the values to be excluded automatically.
isExclusive() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Indicates whether ExclusiveIsolatedClientSession should be created.
isExclusiveAlways() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Indicates whether exclusiveMode is Always.
isExclusiveConnectionRequired() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: This method is called in case externalConnectionPooling is used.
isExclusiveConnectionRequired() - Method in class org.eclipse.persistence.internal.sessions.ExclusiveIsolatedClientSession
INTERNAL: This method is called in case externalConnectionPooling is used.
isExclusiveConnectionRequired() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: This method is called in case externalConnectionPooling is used.
isExclusiveIsolated() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Indicates whether exclusiveMode is Isolated.
isExclusiveIsolatedClientSession() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if this session is an exclusive isolated client session.
isExclusiveIsolatedClientSession() - Method in class org.eclipse.persistence.internal.sessions.ExclusiveIsolatedClientSession
PUBLIC: Return if this session is an exclusive isolated client session.
isExecuteCall - Variable in class org.eclipse.persistence.queries.ResultSetMappingQuery
 
isExecuteUpdate() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Returns true if this call returns from a statement.execute call.
isExecutingEvents - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
records that the UOW is executing deferred events.
isExecutionClone - Variable in class org.eclipse.persistence.queries.DatabaseQuery
PERF: Determines if the query has already been cloned for execution, to avoid duplicate cloning.
isExecutionClone() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: PERF: Return if the query is an execution clone.
isEXISTS() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
Return if using the EXISTS fetch type.
isExpressionBuilder() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isExpressionBuilder() - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL:
isExpressionQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this query uses an expression query mechanism
isExpressionQueryMechanism() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Return true if this is an expression query mechanism
isExpressionQueryMechanism() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return true if this is an expression query mechanism.
isExtendingPessimisticLockScope(ObjectBuildingQuery) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Indicates whether the source query's pessimistic lock scope scope should be extended in the target query.
isExtensionSupported(String) - Method in class org.eclipse.persistence.tools.PackageRenamer
Return true if the PackageRenamer should work on the given file extension.
isFetchGroup() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
isFetchGroup() - Method in class org.eclipse.persistence.queries.FetchGroup
 
isFieldExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isFieldExpression() - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
 
isFieldMatchingRequired - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
isFieldMatchingRequired() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Return if field matching is required.
isFinal - Variable in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isFinal() - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isFinalizersEnabled - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
PERF: Allow for finalizers to be enabled, currently enables client-session finalize.
isFinalizersEnabled() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if this session's decendants should use finalizers.
isFinalizersEnabled() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if this session's descendants should use finalizers.
isFinished() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Return whether all the results of the call have been returned.
isFinished() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Return whether all the results of the call have been returned.
isFinished() - Method in interface org.eclipse.persistence.queries.Call
INTERNAL: Return whether the call is finished returning all of its results (e.g.
isFinished() - Method in class org.eclipse.persistence.queries.JPQLCall
Return whether all the results of the call have been returned.
isFirebird() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isFirebird() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
 
isFirst() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
Indicates whether the cursor is on the first row of the result set.
isFirst() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
isFirst() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Indicates whether the cursor is on the first row of the result set.
isFirstElementPrinted - Variable in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
isFirstElementPrinted() - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
INTERNAL: Used in figuring out when to print a comma in the select clause
isFirstRepeatingThreadThatExplainsDeadLock() - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
isFirstToAdd - Variable in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
isFirstToAddAlreadyInCollection - Variable in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
isFirstToAddAlreadyInCollection() - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
isFirstToRemove - Variable in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
isFirstToRemoveAlreadyOutCollection - Variable in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
isFirstToRemoveAlreadyOutCollection() - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
isFloatingPointType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if the specified type represents an floating point type or a wrapper class of an floating point type.
isFloatType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if type is the float primitive type or the Float wrapper class
isFlush - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
isFlush() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
isForDetach() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
isForeignKeyRelationship - Variable in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
Keeps track if any of the fields are foreign keys.
isForeignKeyRelationship - Variable in class org.eclipse.persistence.mappings.ObjectReferenceMapping
Keeps track if any of the fields are foreign keys.
isForeignKeyRelationship() - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Return if the 1-M mapping has a foreign key dependency to its target.
isForeignKeyRelationship() - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Return if the 1-1 mapping has a foreign key dependency to its target.
isForeignReferenceMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isForeignReferenceMapping() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL:
isForeignReferenceQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
INTERNAL: override the isForeignReferenceQueryKey() method in the superclass to return true.
isForeignReferenceQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
PUBLIC:: Related query key should implement this method to return true.
isForMapKey - Variable in class org.eclipse.persistence.mappings.converters.ConverterClass
 
isFormattedOutput() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
Returns if this Marshaller should format the output.
isFormattedOutput() - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
isForRefresh - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
records that this merge process is for a refresh
isForRefresh() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
isForUpdateCompatibleWithDistinct() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether SELECT DISTINCT ...
isForUpdateCompatibleWithDistinct() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
isForUpdateCompatibleWithDistinct() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
isForUpdateCompatibleWithDistinct() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
 
isForUpdateCompatibleWithDistinct() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Indicates whether SELECT DISTINCT ...
isForUpdateCompatibleWithDistinct() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
INTERNAL: Indicates whether SELECT DISTINCT ...
isForUpdateCompatibleWithDistinct() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Indicates whether SELECT DISTINCT ...
isForUpdateOfClause() - Method in class org.eclipse.persistence.internal.expressions.ForUpdateClause
 
isForUpdateOfClause() - Method in class org.eclipse.persistence.internal.expressions.ForUpdateOfClause
 
isFractionalTimeSupported() - Method in class org.eclipse.persistence.platform.database.MariaDBPlatform
 
isFractionalTimeSupported() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
 
isFragment() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: XMLType Function - evaluates to 0 if the xml is a well formed document and 1 if the document is a fragment
isFragment() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
 
isFragment() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
PUBLIC: Returns if this should marshal to a fragment.
isFragment() - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
IsFragment - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
isFragPrimaryKey(XPathFragment, DirectMapping) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Indicates if a given fragment is a primary key.
isFullFetchGroup(FetchGroup) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
PUBLIC: Indicates whether the passed fetch group contains all the attributes, no nesting.
isFullRowRequired - Variable in class org.eclipse.persistence.queries.DeleteObjectQuery
PERF: By default only the translation row is used for deletes, the full row can be requested for custom deletes.
isFullRowRequired() - Method in class org.eclipse.persistence.queries.DeleteObjectQuery
ADVANCED: Return if the full row is required by the delete query.
isFullyInitialized() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Check if the descriptor is finished initialization.
isFunctionExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isFunctionExpression() - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
isFunctionOperator() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
General functions are any normal function such as UPPER.
isGeneratedPrefix() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
isGlobalDefinition() - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
Indicates a global definition
isGlobalRuntime() - Method in class org.eclipse.persistence.platform.server.wls.WebLogic_12_Platform
 
isH2() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isH2() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isH2() - Method in class org.eclipse.persistence.platform.database.H2Platform
 
isHANA() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isHANA() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isHANA() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
isHistoricalSession() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return if this session is a historical session.
isHSQL() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isHSQL() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isHSQL() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
 
isIdentity - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
isIdentity() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Answer whether the receiver is an identity field.
isIgnoreOrder() - Method in class org.eclipse.persistence.platform.xml.XMLComparer
 
isIN() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
Return if using the IN fetch type.
isInAndOutSopObject() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Indicates whether the mapping is both in and out of SerializedObjectPolicy's sopObject.
isInBatchWritingMode(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Return the batch writing mode.
isInBroker - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Used to determine If a session is in a Broker or not
isInBroker() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Returns true if the session is in a session Broker.
isIncludeRoot() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
Determine if the root not should be marshalled.
isIncludeRoot() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
Determine if the @XMLRootElement should be marshalled when present.
isIncludeRoot() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Determine if the @XMLRootElement should be marshalled when present.
isIncludeRoot() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Determine if the @XMLRootElement should be marshalled when present.
isInCollection() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
isIndexableExpression(Expression, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Lookup the expression in the cache if it contains any indexes.
isIndexedFormat() - Method in class org.eclipse.persistence.eis.EISDescriptor
 
isIndexedRecordSupported - Variable in class org.eclipse.persistence.eis.EISPlatform
 
isIndexedRecordSupported() - Method in class org.eclipse.persistence.eis.EISPlatform
Return if this platform supports JCA IndexedRecord.
isInEarlyTransaction - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Used to isolate queries to a unit of work in an early transaction.
isInformix() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isInformix() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isInformix() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
 
isInformixOuterJoin() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Some database require outer joins to be given in the where clause, others require it in the from clause.
isInformixOuterJoin() - Method in class org.eclipse.persistence.platform.database.Informix11Platform
Overrides the default behavior to return false, indicating that ANSI OUTER JOIN syntax should be used, since all modern versions of Informix support it.
isInformixOuterJoin() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Some database require outer joins to be given in the where clause, others require it in the from clause.
isInitialized() - Method in class org.eclipse.persistence.internal.descriptors.InstanceVariableAttributeAccessor
Returns true if this attribute accessor has been initialized and now stores a reference to the class's attribute.
isInitialized() - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Returns true if this attribute accessor has been initialized and now stores a reference to the class's attribute.
isInitialized() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
isInitialized() - Method in class org.eclipse.persistence.mappings.AttributeAccessor
Returns true if this attribute accessor has been initialized and now stores a reference to the class's attribute.
isInitialized(int) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Check if descriptor is already initialized for the level of initialization.
isInMemoryOnly - Variable in class org.eclipse.persistence.queries.DeleteAllQuery
Defines if objects should be remove from the persistence context only (no database).
isInMemoryOnly() - Method in class org.eclipse.persistence.queries.DeleteAllQuery
INTERNAL: Return if objects should be remove from the persistence context only (no database).
isInnerJoinFetched() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Return if this relationship should always be INNER join fetched.
isInOnlySopObject() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Indicates whether the mapping is in SerializedObjectPolicy's sopObject and not out of it.
isInProfile - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Used to determine If a session is in a profile or not
isInProfile() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if a profiler is being used.
isInProfile() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if a profiler is being used.
isInRange(Object) - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartition
INTERNAL: Return if the value is in the partitions range.
isInsert() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
isInsertable - Variable in class org.eclipse.persistence.descriptors.CacheIndex
 
isInsertable - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
 
isInsertable - Variable in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
Flag to support insertable JPA setting
isInsertable() - Method in class org.eclipse.persistence.descriptors.CacheIndex
Return if the index field can be inserted.
isInsertable() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Used to specify whether the column should be included in SQL UPDATE statements.
isInsertable() - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL: Return true if this mapping is insertable.
isInsertModeReturnOnly() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
isInsertObjectQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this is an insert object query.
isInsertObjectQuery() - Method in class org.eclipse.persistence.queries.InsertObjectQuery
PUBLIC: Return if this is an insert object query.
isInSopObject - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
Irrelevant (and not set) unless descriptor has SerializedObjectPolicy (SOP).
isInSopObject() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Indicates whether the mapping is in SerializedObjectPolicy's sopObject.
isInstanceVariableAttributeAccessor() - Method in interface org.eclipse.persistence.core.mappings.CoreAttributeAccessor
 
isInstanceVariableAttributeAccessor() - Method in class org.eclipse.persistence.internal.descriptors.InstanceVariableAttributeAccessor
 
isInstanceVariableAttributeAccessor() - Method in class org.eclipse.persistence.mappings.AttributeAccessor
 
isInstantiated - Variable in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Indicates whether the object has been read from the database or not.
isInstantiated() - Method in interface org.eclipse.persistence.indirection.IndirectContainer
PUBLIC: Return whether the contents have been read from the database.
isInstantiated() - Method in class org.eclipse.persistence.indirection.IndirectList
PUBLIC: Return whether the contents have been read from the database.
isInstantiated() - Method in class org.eclipse.persistence.indirection.IndirectMap
PUBLIC: Return whether the contents have been read from the database.
isInstantiated() - Method in class org.eclipse.persistence.indirection.IndirectSet
Return whether the contents have been read from the database.
isInstantiated() - Method in class org.eclipse.persistence.indirection.ValueHolder
PUBLIC: Return a boolean indicating whether the wrapped object has been set or not.
isInstantiated() - Method in interface org.eclipse.persistence.indirection.ValueHolderInterface
PUBLIC: Return whether the contents have been read from the database.
isInstantiated() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Return a boolean indicating whether the object has been read from the database or not.
isIntegerType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if type is the int primitive type or the Integer wrapper class
isIntegralType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if the specified type represents an integral type or a wrapper class of an integral type.
isInterface() - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
isInterfaceChildDescriptor() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if the descriptor defines inheritance and is a child.
isInterfaceChildDescriptor() - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Check if it is a child descriptor.
isInterfaceInitialized(int) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Check if interface descriptor is already initialized for the level of initialization.
isInternalCommand() - Method in class org.eclipse.persistence.internal.sessions.coordination.RCMCommand
 
isInternalCommand() - Method in class org.eclipse.persistence.sessions.coordination.Command
INTERNAL: Determine whether this command is public or internal to EclipseLink.
isIntersolvSequeLinkDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether an Intersolv SeqeLink JDBC driver is being used.
isInTransaction - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Keep track if the accessor is within a transaction context
isInTransaction - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Used to resolve transaction treading for client-side nested transaction where server uses many worker threads.
isInTransaction() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return whether the accessor is in transaction.
isInTransaction() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return the transaction status of the receiver.
isInTransaction() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if the session is currently in the progress of a database transaction.
isInTransaction() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
 
isInTransaction() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Return whether the session currently has a database transaction in progress.
isInTransaction() - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Return if the session is currently in the progress of a database transaction.
isIntType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if type is the int primitive type or the Integer wrapper class
isInvalid - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Invalid change set shouldn't be merged into object in cache, rather the object should be invalidated
isInvalid() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if an error occurred during initialization which should abort any further initialization.
isInvalid() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Indicates whether the change set is invalid.
isInvalidated(CacheKey) - Method in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
INTERNAL: return true if this object is expire, false otherwise.
isInvalidated(CacheKey) - Method in class org.eclipse.persistence.descriptors.invalidation.NoExpiryCacheInvalidationPolicy
INTERNAL: This will return true if the object is set to be invalid, false otherwise.
isInvalidated(CacheKey, long) - Method in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
INTERNAL: return true if this object is expire, false otherwise.
isInvalidated(CacheKey, long) - Method in class org.eclipse.persistence.descriptors.invalidation.DailyCacheInvalidationPolicy
INTERNAL: Return true if this object has expire or is invalid
isInvalidated(CacheKey, long) - Method in class org.eclipse.persistence.descriptors.invalidation.NoExpiryCacheInvalidationPolicy
INTERNAL: This will return true if the object is set to be invalid, false otherwise.
isInvalidated(CacheKey, long) - Method in class org.eclipse.persistence.descriptors.invalidation.TimeToLiveCacheInvalidationPolicy
INTERNAL: Return true if this object is set as invalid or has expired.
isInvalidationRandomized - Variable in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
Allows the timeToLive to be randomized to avoid bottlenecks.
isInvalidationRandomized() - Method in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
PUBLIC: Allows the timeToLive to be randomized to avoid bottlenecks.
isIsolated - Variable in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Is this identity map within an IsolatedClientSession
isIsolated - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
Set to true if this CacheKey comes from an IsolatedClientSession, or DatabaseSessionImpl.
isIsolated() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Returns true if the descriptor represents an isolated class
isIsolated() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Returns true if the descriptor represents an isolated class
isIsolated() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Returns true if this CacheKey is from an IsolatedClientSession
isIsolatedClientSession() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if this session is an isolated client session.
isIsolatedClientSession() - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSession
PUBLIC: Return if this session is an isolated client session.
isIsolatedQuery(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSession
INTERNAL: Answers if this query is an isolated query and must be executed locally.
isJConnectDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether a Sybase JConnect JDBC driver is being used.
isJDBCConnectDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether a Borland JDBCConnect JDBC driver is being used.
isJDBCConnectRemoteDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether a Borland JDBCConnect JDBC driver is being used.
isJDBCExecuteCompliant() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Returns true if this platform complies with the expected behavior from a jdbc execute call.
isJDBCExecuteCompliant() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
Calling a stored procedure query on PostgreSQL with no output parameters always returns true from an execute call regardless if a result set is returned or not.
isJDBCODBCBridge() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether a Sun/Merant JDBC-ODBC bridge driver is being used.
isJDBCType() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
isJDBCType() - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
isJDBCType() - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
isJDBCType() - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
 
isJDBCType() - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
isJDBCType() - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
isJOIN() - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
Return if using the JOIN fetch type.
isJoinedStrategy - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
isJoinedStrategy() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Indicate whether a single table or joined inheritance strategy is being used.
isJoinFetched() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Return if this relationship should always be join fetched.
isJoiningSupported() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Return if this mapping support joining.
isJoiningSupported() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return if this mapping support joining.
isJoiningSupported() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return if this mapping support joining.
isJoiningSupported() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return if this mapping supports joining.
isJoiningSupported() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Return if this mapping support joining.
isJoiningSupported() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Return if this mapping support joining.
isJoiningSupported() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return if this mapping support joining.
isJPAId - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
 
isJPAId() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Flags that this mapping is part of a JPA id mapping.
isJPAIdNested(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Flags that either this mapping or nested mapping is a JPA id mapping.
isJPAQueriesProcessed() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: used to see if JPA Queries have been processed during initialization
isJPASession() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Return whether this session is an EclipseLink JPA session.
isJPASession() - Method in class org.eclipse.persistence.services.RuntimeServices
Return whether this session is an EclipseLink JPA session.
isJPQLCall() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
isJPQLCall() - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: Yes this is an JPQLCall
isJPQLCallQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this query uses an JPQL query mechanism .
isJPQLCallQueryMechanism() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Delete a collection of objects This should be overridden by subclasses.
isJPQLCallQueryMechanism() - Method in class org.eclipse.persistence.internal.queries.JPQLCallQueryMechanism
 
isJsonDisableNestedArrayName() - Method in class org.eclipse.persistence.internal.oxm.JsonTypeConfiguration
Getter for JSON property to enable/disable generation of "item" name in nested arrays in JSON.
isJsonType(Type) - Method in interface org.eclipse.persistence.internal.databaseaccess.DatabaseJsonPlatform
Check whether provided Type is JSON type.
isJsonTypeCompatibility() - Method in class org.eclipse.persistence.internal.oxm.JsonTypeConfiguration
Getter for jsonTypeCompatibility
isJTA11() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: Check whether JTA 1.1 API is available.
isJTA11() - Method in class org.eclipse.persistence.platform.server.wls.WebLogic_10_Platform
INTERNAL: Check whether JTA 1.1 API is available.
isJTA11() - Method in class org.eclipse.persistence.platform.server.wls.WebLogicPlatform
INTERNAL: Check whether JTA 1.1 API is available.
isJTAEnabled() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: isJTAEnabled(): Answer true if the DatabaseSession's external transaction controller class will be populated with my transaction controller class at runtime.
isJTAEnabled() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: isJTAEnabled(): Answer true if the DatabaseSession's external transaction controller class will be populated with my transaction controller class at runtime.
isKeepAllAsElement() - Method in interface org.eclipse.persistence.internal.oxm.mappings.UnmarshalKeepAsElementPolicy
 
isKeepAllAsElement() - Method in enum org.eclipse.persistence.oxm.mappings.UnmarshalKeepAsElementPolicy
 
isKeepNoneAsElement() - Method in interface org.eclipse.persistence.internal.oxm.mappings.UnmarshalKeepAsElementPolicy
 
isKeepNoneAsElement() - Method in enum org.eclipse.persistence.oxm.mappings.UnmarshalKeepAsElementPolicy
 
isKeepUnknownAsElement() - Method in interface org.eclipse.persistence.internal.oxm.mappings.UnmarshalKeepAsElementPolicy
 
isKeepUnknownAsElement() - Method in enum org.eclipse.persistence.oxm.mappings.UnmarshalKeepAsElementPolicy
 
isKeyAvailableFromElement() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
MapContainerPolicy is for mappings where the key is stored in actual element.
isKeyAvailableFromElement() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
CollectionTableMapContainerPolicy is for mappings where the key is stored in a table separately from the map element.
isKeyForSourceSpecified() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Checks if source and target keys are mentioned by the user or not.
isLast() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
Indicates whether the cursor is on the last row of the result set.
isLast() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Indicates whether the cursor is on the last row of the result set.
isLastEventStart - Variable in class org.eclipse.persistence.oxm.record.JsonRecord
 
isLazilyInitialized() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
If true, the descriptor may be lazily initialized.
isLazilyInitialized() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
If true, the descriptor may be lazily initialized.
isLazy - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
Specifies whether this mapping is lazy, this means not included in the default fetch group.
isLazy - Variable in class org.eclipse.persistence.sessions.server.ConnectionPolicy
Determines if the write/exclusive connection is acquired only when first requested (lazy, this is the default) or immediately when the client session is acquired.
isLazy() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
Return if this mapping is lazy.
isLazy() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Return if this mapping is lazy.
isLazy() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Return if a lazy connection should be used, a lazy connection only acquire a physical connection when a transaction is started and releases the connection when the transaction completes.
isListOrderBrokenInDb() - Method in class org.eclipse.persistence.indirection.IndirectList
 
isListOrderFieldSupported - Variable in class org.eclipse.persistence.mappings.CollectionMapping
Indicates whether the mapping supports listOrderField, if it doesn't attempt to set listOrderField throws exception.
isListOrderFieldSupported() - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: indicates whether the mapping supports listOrderField, if it doesn't attempt to set listOrderField throws exception.
isListOrderFieldUpdatable - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
indicates whether listOrderField value could be updated in the db.
isListOrderFieldUpdatable() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: indicates whether listOrderField value could be updated in the db.
isListPolicy() - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
 
isListPolicy() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
isListPolicy() - Method in class org.eclipse.persistence.internal.queries.ListContainerPolicy
 
isLiteralExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isLiteralExpression() - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
 
isLoadGroup() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
isLoadGroup() - Method in class org.eclipse.persistence.queries.AttributeGroup
 
isLoadGroup() - Method in class org.eclipse.persistence.queries.LoadGroup
 
isLob(DatabaseField) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
isLobCompatibleWithDistinct() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether SELECT DISTINCT lob FROM ...
isLobCompatibleWithDistinct() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Indicates whether SELECT DISTINCT lob FROM ...
isLOBLocatorNeeded() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Return if the locator is required for the LOB (BLOB and CLOB) writing.
isLocal - Variable in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
 
isLocal() - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: Indicates whether connection is local (subscriber) or external (publisher).
isLockableMapping() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return whether this mapping should be traversed when we are locking
isLockableMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return whether this mapping should be traversed when we are locking
isLockableMapping() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return whether this mapping should be traversed when we are locking
isLockableMapping() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return whether this mapping should be traversed when we are locking.
isLockedByMergeManager() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
INTERNAL: Used byt the refresh process to determine if this concurrency manager is locked by the merge process.
isLockQuery() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
PUBLIC: Answers if the query lock mode is known to be LOCK or LOCK_NOWAIT.
isLockQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Answers if the query lock mode is known to be LOCK or LOCK_NOWAIT.
isLockQuery(Session) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
ADVANCED: Answers if this query will issue any pessimistic locks.
isLockTimeoutException(DatabaseException) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return true is the given exception occurred as a result of a lock time out exception (WAIT clause).
isLockTimeoutException(DatabaseException) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Return true if the given exception occurred as a result of a lock time out exception (WAIT clause).
isLoggedIn - Variable in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL Indicate if this session is logged in.
isLoggedIn() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Return if the session was logged in.
isLoggingOff - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
PERF: Quick check if logging is OFF entirely.
isLoggingOff() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: PERF: Used for quick check if logging is OFF entirely.
isLogicalExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isLogicalExpression() - Method in class org.eclipse.persistence.internal.expressions.LogicalExpression
INTERNAL:
isLogicalOperator() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
Logical functions are functions such as and and or.
isLogPayload() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
isLogPayload() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
isLongType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if type is the long primitive type or the Long wrapper class
isManyToMany() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Indicates whether this expression corresponds to ManyToMany.
isManyToManyMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isManyToManyMapping() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
 
isManyToManyQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.ManyToManyQueryKey
INTERNAL: override the isManyToManyQueryKey() method in the superclass to return true.
isManyToManyQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
PUBLIC:: Related query key should implement this method to return true.
isManyToOneMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isManyToOneMapping() - Method in class org.eclipse.persistence.mappings.ManyToOneMapping
INTERNAL: Related mapping should implement this method to return true.
isMapEntryExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isMapEntryExpression() - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
INTERNAL:
isMapKeyAttribute() - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Return whether a map key this container policy represents is an attribute By default this method will return false since only subclasses actually represent maps.
isMapKeyAttribute() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return whether a map key this container policy represents is an attribute.
isMapKeyAttribute() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Return whether a map key this container policy represents is an attribute By default this method will return false since only subclasses actually represent maps.
isMapKeyMapping - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
Records if this mapping is being used as a MapKeyMapping.
isMapKeyMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
 
isMapKeyObject() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return if the map key this container policy represents is a OneToOne.
isMapKeyObject() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Return if the map key this container policy represents is a OneToOne.
isMapKeyObjectRelationship() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Return if the expression if for a map key mapping where the key is a OneToOne.
isMapKeyObjectRelationship() - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Return if this mapping has a mapped key that uses a OneToOne (object).
isMappedFormat() - Method in class org.eclipse.persistence.eis.EISDescriptor
 
isMappedKeyMapPolicy() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
isMappedKeyMapPolicy() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
 
isMappedRecordSupported - Variable in class org.eclipse.persistence.eis.EISPlatform
 
isMappedRecordSupported() - Method in class org.eclipse.persistence.eis.EISPlatform
Return if this platform supports JCA MappedRecord.
isMappingInJoinedExpressionList(DatabaseMapping, List) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Iterate through a list of expressions searching for the given attribute name.
isMappingNodeValue() - Method in class org.eclipse.persistence.internal.oxm.MappingNodeValue
 
isMappingNodeValue() - Method in class org.eclipse.persistence.internal.oxm.NodeValue
 
isMapPolicy() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
isMapPolicy() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL Yes this is a MapPolicy
isMapValueAttributeAccessor() - Method in class org.eclipse.persistence.mappings.AttributeAccessor
 
isMariaDB() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isMariaDB() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isMariaDB() - Method in class org.eclipse.persistence.platform.database.MariaDBPlatform
 
isMarshalEmptyCollections() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Name of the property to determine if empty collections should be marshalled as [] Ignored marshalling XML.
isMarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.CollectionGroupingElementNodeValue
 
isMarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.NodeValue
 
isMarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.TypeNodeValue
 
isMarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
isMarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
isMarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
 
isMarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
 
isMarshalOnlyNodeValue() - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL: Return whether we ignore this node value when marshalling its parent
isMaxDB() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isMaxDB() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isMaxDB() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
isMergePending() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if the unit of work is waiting to be merged or in the process of being merged.
isMetadataRemote - Variable in class org.eclipse.persistence.sessions.remote.DistributedSession
Define if meta-data is initialized locally, or serialized from the server.
isMetadataRemote() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
ADVANCED: Return if the descriptors and meta-data should be serialized from the server, or if they will be provided locally.
isMethodAttributeAccessor() - Method in interface org.eclipse.persistence.core.mappings.CoreAttributeAccessor
 
isMethodAttributeAccessor() - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
 
isMethodAttributeAccessor() - Method in class org.eclipse.persistence.mappings.AttributeAccessor
 
isMinimalFetchGroup(FetchGroup) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
PUBLIC: Indicates whether the passed fetch group is minimal.
isMixed() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexContent
 
isMixed() - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
isMixedContent() - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyCollectionMapping
 
isMixedContent() - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyObjectMapping
 
isMixedContent() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
isMixedContent() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
isMixedContent() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
isMixedContent() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
isMixedContentNodeValue() - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL: Return true if this is the node value representing mixed content.
isMixedContentNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
INTERNAL: Return true if this is the node value representing mixed content.
isMixedContentNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyObjectMappingNodeValue
 
isMixedContentNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
INTERNAL: Return true if this is the node value representing mixed content.
isMixedContentNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
INTERNAL: Return true if this is the node value representing mixed content.
isMixedContentNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
isMixedContentNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathMappingNodeValue
 
isModifyAllQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this is a modify all query.
isModifyAllQuery() - Method in class org.eclipse.persistence.queries.ModifyAllQuery
PUBLIC: Return true if this is a modify all query.
isModifyQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this is a modify query.
isModifyQuery() - Method in class org.eclipse.persistence.queries.ModifyQuery
PUBLIC: Return if this is a modify query.
isMultipleCursorOutputProcedure - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Allow for multiple cursored output parameter.
isMultipleCursorOutputProcedure() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Used for Oracle result sets through procedures.
isMultipleTableDescriptor() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if this descriptor has more than one table.
isMultitenantPrimaryKeyMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL
isMultitenantPrimaryKeyMapping() - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL
isMutable - Variable in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
PERF: Indicates if this mapping's attribute is a simple atomic value and cannot be modified, only replaced.
isMutable - Variable in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PERF: Indicates if this mapping's attribute is a simple value which cannot be modified only replaced.
isMutable() - Method in class org.eclipse.persistence.mappings.converters.ClassInstanceConverter
INTERNAL: If the converter converts the value to a non-atomic value, i.e.
isMutable() - Method in interface org.eclipse.persistence.mappings.converters.Converter
PUBLIC: If the converter converts the value to a mutable value, i.e.
isMutable() - Method in class org.eclipse.persistence.mappings.converters.ConverterClass
INTERNAL:
isMutable() - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: If the converter converts the value to a non-atomic value, i.e.
isMutable() - Method in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
INTERNAL: If the converter converts the value to a non-atomic value, i.e.
isMutable() - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
INTERNAL: If the converter converts the value to a non-atomic value, i.e.
isMutable() - Method in class org.eclipse.persistence.mappings.converters.UUIDConverter
UUID values and String are immutable.
isMutable() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
PUBLIC: Return true if the attribute for this mapping is a simple atomic value that cannot be modified, only replaced.
isMutable() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Return true if the attribute for this mapping is not a simple atomic value that cannot be modified, only replaced.
isMutable() - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLListConverter
 
isMutable() - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLRootConverter
 
isMySQL() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isMySQL() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isMySQL() - Method in class org.eclipse.persistence.platform.database.MariaDBPlatform
 
isMySQL() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
Answers whether platform is MySQL.
isNamespaceAware() - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
Determine if namespaces will be considered during marshal/unmarshal operations.
isNamespaceAware() - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
Determine if namespaces will be considered during marshal/unmarshal operations.
isNamespaceAware() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
isNamespaceAware() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
INTERNAL: Determine if namespaces will be considered during marshal/unmarshal operations.
isNamespaceAware() - Method in interface org.eclipse.persistence.internal.oxm.record.XMLRecord
 
isNamespaceAware() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
isNamespaceAware() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
isNamespaceAware() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL: Determine if namespaces will be considered during marshal/unmarshal operations.
isNamespaceAware() - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
isNamespaceDeclarationIncluded() - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyAttributeMapping
 
isNamespaceDeclarationIncluded() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
isNative - Variable in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isNative() - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isNative() - Method in class org.eclipse.persistence.sequencing.NativeSequence
 
isNative() - Method in class org.eclipse.persistence.sequencing.Sequence
 
isNativeConnectionRequired - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
Allow connection unwrapping to be configured.
isNativeConnectionRequired - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Allow connection unwrapping to be configured.
isNativeConnectionRequired - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Allow connection unwrapping to be configured.
isNativeConnectionRequired() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Return if the descriptor requires usage of a native (unwrapped) JDBC connection.
isNativeConnectionRequired() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Return if the call requires usage of a native (unwrapped) JDBC connection.
isNativeConnectionRequired() - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: Return if the descriptor requires usage of a native (unwrapped) JDBC connection.
isNativeConnectionRequiredForLobLocator() - Method in class org.eclipse.persistence.platform.database.Oracle10Platform
INTERNAL: Indicate whether app.
isNativeConnectionRequiredForLobLocator() - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
INTERNAL: Indicates whether app.
isNativeConnectionRequiredForLobLocator() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Used by derived platforms (Oracle8Platform and higher) to indicate whether app.
isNeedToCloseComplex() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
isNeedToOpenComplex() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
isNested() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Return if this manager is within a nested acquire.
isNestedAccessor() - Method in interface org.eclipse.persistence.descriptors.CMPPolicy.KeyElementAccessor
 
isNestedAccessor() - Method in class org.eclipse.persistence.descriptors.CMPPolicy.KeyIsElementAccessor
 
isNestedArray() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
INTERNAL:
isNestedArray() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
isNestedArray() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
isNestedArray() - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL:
isNestedTable - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCollection
 
isNestedTable() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLTable
(Optional) Indicates a non-associative (nested) table.
isNestedTable() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCollection
Indicates if the instance represents a Nested Table (as opposed to Varray).
isNestedTableMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isNestedTableMapping() - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL:
isNestedUnitOfWork - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PERF: Cache isNestedUnitOfWork check.
isNestedUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Return whether this session is a nested unit of work or not.
isNestedUnitOfWork() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Return if this session is a nested unit of work.
isNew - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
isNew() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
ADVANCED: Returns true if this ObjectChangeSet represents a new object.
isNew() - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCED: Returns true if this ObjectChangeSet represents a new object.
isNewerVersion(Object, Object) - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: Compares two values.
isNewerVersion(Object, Object) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Compares two values.
isNewerVersion(Object, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Compares the value and the value from the object (or cache).
isNewerVersion(Object, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: Compares the value with the value from the object (or cache).
isNewerVersion(Object, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Compares the value with the value from the object (or cache).
isNewerVersion(Object, Object, Object, AbstractSession) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: Returns true if the value stored with the domainObject is more recent than the value .
isNewerVersion(AbstractRecord, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Compares the value from the row and from the object (or cache).
isNewerVersion(AbstractRecord, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: Compares the value from the row and from the object (or cache).
isNewerVersion(AbstractRecord, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Compares the value from the row and from the object (or cache).
isNewerVersion(AbstractRecord, Object, Object, AbstractSession) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: Returns true if the value stored with the domainObject is more recent than the value in the row.
isNewlyWeavedValueHolder() - Method in class org.eclipse.persistence.indirection.ValueHolder
Used as part of the implementation of WeavedAttributeValueHolderInterface Used to determine if this ValueHolder was added instantiated as part of the constructor of a weaved class
isNewlyWeavedValueHolder() - Method in interface org.eclipse.persistence.indirection.WeavedAttributeValueHolderInterface
This method returns whether this valueholder has been newly instantiated by weaved code.
isNewlyWeavedValueHolder() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
This method is used as part of the implementation of WeavedAttributeValueHolderInterface.
isNewObjectInParent(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This method determines if the specified clone is new in the parent UnitOfWork
isNil() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
isNil() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
isNil() - Method in class org.eclipse.persistence.internal.oxm.Root
Checks if is nil.
isNil() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
isNillable() - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
isNodeEqual(Node, Node) - Method in class org.eclipse.persistence.platform.xml.XMLComparer
Compare two DOM nodes.
isNonCursorOutputProcedure() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Return true for procedures with any output (or in/out) parameters and no cursors
isNormalizingStringValues() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
 
isNormalizingStringValues() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
PUBLIC: Returns true if this mapping is normalizing string values on unmarshal before adding them to the collection.
isNormalizingStringValues() - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
PUBLIC: Returns true if this mapping is normalizing string values on unmarshal before setting them in the object.
isNotEqualNull(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
Check if the expression is an equal null expression, these must be handle in a special way in SQL.
isNothingReturned() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The return type is one of, NoReturn, ReturnOneRow or ReturnManyRows.
isNothingReturned() - Method in interface org.eclipse.persistence.queries.Call
The return type is one of, NoReturn, ReturnOneRow or ReturnManyRows.
isNothingReturned() - Method in class org.eclipse.persistence.queries.JPQLCall
The return type is one of, NoReturn, ReturnOneRow or ReturnManyRows.
isNotNullOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
isNull() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Compare to null.
isNull() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the ISNULL operator.
IsNull - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
isNullable - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
 
isNullable() - Method in class org.eclipse.persistence.internal.descriptors.QueryArgument
 
isNullable() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Used for generating DDL.
isNullAllowed - Variable in class org.eclipse.persistence.mappings.AggregateObjectMapping
If all the fields in the database row for the aggregate object are NULL, then, by default, the mapping will place a null in the appropriate source object (as opposed to an aggregate object filled with nulls).
isNullAllowed - Variable in class org.eclipse.persistence.tools.schemaframework.ObjectVarrayDefinition
 
isNullAllowed() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
PUBLIC: Return if all the fields in the database row for the aggregate object are NULL, then, by default, the mapping will place a null in the appropriate source object (as opposed to an aggregate object filled with nulls).
isNullAllowed() - Method in class org.eclipse.persistence.tools.schemaframework.ObjectVarrayDefinition
PUBLIC: Return if the varray collection is allowed NULL or not
isNullAllowedInSelectClause() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Override this if the platform cannot handle NULL in select clause.
isNullAllowedInSelectClause() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 does not allow NULL in select clause.
isNullCapableValue() - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL:
isNullCapableValue() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
isNullCapableValue() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
isNullCapableValue() - Method in class org.eclipse.persistence.internal.oxm.XMLDirectMappingNodeValue
 
isNullCapableValue() - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentMappingNodeValue
 
isNullIgnored - Variable in class org.eclipse.persistence.queries.QueryResultsCachePolicy
Allows the caching of null to be configured.
isNullIgnored() - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Return if null results should be cached or ignored.
isNullOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
isNullRecord(AbstractNullPolicy, Attributes, UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
isNullRepresentedByEmptyNode - Variable in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
This state flag determines how we unmarshal empty nodes.
isNullRepresentedByEmptyNode() - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
 
isNullRepresentedByXsiNil - Variable in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
This state flag determines how we unmarshal xsi:nil nodes.
isNullRepresentedByXsiNil() - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
 
isNullRepresentedByXsiNil(AbstractNullPolicy) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
isNullValueMarshalled() - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
PUBLIC: Returns true if this mapping's value should be marshalled, in the case that it is equal to the default null value.
isNumberNegativeOrZero(Object) - Static method in class org.eclipse.persistence.internal.helper.Helper
Returns true if the passed value is Number that is negative or equals to zero.
isNumericType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if the class is any numeric type.
isObjectBuildingQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return if this is an object building query.
isObjectBuildingQuery() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
PUBLIC: Return if this is an object building query.
isObjectChangeTrackingPolicy() - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
Used to track instances of the change policies without doing an instance of check
isObjectChangeTrackingPolicy() - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
Used to track instances of the change policies without doing an instance of check
isObjectChangeTrackingPolicy() - Method in class org.eclipse.persistence.descriptors.changetracking.ObjectChangeTrackingPolicy
Used to track instances of the change policies without doing an instance of check
isObjectComparison() - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Return if the represents an object comparison.
isObjectComparison(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
INTERNAL: Return if the represents an object comparison.
isObjectComparisonExpression - Variable in class org.eclipse.persistence.internal.expressions.RelationExpression
PERF: Cache if the expression is an object comparison expression.
isObjectDeleted(Object) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Return if the object has been deleted in this unit of work.
isObjectDeleted(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if the object has been deleted in this unit of work.
isObjectExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isObjectExpression() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
isObjectLevelModifyQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this is an object level modify query.
isObjectLevelModifyQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
PUBLIC: Return if this is an object level modify query.
isObjectLevelReadQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this is an object level read query.
isObjectLevelReadQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Return if this is an object level read query.
isObjectNew(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This method is used to determine if the clone is a new Object in the UnitOfWork
isObjectReferenceMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isObjectReferenceMapping() - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Related mapping should implement this method to return true.
isObjectReferenceMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
 
isObjectRegistered(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Return whether the clone object is already registered.
isObjectRegistered(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Return whether the clone object is already registered.
isObjectRelationalDatabaseField() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
PUBLIC: Return if this is an ObjectRelationalDatabaseField.
isObjectRelationalDatabaseField() - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDatabaseField
PUBLIC: Return if this is an ObjectRelationalDatabaseField.
isObjectRelationalDataTypeDescriptor() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return if the descriptor maps to an object-relational structured type.
isObjectRelationalDataTypeDescriptor() - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
PUBLIC: Return if this is an ObjectRelationalDataTypeDescriptor.
isObjectValidForFetchGroup(Object, FetchGroup) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Return if the cached object data is sufficiently valid against a fetch group
isODBC() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isODBC() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isOff() - Method in class org.eclipse.persistence.logging.AbstractSessionLog
INTERNAL: Check if the log level is set to off.
ISOLATE_CACHE_AFTER_TRANSACTION - Static variable in class org.eclipse.persistence.descriptors.CachePolicy
 
ISOLATE_CACHE_AFTER_TRANSACTION - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
ISOLATE_CACHE_ALWAYS - Static variable in class org.eclipse.persistence.descriptors.CachePolicy
 
ISOLATE_CACHE_ALWAYS - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
ISOLATE_FROM_CLIENT_SESSION - Static variable in class org.eclipse.persistence.descriptors.CachePolicy
 
ISOLATE_FROM_CLIENT_SESSION - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
ISOLATE_NEW_DATA_AFTER_TRANSACTION - Static variable in class org.eclipse.persistence.descriptors.CachePolicy
 
ISOLATE_NEW_DATA_AFTER_TRANSACTION - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
Isolated - org.eclipse.persistence.sessions.server.ConnectionPolicy.ExclusiveMode
 
Isolated - Static variable in class org.eclipse.persistence.config.ExclusiveConnectionMode
The value causes creation of ExclusiveIsolatedClientSession in isolated case and throws exception otherwise.
ISOLATED - org.eclipse.persistence.config.CacheIsolationType
The Entity and its data is not stored in the shared cache but is isolated to the Persistence Context/UnitOfWork or IsolatedClientSession.
ISOLATED_DATA_NOT_SUPPORTED_IN_CLIENTSESSIONBROKER - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ISOLATED_DESCRIPTOR_REFERENCED_BY_SHARED_DESCRIPTOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ISOLATED_QUERY_EXECUTED_ON_SERVER_SESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
IsolatedClientSession - Class in org.eclipse.persistence.internal.sessions
Provides isolation support by allowing a client session to have a local cache of the subset of the classes.
IsolatedClientSession(ServerSession, ConnectionPolicy) - Constructor for class org.eclipse.persistence.internal.sessions.IsolatedClientSession
 
IsolatedClientSession(ServerSession, ConnectionPolicy, Map) - Constructor for class org.eclipse.persistence.internal.sessions.IsolatedClientSession
 
IsolatedClientSessionIdentityMapAccessor - Class in org.eclipse.persistence.internal.sessions
INTERNAL: Internal subclass that provides access to identity maps through the session.
IsolatedClientSessionIdentityMapAccessor(AbstractSession) - Constructor for class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: An IdentityMapAccessor sits between the session and the identityMapManager It needs references in both directions
isolatedDataNotSupportedInSessionBroker(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
isolateDescriptorReferencedBySharedDescriptor(String, String, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
isolatedQueryExecutedOnServerSession() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
isolation() - Method in annotation type org.eclipse.persistence.annotations.Cache
(Optional) Controls the level of caching this Entity will use.
isOnClient - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
isOnClient() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
isOneRowReturned() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The return type is one of, NoReturn, ReturnOneRow or ReturnManyRows.
isOneRowReturned() - Method in interface org.eclipse.persistence.queries.Call
The return type is one of, NoReturn, ReturnOneRow or ReturnManyRows.
isOneRowReturned() - Method in class org.eclipse.persistence.queries.JPQLCall
The return type is one of, NoReturn, ReturnOneRow or ReturnManyRows.
isOneToMany() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Indicates whether this expression corresponds to OneToMany.
isOneToManyMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isOneToManyMapping() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL:
isOneToManyQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.OneToManyQueryKey
INTERNAL: override the isOneToManyQueryKey() method in the superclass to return true.
isOneToManyQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
PUBLIC:: Related query key should implement this method to return true.
isOneToOne() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Indicates whether this expression corresponds to OneToOne.
isOneToOneMapping() - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL:
isOneToOneMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isOneToOneMapping() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL:
isOneToOnePrimaryKeyRelationship - Variable in class org.eclipse.persistence.mappings.OneToOneMapping
Defines if this mapping was built using primary key join columns.
isOneToOnePrimaryKeyRelationship() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
Return if this mapping is mapped using primary key join columns.
isOneToOneQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.OneToOneQueryKey
INTERNAL: override the isOneToOneQueryKey() method in the superclass to return true.
isOneToOneQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
PUBLIC:: Related query key should implement this method to return true.
isOneToOneRelationship - Variable in class org.eclipse.persistence.mappings.OneToOneMapping
Define if this mapping is really for a OneToOne relationship.
isOneToOneRelationship() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
Return if this mapping is really for a OneToOne relationship.
isOptional - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
Specifies whether this mapping is optional (i.e.
isOptional() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
Return whether the value of this mapping is optional (that is, can be null).
isOracle() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isOracle() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isOracle() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
 
isOracle12() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isOracle12() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isOracle7JDBCDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether an Oracle native 7.x OCI JDBC driver is being used.
isOracle9() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isOracle9() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isOracleJDBCDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether an Oracle 8.x native OCI JDBC driver is being used.
isOracleServerJDBCDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether an Oracle thin JDBC driver is being used.
isOracleThinJDBCDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether an Oracle thin JDBC driver is being used.
isOrderableType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if the specified type denotes an orderable type
isOrderedListPolicy() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
isOrderedListPolicy() - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
 
isOrderOperator() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
Order functions are used in the order by such as ASC.
isOriginalNewObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return whether the original object is new.
isOuterJoinFetched() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Return if this relationship should always be OUTER join fetched.
isOutOnlySopObject() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Indicates whether the mapping is out of SerializedObjectPolicy's sopObject and not in it.
isOutputAllowWithResultSet() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Return true if output parameters can be built with result sets.
isOutputAllowWithResultSet() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Return true if output parameters can be built with result sets.
isOutputAllowWithResultSet() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Return true if output parameters can be built with result sets.
isOutputParameterType(DatasourceCall.ParameterType) - Static method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
isOutSopObject() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Indicates whether the mapping is out of SerializedObjectPolicy's sopObject.
isOverriddenEvent(DescriptorEvent, List<DescriptorEventManager>) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
isOverriddenEvent(DescriptorEvent, List<DescriptorEventManager>) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
Implementers should define this method if they need or want to restrict the calling of inherited events.
isOwned() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL:
isOwned() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
Returns true if this mapping is owned by the parent descriptor.
isOwned() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL:
isOwned() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL:
isOwned() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL:
isOwned() - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL:
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.CollectionGroupingElementNodeValue
 
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL:
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
 
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyObjectMappingNodeValue
 
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceObjectMappingNodeValue
 
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
 
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
Indicate if the next XPathFragment is an attribute or text() node.
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLDirectMappingNodeValue
 
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentMappingNodeValue
 
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectReferenceMappingNodeValue
Indicate if the XPathFragment is an attribute or text() node.
isOwningNode(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathMappingNodeValue
INTERNAL:
isParameterExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isParameterExpression() - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
 
isParsed - Variable in class org.eclipse.persistence.internal.queries.QueryByExampleMechanism
 
isParsed - Variable in class org.eclipse.persistence.queries.JPQLCall
 
isParsed() - Method in class org.eclipse.persistence.internal.queries.QueryByExampleMechanism
INTERNAL: Is this query Parsed
isParsed() - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL Is this query Parsed
isPartialAttribute(String) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return if partial attribute.
isPartialObject(Object) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Return true if the object is partially fetched and cached.
isPervasive() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isPervasive() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Answers whether platform is Pervasive
isPessimisticLocked(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if the clone has been pessimistic locked in this unit of work.
isPessimisticLockingValueHolder() - Method in class org.eclipse.persistence.internal.indirection.BackupValueHolder
 
isPessimisticLockingValueHolder() - Method in class org.eclipse.persistence.internal.indirection.CacheBasedValueHolder
 
isPessimisticLockingValueHolder() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Answers if this valueholder is a pessimistic locking one.
isPessimisticLockingValueHolder() - Method in class org.eclipse.persistence.internal.indirection.ProtectedValueHolder
 
isPessimisticLockingValueHolder() - Method in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
INTERNAL: Answers if this valueholder is a pessimistic locking one.
isPessimisticLockingValueHolder() - Method in class org.eclipse.persistence.internal.indirection.TransformerBasedValueHolder
INTERNAL: Answers if this valueholder is a pessimistic locking one.
isPessimisticLockingValueHolder() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
INTERNAL: Answers if this valueholder is a pessimistic locking one.
isPessimisticLockingValueHolder() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
INTERNAL: Answers if this valueholder is a pessimistic locking one.
isPgObjectInstance(Object) - Method in interface org.eclipse.persistence.platform.database.PostgreSQL10Platform.PostgreSQL10JsonExtension
Check whether provided instance is an instance of PGobject.
isPlatformWrapper(Object) - Static method in interface org.eclipse.persistence.internal.databaseaccess.PlatformWrapper
Check whether provided instance is marked as DatabasePlatform specific wrapper.
isPointBase() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isPointBase() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isPointBase() - Method in class org.eclipse.persistence.platform.database.PointBasePlatform
 
isPooled() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
INTERNAL: Return if part of a connection pool.
isPopulatingObject - Variable in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
Indicates that the whole object is being populated.
isPopulatingObject() - Method in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
 
isPossibleFailure() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
 
isPostgreSQL() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isPostgreSQL() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isPostgreSQL() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Answers whether platform is Postgres.
isPreDeleteComplete() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
isPrefix - Variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
isPrefix() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Return true if this is a prefix operator.
isPrefixPerTable() - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
PUBLIC: Return true if this descriptor requires a prefix to the table per tenant.
isPrepared - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
isPrepared - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Queries prepare common stated in themselves.
isPrepared() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Bound calls can have the SQL pre generated.
isPrepared() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Queries are prepared when they are executed and then do not need to be prepared on subsequent executions.
isPreparedUsingTempStorage - Variable in class org.eclipse.persistence.queries.ModifyAllQuery
Indicates whether the query was prepared so that it will execute using temp storage
isPreparedUsingTempStorage() - Method in class org.eclipse.persistence.queries.ModifyAllQuery
INTERNAL:
isPrePrepared - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Allow a prePrepare stage to build the expression for EJBQL and QBE and resolve joining.
isPrePrepared() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Queries prepare common stated in themselves.
isPrimaryKey - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
 
isPrimaryKey - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
isPrimaryKey() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Used to specify whether the column should be included in the primary on the database table.
isPrimaryKey() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Answer whether the receiver is a primary key.
isPrimaryKey(DatabaseField) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Returns whether or not this field is a primary key.
isPrimaryKeyComponentInvalid(Object, int) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
isPrimaryKeyExpression(boolean, Expression, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return if the expression is by primary key.
isPrimaryKeyMapping - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
PERF: Used as a quick check to see if this mapping is a primary key mapping, set by the object builder during initialization.
isPrimaryKeyMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Set by the Object builder during initialization returns true if this mapping is used as a primary key mapping.
isPrimaryKeyMapping(DatabaseMapping) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
isPrimaryKeyQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return if the query is known to be by primary key.
isPrimaryKeyQuery() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Return if the query is by primary key.
isPrimaryKeySetAfterInsert(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Indicates whether pk or some of its components set after insert into the database.
isPrimitiveWrapper(Class<?>) - Static method in class org.eclipse.persistence.internal.helper.Helper
ADVANCED returns true if the class in question is a primitive wrapper
isPrivateOwned - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Indicates whether the referenced object is privately owned or not.
isPrivateOwned() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Return if the mapping has ownership over its target object(s).
isPrivateOwned() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Return true if referenced objects are privately owned else false.
isProcessedCommit(Object) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Return if the object has been processed.
isProcessingCData - Variable in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
isProcessingCData - Variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
isProcessingCData - Variable in class org.eclipse.persistence.oxm.record.WriterRecord
 
isProjectClassConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.project.ProjectClassConfig
 
isProjectClassConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.project.ProjectConfig
 
isProjectXMLConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.project.ProjectConfig
 
isProjectXMLConfig() - Method in class org.eclipse.persistence.internal.sessions.factories.model.project.ProjectXMLConfig
 
isProperty - Variable in class org.eclipse.persistence.internal.expressions.ParameterExpression
 
isProperty() - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Return true if this parameter expression maps to a property.
isProtectedIsolation() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Returns true if the descriptor represents a protected class.
isProtectedIsolation() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Returns true if the descriptor represents an isolated class
isProtectedSession() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Returns true if Protected Entities should be built within this session
isProtectedSession() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Returns true if Protected Entities should be built within this session
isProtectedSession() - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSession
PUBLIC: Returns true if Protected Entities should be built within this session
isQueryByExampleMechanism() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Return true if this is a query by example mechanism
isQueryByExampleMechanism() - Method in class org.eclipse.persistence.internal.queries.QueryByExampleMechanism
Return true if this is a query by example mechanism
isQueryCacheForceDeferredLocks() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Get property to Force all queries and relationships to use deferred lock strategy during object building and L2 cache population.
isQueryKey() - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
INTERNAL: This is a QueryKey.
isQueryKeyExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isQueryKeyExpression() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
isQueryStringCall() - Method in class org.eclipse.persistence.eis.interactions.QueryStringInteraction
 
isQueryStringCall() - Method in class org.eclipse.persistence.eis.interactions.XQueryInteraction
 
isQueryStringCall() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
isQueryStringCall() - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
Should return true.
isQueryStringCall() - Method in class org.eclipse.persistence.queries.SQLCall
 
isReadAllQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this is a read all query.
isReadAllQuery() - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Return if this is a read all query.
isReadObjectQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this is a read object query.
isReadObjectQuery() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return if this is a read object query.
isReadOnly - Variable in class org.eclipse.persistence.mappings.AttributeAccessor
 
isReadOnly - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
Makes this mapping read only.
isReadOnly - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PERF: Allow queries to be defined as read-only in unit of work execution.
isReadOnly() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Returns true if mapping is read only else false.
isReadOnly() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Returns true is this database field should be read only.
isReadOnly() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
 
isReadOnly() - Method in class org.eclipse.persistence.mappings.AttributeAccessor
INTERNAL
isReadOnly() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Returns true if mapping is read only else false.
isReadOnly() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Return true if read-only is explicitly set to true; otherwise return whether the transformation has no fields (no fields = read-only)
isReadOnly() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Return if the query is read-only.
isReadQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this is a read query.
isReadQuery() - Method in class org.eclipse.persistence.queries.ReadQuery
PUBLIC: Return if this is a read query.
isRecord() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
isRecord() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
isReduceAnyArrays() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
Property to determine if size 1 any collections should be treated as collections.
isReduceAnyArrays() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Property to determine if size 1 any collections should be treated as collections Ignored marshalling XML.
isReferenceClassLocked - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PERF: Caches locking policy isReferenceClassLocked setting.
isReferenceClassLocked() - Method in class org.eclipse.persistence.internal.expressions.ForUpdateClause
 
isReferenceClassLocked() - Method in class org.eclipse.persistence.internal.expressions.ForUpdateOfClause
 
isReferenceClassLocked() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Cache the locking policy isReferenceClassLocked check.
isReferenceMapping() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Related mapping should implement this method to return true.
isReferenceMapping() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
 
isReferenceMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isReferenceMapping() - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL:
isRegistered - Variable in class org.eclipse.persistence.indirection.IndirectList
PERF: Quick check flag if has been registered in a unit of work.
isRegisteringResults() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Answers if we are executing through a UnitOfWork and registering results.
isRelationalDescriptor() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return if the descriptor maps to a relational table.
isRelationalDescriptor() - Method in class org.eclipse.persistence.descriptors.RelationalDescriptor
PUBLIC: Return if the descriptor maps to a relational table.
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL:
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL:
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: All relational mappings should implement this method to return true.
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.DirectToFieldMapping
INTERNAL:
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL:
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL:
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL:
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL:
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.structures.ArrayMapping
INTERNAL:
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.structures.ObjectArrayMapping
INTERNAL:
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL:
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.structures.StructureMapping
INTERNAL:
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.TransformationMapping
INTERNAL:
isRelationalMapping() - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL:
isRelationExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isRelationExpression() - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
INTERNAL:
isRelationshipMaintenanceRequired() - Method in class org.eclipse.persistence.indirection.IndirectList
 
isRelationshipMaintenanceRequired() - Method in class org.eclipse.persistence.indirection.IndirectSet
 
isRemotelyInitialized - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
It is needed only in remote initialization and mapping is in parent descriptor
isRemotelyInitialized() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
 
isRemoteSession() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if this session is remote.
isRemoteSession() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Return if this session is a remote session.
isRemoteSession() - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
INTERNAL: Return if this session is remote.
isRemoteSession() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if this session is a remote session.
isRemoteUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if this session is a unit of work.
isRemoteUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
Return if this session is a unit of work.
isRemoteUnitOfWork() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if this session is a remote unit of work.
isRepeating - Variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
isReportQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this is a report query.
isReportQuery() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Return if this is a report query.
isRequired() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Indicates if this XMLField represents a "required" XML element or attribute ([minOccurs="1"] for elements, [use="required"] for attributes).
isRequired() - Method in class org.eclipse.persistence.oxm.XMLField
Indicates if this XMLField represents a "required" XML element or attribute ([minOccurs="1"] for elements, [use="required"] for attributes).
isResultAlwaysXMLRoot() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
 
isResultAlwaysXMLRoot() - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
isResultAlwaysXMLRoot() - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
isResultAlwaysXMLRoot() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
isResultAlwaysXMLRoot() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
 
isResultAlwaysXMLRoot() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
isResultAlwaysXMLRoot() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
isResultSetAccessOptimizedQuery - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PERF: Allow queries to build while accessing the database result-set.
isResultSetAccessOptimizedQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
ADVANCED: Return if the query result set access should be optimized.
isResultSetAccessOptimizedQueryDefault - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
If neither query specifies isResultSetOptimizedQuery nor session specifies shouldOptimizeResultSetAccess then this value is used to indicate whether optimization should be attempted
isResultSetMappingQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this is a result set mapping query.
isResultSetMappingQuery() - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: Return true if this is a result set mapping query.
isResultSetOptimizedQuery - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PERF: Allow queries to build directly from the database result-set.
isResultSetOptimizedQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
ADVANCED: Return if the query should be optimized to build directly from the result set.
isResultSetScrollable - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
isResultSetScrollable() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
isReturnSet() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Return if the call's return type has been set.
isReturnTypeRequiredForReturningPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Indicates if a return type is required for the field set on the returning policy.
isReturnTypeRequiredForReturningPolicy() - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: Indicates if a return type is required for the field set on the returning policy.
isRolledBack_impl(Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return true if the transaction is in the rolled back state.
isRolledBack_impl(Object) - Method in class org.eclipse.persistence.transaction.JTA11TransactionController
INTERNAL: Check whether the transaction is rolled back.
isRolledBack_impl(Object) - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Return true if the transaction is rolled back.
isRootArray - Variable in class org.eclipse.persistence.oxm.record.JsonRecord
 
isRootParentDescriptor() - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL: Return whether or not is root parent descriptor
isRootParentDescriptor() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return whether or not is root parent descriptor
isRowCountOutputParameterRequired() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return if the platform does not maintain the row count on batch executes and requires an output parameter to maintain the row count.
isRowCountOutputParameterRequired() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Oracle does not return the row count from PLSQL anon blocks, so an output parameter is required for this.
isRuntimeServicesEnabled() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: isRuntimeServicesEnabled(): Answer true if the JMX/MBean providing runtime services for the receiver's DatabaseSession will be deployed at runtime.
isRuntimeServicesEnabled() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: isRuntimeServicesEnabled(): Answer true if the JMX/MBean providing runtime services for the receiver's DatabaseSession will be deployed at runtime.
isRuntimeServicesEnabledDefault() - Method in class org.eclipse.persistence.platform.server.glassfish.GlassfishPlatform
 
isRuntimeServicesEnabledDefault() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: isRuntimeServicesEnabledDefault(): Answer true if the JMX/MBean providing runtime services for the receiver's DatabaseSession will be deployed at runtime.
isRuntimeServicesEnabledDefault() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: isRuntimeServicesEnabledDefault(): Answer true if the JMX/MBean providing runtime services for the receiver's DatabaseSession will be deployed at runtime.
isRuntimeServicesEnabledDefault() - Method in class org.eclipse.persistence.platform.server.was.WebSphere_7_Platform
 
isRuntimeServicesEnabledDefault() - Method in class org.eclipse.persistence.platform.server.wls.WebLogic_10_Platform
 
isSchemaInstanceIncluded() - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyAttributeMapping
 
isSchemaInstanceIncluded() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
isSchemaPerMultitenantPolicy() - Method in interface org.eclipse.persistence.descriptors.MultitenantPolicy
 
isSchemaPerMultitenantPolicy() - Method in class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
isSchemaPerMultitenantPolicy() - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL:
isSchemaPerMultitenantPolicy() - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL:
isSchemaPerTable() - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
PUBLIC: Return true if this descriptor requires a table schema per tenant.
isSchemaType(QName) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
INTERNAL
isSchemaType(QName) - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL
isSchemaType(QName) - Method in class org.eclipse.persistence.oxm.XMLUnionField
INTERNAL
isScrollableCursorPolicy() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
isScrollableCursorPolicy() - Method in class org.eclipse.persistence.queries.ScrollableCursorPolicy
 
isSecureProcessingDisabled() - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
isSecureProcessingDisabled() - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
isSecureProcessingDisabled() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
isSecureProcessingDisabled() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
isSecureProcessingDisabled() - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
 
isSelfField() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
INTERNAL: Indicates if the xpath for this field is "."
isSelfField() - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL: Indicates if the xpath for this field is "."
isSelfFragment - Variable in class org.eclipse.persistence.internal.oxm.XPathFragment
 
isSelfFragment() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
INTERNAL: Indicates if the xpath is "."
isSelfRecord() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
isSelfRecord() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
Indicates if this UnmarshalRecord represents a 'self' record
isSelfRecord() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
isSequencedObject() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL:
isSequencedObject() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL:
isSequenceSupported - Variable in class org.eclipse.persistence.platform.database.DerbyPlatform
Allow sequence support to be disabled for Derby < 10.6.1.
isSequencingCallbackRequired() - Method in interface org.eclipse.persistence.internal.sequencing.SequencingHome
 
isSequencingCallbackRequired() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Indicates whether SequencingCallback is required.
isSequencingCallbackRequired() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Indicates whether SequencingCallback is required.
isSequencingCallbackRequired() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Indicates whether sequencing callback may be required.
isSerializedRemoteUnitOfWorkValueHolder() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Used to determine if this is a remote uow value holder that was serialized to the server.
isSerializedRemoteUnitOfWorkValueHolder() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
Used to determine if this is a remote uow value holder that was serialized to the server.
isServerSession() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if this session is a server session.
isServerSession() - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Return if this session is a server session.
isServerSession() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if this session is a server session.
isServerSessionBroker() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Return if this session is a server session broker.
isSessionBroker() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if this session is a session broker.
isSessionBroker() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Return if this session is a session broker.
isSessionBroker() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if this session is a session broker.
isSet - Variable in class org.eclipse.persistence.descriptors.changetracking.CollectionChangeEvent
INTERNAL: Set operation in IndirectList results in raising two events: removal of the old value and addition of the new one at the same index: oldValue = list.set(i, newValue); raiseRemoveEvent(i, oldValue, true); raiseAddEvent(i, newValue, true); This flag indicates whether the event was raised by set operation on the list.
isSet() - Method in class org.eclipse.persistence.descriptors.changetracking.CollectionChangeEvent
INTERNAL: Return whether the event was raised by set operation on the list.
isSet() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl.PropertyWrapper
Checks if is sets the.
isSet(boolean) - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl.PropertyWrapper
Checks if is set.
isSet(String) - Method in interface org.eclipse.persistence.dynamic.DynamicEntity
Discover if a property has a persistent value
isSet(String) - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
isSetDefaultValue() - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
isSetMethodName() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlIsSetNullPolicy
 
IsSetNullPolicy - Class in org.eclipse.persistence.oxm.mappings.nullpolicy
PUBLIC: Description: This null policy allows for various configurations of isSet behavior to be set.
Marshal:
The boolean value of the isSet() state of a node will determine whether a node will be written out for a null value.
IsSetNullPolicy() - Constructor for class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
Default Constructor Set the IsSetPerformedForAbsentNode to false to enable the other 2 flags isNullRepresentedByEmptyNode and isNullRepresentedByXsiNil
IsSetNullPolicy(String) - Constructor for class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
Specific Constructor to set the name for checking the isSet state of the mapping
IsSetNullPolicy(String, boolean, boolean, XMLNullRepresentationType) - Constructor for class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
Specific Constructor to set both the Marshal enum and the Unmarshal flags.
IsSetNullPolicyIsSetParametersAttributeAccessor() - Constructor for class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.IsSetNullPolicyIsSetParametersAttributeAccessor
 
IsSetNullPolicyIsSetParameterTypesAttributeAccessor() - Constructor for class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.IsSetNullPolicyIsSetParameterTypesAttributeAccessor
 
isSetParameters() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlIsSetNullPolicy
 
isSetPerformedForAbsentNode - Variable in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
This state flag determines how we unmarshal absent nodes.
isSetPerformedForAbsentNode() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNullPolicy
 
isShallowCommitted(Object) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Return if the object is shallow committed.
isSharedIsolation() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Returns true if the descriptor represents a shared class.
isSharedIsolation() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Returns true if the descriptor represents an isolated class
isShortType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if type is the short primitive type or the Short wrapper class
isSimple - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Cache if is a simple mapping, all direct.
isSimple() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Return if the descriptor has no complex mappings, all direct.
isSimple(Descriptor) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Determines if a given descriptor contains a direct mapping to "text()" indicating a simple mapping.
isSimpleXMLRoot(Root) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
isSingleKey(CMPPolicy.KeyElementAccessor[]) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
Check to see if there is a single key element.
isSingleSourceRelationKeySpecified() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Checks if a single source key was specified.
isSingleTableMultitenantPolicy() - Method in interface org.eclipse.persistence.descriptors.MultitenantPolicy
 
isSingleTableMultitenantPolicy() - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL:
isSingleTableMultitenantPolicy() - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL:
isSingleTargetRelationKeySpecified() - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Checks if a single target key was specified.
isSizeAllowed - Variable in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
isSizeAllowed() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Return if this type can support a size specification.
isSizeRequired - Variable in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
isSizeRequired() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Return if this type must have a size specification.
isSmartMerge() - Static method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return the status of smart merge
isSourceKeySpecified() - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Checks if source key is specified or not.
isSourceKeySpecified() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
Return whether the source key is specified.
isSQLAnywhere() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isSQLAnywhere() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isSQLAnywhere() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
isSQLCall() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
isSQLCall() - Method in class org.eclipse.persistence.queries.SQLCall
 
isSQLCallQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this query uses an SQL query mechanism .
isSQLServer() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isSQLServer() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isSQLServer() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
 
isSQLXML(Object) - Static method in class org.eclipse.persistence.internal.helper.JavaPlatform
INTERNAL: Indicates whether the passed object implements java.sql.SQLXML introduced in jdk 1.6
isStartElementOpen - Variable in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
 
isStartElementOpen - Variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
isStartElementOpen - Variable in class org.eclipse.persistence.oxm.record.WriterRecord
 
isStatementQueryMechanism() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Return true if this is a statement query mechanism
isStatementQueryMechanism() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return true if this is a statement query mechanism
isStatementQueryMechanism() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Return true if this is a statement query mechanism
isStatic - Variable in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isStatic() - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isStopped - Variable in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
isStopped() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
PUBLIC: Indicates whether the RCM has been stopped: either initialize hasn't been called or shutdown has been called.
isStoredFunctionCall() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
isStoredFunctionCall() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredFunctionCall
INTERNAL:
isStoredFunctionCall() - Method in class org.eclipse.persistence.queries.StoredFunctionCall
INTERNAL:
isStoredInCache() - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
PUBLIC: Return true if the lock value is stored in the cache.
isStoredInCache() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
PUBLIC: Return true if the lock value is stored in the cache.
isStoredInCache() - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: Return true if the lock value is stored in the cache.
isStoredInObject() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
PUBLIC: Return true if the lock value is stored in the object.
isStoredPLSQLFunctionCall() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
isStoredPLSQLFunctionCall() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredFunctionCall
 
isStoredPLSQLProcedureCall() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
isStoredPLSQLProcedureCall() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
isStoredProcedureCall() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
isStoredProcedureCall() - Method in class org.eclipse.persistence.queries.StoredProcedureCall
 
isStrictlyAssignableFrom(Object, Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
convenience method for java's isAssignableFrom that allows auto-boxing but follows more closely Java's Class.isAssignableFrom method results, and returns true if either arguments is null.
isStringType(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if the specified type represents java.lang.String.
isStruct() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
isStruct() - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
isStructureMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isStructureMapping() - Method in class org.eclipse.persistence.mappings.structures.StructureMapping
INTERNAL:
isStuckOnReleaseDeferredLock() - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
isStuckThreadAcquiringLockForReading() - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
isStuckThreadAcquiringLockForWriting() - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
isSubSelect() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
isSubSelectExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isSubSelectExpression() - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
INTERNAL:
issueModifyAllQueryList() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Will notify all the deferred ModifyAllQuery's (excluding UpdateAllQuery's) and deferred UpdateAllQuery's to execute.
issueSQLbeforeCompletion() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: For synchronized units of work, dump SQL to database
issueSQLbeforeCompletion() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: For synchronized units of work, dump SQL to database.
issueSQLbeforeCompletion(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: For synchronized units of work, dump SQL to database.
isSuffixPerTable() - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
PUBLIC: Return true if this descriptor requires a suffix to the table per tenant.
isSupersetOf(CoreAttributeGroup) - Method in class org.eclipse.persistence.internal.queries.EntityFetchGroup
Return true if this EntityFetchGroup is a super-set of the passed in EntityFetchGroup.
isSupersetOf(CoreAttributeGroup<ATTRIBUTE_ITEM, DESCRIPTOR>) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Return true if this AttributeGroup is a super-set of the passed in AttributeGroup.
isSupersetOf(AttributeGroup) - Method in class org.eclipse.persistence.queries.AttributeGroup
Return true if this AttributeGroup is a super-set of the passed in AttributeGroup.
isSupported - Variable in class org.eclipse.persistence.internal.sessions.factories.model.platform.ServerPlatformConfig
 
isSupported() - Method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Check whether this platform is supported platform.
isSupported() - Method in class org.eclipse.persistence.internal.sessions.factories.model.platform.ServerPlatformConfig
 
isSwaRef() - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
 
isSwaRef() - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
 
isSwaRef() - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
isSwaRef() - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
 
isSybase() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isSybase() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isSybase() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
isSybase() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
isSymfoware() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isSymfoware() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isSymfoware() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Identifies this database platform as Symfoware's.
isSynchronized - Variable in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isSynchronized - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Indicates whether the session is synchronized.
isSynchronized() - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isSynchronized() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return if this session is synchronized.
isSynchronizeOnMerge - Static variable in class org.eclipse.persistence.mappings.CollectionMapping
Flag to indicate if collection needs to be synchronized instead of cloning during merge.
isTable() - Method in class org.eclipse.persistence.sequencing.Sequence
 
isTable() - Method in class org.eclipse.persistence.sequencing.TableSequence
 
isTableExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isTableExpression() - Method in class org.eclipse.persistence.internal.expressions.TableExpression
 
isTablePerClassPolicy() - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL:
isTablePerClassPolicy() - Method in class org.eclipse.persistence.descriptors.TablePerClassPolicy
INTERNAL:
isTablePerMultitenantPolicy() - Method in interface org.eclipse.persistence.descriptors.MultitenantPolicy
 
isTablePerMultitenantPolicy() - Method in class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
isTablePerMultitenantPolicy() - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL:
isTablePerMultitenantPolicy() - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL:
isTableSequenceDefinition() - Method in class org.eclipse.persistence.tools.schemaframework.SequenceDefinition
INTERNAL:
isTableSequenceDefinition() - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
INTERNAL:
isTableSequenceDefinition() - Method in class org.eclipse.persistence.tools.schemaframework.UnaryTableSequenceDefinition
INTERNAL:
isTempClassLoader() - Method in class org.eclipse.persistence.internal.helper.JPAClassLoaderHolder
INTERNAL:
isThereATypeConflict(DatabaseField, DatabaseField) - Static method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
isThereConflictBetweenLoginAndType() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: Checks for a conflict between pool's type and pool's login
isThereConflictBetweenLoginAndType() - Method in class org.eclipse.persistence.sessions.server.ExternalConnectionPool
INTERNAL: Checks for a conflict between pool's type and pool's login
isThreadComplete - Variable in class org.eclipse.persistence.internal.helper.DeferredLockManager
 
isThreadComplete() - Method in class org.eclipse.persistence.internal.helper.DeferredLockManager
Return if the thread is complete
isTimesTen() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isTimesTen() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isTimesTen() - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
 
isTimesTen7() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
isTimesTen7() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
 
isTimesTen7() - Method in class org.eclipse.persistence.platform.database.TimesTen7Platform
 
isTimeZoneQualified() - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
isToManyJoin - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Used to determine if -m joining has been used.
isToManyJoin() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return if the query uses any -m joins, and thus return duplicate/multiple rows.
isTransactionalValueHolder() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Answers if this valueholder is referenced only by a UnitOfWork valueholder.
isTransformationMapping() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Related mapping should implement this method to return true.
isTransformationMapping() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
Related mapping should implement this method to return true.
isTransformationMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isTransformationMapping() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL:
isTransient - Variable in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isTransient() - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isTransitionedToDeferredLocks - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
records that deferred locks have been employed for the merge process
isTransitionedToDeferredLocks() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTERNAL: Will return if the merge process has transitioned the active merge locks to deferred locks for readlock deadlock avoidance.
isTranslated - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
Returns true if this field was translated.
isTranslated() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Return true if this database field is a translation.
isTranslatedCustomQuery - Variable in class org.eclipse.persistence.queries.SQLCall
 
isTraversable() - Method in interface org.eclipse.persistence.descriptors.WrapperPolicy
PUBLIC: Required: Return true if the wrapped value should be traversed.
isTreatExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
isTreatExpression() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
INTERNAL:
isTreatUsed() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL Return true if treat was used on this expression
isTypedTextField - Variable in class org.eclipse.persistence.oxm.XMLField
 
isTypedTextField() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Returns if the field is a typed text field True when we should base conversions on the "type" attribute on elements
isTypedTextField() - Method in class org.eclipse.persistence.oxm.XMLField
Returns if the field is a typed text field True when we should base conversions on the "type" attribute on elements
isTypeNameRequired - Variable in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
isTypeNameRequired() - Method in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
isUnaryTable() - Method in class org.eclipse.persistence.sequencing.Sequence
 
isUnaryTable() - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
isUnidirectionalOneToManyMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL:
isUnidirectionalOneToManyMapping() - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL:
isUnionField() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
INTERNAL: Returns false since this is a union field The subclass XMLUnionField returns true for this
isUnionField() - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL: Returns false since this is a union field The subclass XMLUnionField returns true for this
isUnionField() - Method in class org.eclipse.persistence.oxm.XMLUnionField
INTERNAL: returns true since this is a union field
isUnique - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
 
isUnique - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
isUnique - Variable in class org.eclipse.persistence.tools.schemaframework.IndexDefinition
 
isUnique() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Used for generating DDL.
isUnique() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Answer whether the receiver is a unique constraint field.
isUnique() - Method in class org.eclipse.persistence.tools.schemaframework.IndexDefinition
 
isUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if this session is a unit of work.
isUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Return if this session is a unit of work.
isUnitOfWork() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if this session is a unit of work.
isUniversal() - Method in class org.eclipse.persistence.history.AsOfClause
PUBLIC: Answers if this is a UniversalAsOfClause, one to be applied to the entire selection criteria.
isUnmarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.NodeValue
 
isUnmarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
isUnmarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
isUnmarshalNodeValue() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
 
isUnregisteredExistingObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if the object is a known unregistered existing object.
isUnregisteredNewObjectInParent(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if the object was existing but not registered in the parent of the nested unit of work.
isUpdatable - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
 
isUpdatable - Variable in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
Flag to support updatable JPA setting
isUpdatable() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Returns whether the column should be included in SQL INSERT statements.
isUpdatable() - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL: Return true if this mapping is updatable.
isUpdate() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
isUpdateable - Variable in class org.eclipse.persistence.descriptors.CacheIndex
 
isUpdateable() - Method in class org.eclipse.persistence.descriptors.CacheIndex
Return if the index field can be updated.
isUpdateAllQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this is an update all query.
isUpdateAllQuery() - Method in class org.eclipse.persistence.queries.UpdateAllQuery
INTERNAL: Return true if this is an update all query.
isUpdateObjectQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this is an update object query.
isUpdateObjectQuery() - Method in class org.eclipse.persistence.queries.UpdateObjectQuery
PUBLIC: Return if this is an update object query.
isUpperCaseString(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Returns true if the string given is an all upper case string
isUsedToSetPrimaryKey - Variable in class org.eclipse.persistence.descriptors.ReturningPolicy
indicates whether ReturningPolicy is used for generation of the PK.
isUsedToSetPrimaryKey() - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
PUBLIC:
isUserDefined - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Internal flag used to bypass user define queries when executing one for custom sql/query support.
isUserDefined() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return true if the query is a custom user defined query.
isUserDefinedConnection() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
INTERNAL: Return if part of a connection pool.
isUserDefinedSQLCall - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Internal flag used to bypass user define queries when executing one for custom sql/query support.
isUserDefinedSQLCall() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return true if the query is a custom user defined SQL call query.
isUsesBindingSet() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL Indicates whether usesBinding has been set.
isUseSemaphoreInObjectBuilder() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
isUseSemaphoreToLimitConcurrencyOnWriteLockManagerAcquireRequiredLocks() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
isUseXsdTypesWithPrefix() - Method in class org.eclipse.persistence.internal.oxm.JsonTypeConfiguration
Getter for useXsdTypesWithPrefix property.
isUsingDefaultConstructor() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
If no method name is specified, they we have to use the default (zero-argument) constructor.
isUsingMethodAccess() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: Return if method access is used.
isUsingOuterJoinForMultitableInheritance() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL: indicates whether additional expressions for multitable inheritance should be used and are available
isValid - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
This attribute is used to determine if the connection should be returned to the pool or removed from the pool and closed.
isValid() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Returns true if this Accessor can continue to be used.
isValid() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Returns true if this Accessor can continue to be used.
isValid(Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Return if this object is valid in the cache.
isValid(Object) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Returns true if an Object with the same primary key and Class type of the the given Object is valid in the cache.
isValid(Object, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Return if this object is valid in the cache.
isValid(Object, Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Returns true if the Object described by the given primary key and Class type is valid in the cache.
isValid(DataRecord, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Return if this object is valid in the cache.
isValid(DataRecord, Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Returns true if this Object with the given primary key of the Row and Class type given is valid in the cache.
isValid(Document, ErrorHandler) - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
 
isValidated - Variable in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Marks this AttributeGroup as having been validated by the builder and does not require further validation
isValidated() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL:
isValidContainer(Object) - Method in class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
INTERNAL: Validate the container type.
isValidContainer(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return whether the specified object is of a valid container type.
isValidContainer(Object) - Method in class org.eclipse.persistence.internal.queries.ListContainerPolicy
INTERNAL: Validate the container type.
isValidContainer(Object) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Validate the container type.
isValidContainerType(Class<?>) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return whether the specified type is a valid container type.
isValidContainerType(Class<?>) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Validate the container type.
isValidType(Class<?>) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Verify that a class type is valid to use for the proxy.
isValueExpression() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Subclasses implement (isParameterExpression() || isConstantExpression())
isValueExpression() - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL:
isValueExpression() - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL:
isValueReadQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return if this is a value read query.
isValueReadQuery() - Method in class org.eclipse.persistence.queries.ValueReadQuery
PUBLIC: Return if this is a value read query.
isValuesAccessor() - Method in class org.eclipse.persistence.internal.dynamic.ValuesAccessor
 
isValuesAccessor() - Method in class org.eclipse.persistence.mappings.AttributeAccessor
 
isVariableOneToOneMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Related mapping should implement this method to return true.
isVariableOneToOneMapping() - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL:
isVirtualAttributeAccessor() - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeAccessor
 
isVirtualAttributeAccessor() - Method in class org.eclipse.persistence.mappings.AttributeAccessor
 
isVolatile - Variable in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isVolatile() - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
isVowel(char) - Static method in class org.eclipse.persistence.internal.helper.Helper
Returns true if the character given is a vowel.
isWeavedObjectBasicIndirectionPolicy() - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL:
isWeavedObjectBasicIndirectionPolicy() - Method in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
 
isWebLogicOracleOCIDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether a WebLogic Oracle OCI JDBC driver is being used.
isWebLogicSQLServerDBLibDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether a WebLogic SQL Server dblib JDBC driver is being used.
isWebLogicSQLServerDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether a WebLogic SQL Server JDBC driver is being used.
isWebLogicSybaseDBLibDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether a WebLogic Sybase dblib JDBC driver is being used.
isWebLogicThinClientDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether a WebLogic thin client JDBC driver is being used.
isWebLogicThinDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return whether a WebLogic thin JDBC driver is being used.
isWhitespaceAware() - Method in class org.eclipse.persistence.internal.oxm.NodeValue
 
isWhitespaceAware() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
isWhitespaceAware() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyObjectMappingNodeValue
 
isWhitespaceAware() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceObjectMappingNodeValue
 
isWhitespaceAware() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
isWhitespaceAware() - Method in class org.eclipse.persistence.internal.oxm.XMLDirectMappingNodeValue
 
isWhitespaceAware() - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
isWhitespaceNode(Text) - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
Check to see if the text node represents a whitespace node.
isWhitespacePreservedForMixedContent() - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyCollectionMapping
 
isWhitespacePreservedForMixedContent() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
Setting this to true indicates that text nodes containing *only* whitespaces should still be added to the collection as strings for mixed content.
isWithinFlush - Variable in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
Track whether we are already in a flush().
isWithinFlush() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
Return whether we are already performing a flush() call
isWrapped(Object) - Method in interface org.eclipse.persistence.descriptors.WrapperPolicy
PUBLIC: Required: Return true if the object is already wrapped.
isWrapper - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
Stores if this CacheKey instance is a wrapper for the underlying CacheKey.
isWrapper() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Returns true if this Instance of CacheKey is a wrapper and should be unwrapped before passing to IdentityMap APIs.
isWrapper() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
 
isWrapper() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
isWrapperAllowedAsCollectionName() - Method in interface org.eclipse.persistence.internal.oxm.ContainerValue
For media types that provide a native representation of collections (such as JSON arrays), can the representation be simplified so that the grouping element can be used as the collection name.
isWrapperAllowedAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
 
isWrapperAllowedAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
isWrapperAllowedAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
isWrapperAllowedAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
isWrapperAllowedAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
isWrapperAllowedAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
 
isWrapperAllowedAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
 
isWrapperAllowedAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
isWrapperAllowedAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
isWrapperAllowedAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
 
isWrapperAllowedAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
isWrapperAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.Marshaller
 
isWrapperAsCollectionName() - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
isWrapperAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
 
isWrapperAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
isWrapperAsCollectionName() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
isWrapperAsCollectionName() - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
isWrapperAsCollectionName() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
isWrapperAsCollectionName() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
isWrapperClass(Object) - Method in class org.eclipse.persistence.internal.helper.BasicTypeHelperImpl
Returns true if the specified type is a wrapper class.
isWrapperNodeValue() - Method in class org.eclipse.persistence.internal.oxm.CollectionGroupingElementNodeValue
 
isWrapperNodeValue() - Method in class org.eclipse.persistence.internal.oxm.NodeValue
 
isWriteObjectQuery() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return true if this is a write object query.
isWriteObjectQuery() - Method in class org.eclipse.persistence.queries.WriteObjectQuery
PUBLIC: Return if this is a write object query.
isWriteOnly - Variable in class org.eclipse.persistence.mappings.AttributeAccessor
 
isWriteOnly() - Method in interface org.eclipse.persistence.core.mappings.CoreAttributeAccessor
INTERNAL:
isWriteOnly() - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Some mappings support no attribute (transformation and multitenant primary key).
isWriteOnly() - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
 
isWriteOnly() - Method in interface org.eclipse.persistence.internal.oxm.mappings.ObjectReferenceMapping
 
isWriteOnly() - Method in class org.eclipse.persistence.mappings.AttributeAccessor
INTERNAL:
isWriteOnly() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Some mappings support no attribute (transformation and multitenant primary key).
isWriteOnly() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Return if the transformation has no attribute, is write only.
isWriteOnly() - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL This mapping must be write only as their is no attribute to read into.
isWriteOnly() - Method in class org.eclipse.persistence.oxm.mappings.XMLAbstractAnyMapping
 
isWriteOnly() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
isWriteOnly() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
isWriteOnly() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
isWriteOnly() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
isWriteOnly() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
isWriteOnly() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
isWriteOnly() - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
 
isWriteOnly() - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
 
isWriteOnly() - Method in interface org.eclipse.persistence.oxm.mappings.XMLMapping
 
isWriteOnly() - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
 
isXDBDocument(Object) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether the passed object is an instance of XDBDocument.
isXmlDescriptor() - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
Indicates if the object builder's descriptor is an XMLDescriptor.
isXMLDescriptor() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return if the descriptor maps to XML.
isXMLDescriptor() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: Return if the descriptor maps to XML.
isXMLFormat() - Method in class org.eclipse.persistence.eis.EISDescriptor
 
isXMLMapping() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: All relational mappings should implement this method to return true.
isXMLMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
isXMLMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
isXMLMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
isXMLMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
isXMLMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
isXMLMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
INTERNAL:
isXMLMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
INTERNAL:
isXMLMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
INTERNAL:
isXMLMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
INTERNAL:
isXMLMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
INTERNAL:
isXMLMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
isXMLMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
INTERNAL: Indicates that this is an XML mapping.
isXMLMapping() - Method in class org.eclipse.persistence.oxm.mappings.XMLTransformationMapping
INTERNAL:
isXMLObjectBuilder() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
isXMLObjectBuilder() - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
isXOPPackage() - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
isXOPPackage() - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
isXOPPackage() - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
isXOPPackage() - Method in interface org.eclipse.persistence.oxm.attachment.XMLAttachmentMarshaller
 
isXOPPackage() - Method in interface org.eclipse.persistence.oxm.attachment.XMLAttachmentUnmarshaller
 
isXOPPackage() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
isXOPPackage() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
isXsiTypeIndicatorField() - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
isXsiTypeIndicatorField() - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
isXsiTypeIndicatorField() - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
isZeroValidPrimaryKey - Static variable in class org.eclipse.persistence.internal.helper.Helper
Deprecated.
Instead of setting the flag to true use: session.getProject().setDefaultIdValidation(IdValidation.NULL)
item - Variable in class org.eclipse.persistence.internal.expressions.FromAliasExpression
 
item(int) - Method in class org.eclipse.persistence.platform.xml.XMLNodeList
 
itemNames_ - Static variable in class org.eclipse.persistence.services.ClassSummaryDetailBase
 
items - Variable in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Specified attributes in the group mapped to their AttributeItems
items - Variable in class org.eclipse.persistence.queries.ReportQuery
Items to be selected, these could be attributes or aggregate functions.
iterate(Object) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
To define a new iterator create a subclass and define at least this method.
iterate(Object) - Method in class org.eclipse.persistence.internal.sessions.remote.ReplaceValueHoldersIterator
if we get here, it is a domain object
iterate(Expression) - Method in class org.eclipse.persistence.internal.expressions.ExpressionIterator
INTERNAL: This method must be defined by subclasses to implement the logic of the iteratation.
iterate(DescriptorIterator) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Perform the iteration operation on the objects attributes through the mappings.
iterate(DescriptorIterator) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Iterate on the appropriate attribute value.
iterate(DescriptorIterator) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Iterate on the appropriate attribute value.
iterate(DescriptorIterator) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Iterate on the iterator's current object's attribute defined by this mapping.
iterate(DescriptorIterator) - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL: Iterate on the appropriate attribute.
iterate(DescriptorIterator) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Iterate on the appropriate attribute value.
iterate(DescriptorIterator) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Perform the iteration opperation on the iterators current objects attributes.
iterate(DescriptorIterator) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL: Iterate on the appropriate attribute value.
iterate(DescriptorIterator) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL: Iterate on the appropriate attribute value.
iterate(DescriptorIterator) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
INTERNAL: Iterate on the appropriate attribute value.
iterate(DescriptorIterator) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL: Iterate on the appropriate attribute value.
iterate(DescriptorIterator) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
INTERNAL: Iterate on the appropriate attribute value.
iterate(DescriptorIterator) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
iterateForAggregateMapping(Object, DatabaseMapping, ClassDescriptor) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Iterate on the mapping's reference object and recursively iterate on the reference object's reference objects.
iterateIndirectContainerForMapping(IndirectContainer, DatabaseMapping) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Iterate on the indirection object for its mapping.
iterateOn(Vector) - Method in class org.eclipse.persistence.internal.expressions.ExpressionIterator
INTERNAL:
iterateOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.ExpressionIterator
INTERNAL: Return the call.
iterateOn(ExpressionIterator) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: For iterating using an inner class
iterateOn(ExpressionIterator) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: For iterating using an inner class
iterateOn(ExpressionIterator) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL: For iterating using an inner class
iterateOn(ExpressionIterator) - Method in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
INTERNAL: Also iterate over the sub-select if present.
iterateOn(ExpressionIterator) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: For iterating using an inner class
iterateOn(ExpressionIterator) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
INTERNAL: For iterating using an inner class
iterateOnAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Iterate over the specified attribute value,
iterateOnAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Iterate over the specified attribute value,
iterateOnAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Iterate over the specified attribute value, heeding the settings in the iterator.
iterateOnAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Iterate over the specified attribute value.
iterateOnAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Iterate over the specified attribute value.
iterateOnAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.AggregateMapping
Iterate on the specified attribute value.
iterateOnAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
Iterate on the specified attribute value.
iterateOnElement(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Iterate on the specified element.
iterateOnElement(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Iterate on the specified element.
iterateOnElement(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Iterate on the specified element.
iterateOnElement(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Iterate on the specified element.
iterateOnMapKey(DescriptorIterator, Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Used in Descriptor Iteration to iterate on map keys.
iterateOnMapKey(DescriptorIterator, Object) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Used in Descriptor Iteration to iterate on map keys.
iterateOnMapKey(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Called when iterating through descriptors to handle iteration on this mapping when it is used as a MapKey
iterateOnMapKey(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Called when iterating through descriptors to handle iteration on this mapping when it is used as a MapKey.
iterateOnMapKey(DescriptorIterator, Object) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Called when iterating through descriptors to handle iteration on this mapping when it is used as a MapKey
iterateOnMapKey(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Called when iterating through descriptors to handle iteration on this mapping when it is used as a MapKey
iterateOnRealAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Iterate on the attribute value.
iterateOnRealAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Iterate on the attribute value.
iterateOnRealAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Iterate on the attribute value.
iterateOnRealAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Iterate on the attribute value.
iterateOnRealAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Iterate on the attribute value.
iterateOnRealAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Iterate on the attribute value.
iterateOnRealAttributeValue(DescriptorIterator, Object) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Iterate on the attribute value.
iteratePrimitiveForMapping(Object, DatabaseMapping) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Iterate on the primitive value for its mapping.
iterateReferenceObjectForMapping(Object, DatabaseMapping) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Iterate on the mapping's reference object and recursively iterate on the reference object's reference objects.
iterateReferenceObjects(Object) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Iterate over the sourceObject's reference objects, updating the visited stack appropriately.
iterateValueHolderForMapping(ValueHolderInterface, DatabaseMapping) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Iterate on the value holder for its mapping.
iterator() - Method in class org.eclipse.persistence.indirection.IndirectList
 
iterator() - Method in class org.eclipse.persistence.indirection.IndirectSet
 
iterator() - Method in class org.eclipse.persistence.internal.helper.IdentityHashSet
Get an iterator for this IdentityHashSet
iterator() - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
iterator() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
iterator() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
iterator() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
 
iterator() - Method in class org.eclipse.persistence.internal.mappings.converters.AttributeNameTokenizer
INTERNAL: Returns an Iterator<String> over attribute name tokens.
iterator() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.EntrySet
 
iterator() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.KeySet
 
iterator() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.ValuesSet
 
iterator() - Method in class org.eclipse.persistence.queries.ReportQueryResult.EntrySet
 
iterator() - Method in class org.eclipse.persistence.queries.ReportQueryResult.KeySet
 
iteratorFor(Object) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Return an iterator for the given container.
iteratorFor(Object) - Method in class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
INTERNAL: Return an iterator for the given container.
iteratorFor(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return an iterator for the given container.
iteratorFor(Object) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return an Iterator for the given container.
iteratorFor(Object) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Return an list iterator for the given container.
iteratorFor(Object) - Method in class org.eclipse.persistence.queries.CursorPolicy
INTERNAL: Return an iterator for the given container.

J

JAR_FILES_IN_PERSISTENCE_XML_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
jarFilesInPersistenceXmlNotSupported() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
JAVA_CLASS_INVOKING_ERROR - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
JAVA_CLASS_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
JAVA_LANG_PACKAGE_NAME - Static variable in class org.eclipse.persistence.internal.codegen.CodeDefinition
 
JAVA_OBJECT_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
JAVA_TYPE_IS_NOT_A_VALID_DATABASE_TYPE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
JAVA_UTIL_PACKAGE_NAME - Static variable in class org.eclipse.persistence.internal.codegen.CodeDefinition
 
javaClass - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
javaClassName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
javaClassNotSpecified(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
JavaDB - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
JavaDBPlatform - Class in org.eclipse.persistence.platform.database
Purpose: Allows to use JavaDBPlatform as a synonym for DerbyPlatform
JavaDBPlatform() - Constructor for class org.eclipse.persistence.platform.database.JavaDBPlatform
Default constructor.
JavaLog - Class in org.eclipse.persistence.logging
PUBLIC:
JavaLog() - Constructor for class org.eclipse.persistence.logging.JavaLog
INTERNAL:
JavaLogConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.log
INTERNAL:
JavaLogConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.log.JavaLogConfig
 
JavaLogger - Static variable in class org.eclipse.persistence.config.LoggerType
 
JavaPlatform - Class in org.eclipse.persistence.internal.helper
INTERNAL: JavaPlatform abstracts the version of the JDK we are using.
JavaPlatform() - Constructor for class org.eclipse.persistence.internal.helper.JavaPlatform
 
JAVASE_DB_INTERACTION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The system property "INTERACT_WITH_DB" specifies to enable or disable the execution of DDL (configured with the "eclipselink.ddl-generation" property) against a database.
JavaSEPlatform - Enum in org.eclipse.persistence.internal.helper
Java SE platforms supported by EclipseLink.
JavaSEPlatform.Version - Class in org.eclipse.persistence.internal.helper
 
JavaSerializer - Class in org.eclipse.persistence.sessions.serializers
Plain old Java serialization.
JavaSerializer() - Constructor for class org.eclipse.persistence.sessions.serializers.JavaSerializer
 
JavaSqlDate_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
Deprecated.
JavaSqlTime_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
Deprecated.
JavaSqlTimestamp_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
Deprecated.
javaStrings - Variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
javaType - Variable in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
Defines the Java class that the complex type maps to.
javaType - Variable in class org.eclipse.persistence.internal.oxm.XMLConversionPair
 
javaType() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.OracleArray
(Optional) The Java Collection class to map the VARRAY to.
javaType() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.OracleObject
(Optional) The Java class to map the OBJECT type to.
javaType() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLRecord
(Optional) The Java class to map the object-type to.
javaType() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLTable
(Optional) The Java Collection class to map the varray to.
javaType(QName) - Method in interface org.eclipse.persistence.internal.oxm.ConversionManager
 
javaType(QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
JAVATYPE_NOT_ALLOWED_IN_BINDINGS_FILE - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
javaTypeIsNotAValidDatabaseType(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
javaTypeName - Variable in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
javaTypeNotAllowedInBindingsFile(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception should be used when a TypeMappingInfo is specified but the Type is not set on it.
JavaVersion - Class in org.eclipse.persistence.internal.helper
Java version storage class.
JavaVersion(int, int) - Constructor for class org.eclipse.persistence.internal.helper.JavaVersion
Constructs an instance of Java specification version number.
JAXB_FRAGMENT - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
JAXB_MARSHALLER - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
JAXBException - Exception in org.eclipse.persistence.exceptions
Purpose: This class provides an implementation of EclipseLinkException specific to the EclipseLink JAXB implementation
JAXBException(String) - Constructor for exception org.eclipse.persistence.exceptions.JAXBException
 
JAXBException(String, Exception) - Constructor for exception org.eclipse.persistence.exceptions.JAXBException
 
JAXBExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: Purpose:
JAXBExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.JAXBExceptionResource
Default constructor.
JAXBLocalization - Class in org.eclipse.persistence.internal.localization
 
JAXBLocalization() - Constructor for class org.eclipse.persistence.internal.localization.JAXBLocalization
 
JAXP_PLATFORM_CLASS_NAME - Static variable in class org.eclipse.persistence.platform.xml.XMLPlatformFactory
 
JBoss - Static variable in class org.eclipse.persistence.config.TargetServer
 
JBossPlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
JBossPlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.JBossPlatformConfig
 
JBossRuntimeServices - Class in org.eclipse.persistence.services.jboss
Purpose: Provide a dynamic interface into the EclipseLink Session.
JBossRuntimeServices() - Constructor for class org.eclipse.persistence.services.jboss.JBossRuntimeServices
PUBLIC: Default Constructor
JBossRuntimeServices(Locale) - Constructor for class org.eclipse.persistence.services.jboss.JBossRuntimeServices
Create an instance of JBossRuntimeServices to be associated with the provided locale The user must call setSession(Session) afterwards to define the session.
JBossRuntimeServices(AbstractSession) - Constructor for class org.eclipse.persistence.services.jboss.JBossRuntimeServices
PUBLIC: Create an instance of JBossRuntimeServices to be associated with the provided session
JBossTransactionController - Class in org.eclipse.persistence.transaction.jboss
Purpose: TransactionController implementation for JBoss JTA
JBossTransactionController() - Constructor for class org.eclipse.persistence.transaction.jboss.JBossTransactionController
Default constructor
JBossTransactionController11 - Class in org.eclipse.persistence.transaction.jboss
Purpose: TransactionController implementation for JBoss JTA
JBossTransactionController11() - Constructor for class org.eclipse.persistence.transaction.jboss.JBossTransactionController11
Default constructor
JCEEncryptor - Class in org.eclipse.persistence.internal.security
EclipseLink reference implementation for password encryption.
JCEEncryptor() - Constructor for class org.eclipse.persistence.internal.security.JCEEncryptor
 
JDBC - Static variable in class org.eclipse.persistence.config.BatchWriting
 
JDBC_ALLOW_PARTIAL_PARAMETERS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property "eclipselink.jdbc.allow-partial-bind-parameters" configures whether partial parameter binding should be allowed in the creation of JDBC prepared statements.
JDBC_BIND_PARAMETERS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property "eclipselink.jdbc.bind-parameters" configures whether parameter binding should be used in the creation of JDBC prepared statements.
JDBC_CONNECTIONS_INITIAL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_INITIAL
JDBC_CONNECTIONS_MAX - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_MAX
JDBC_CONNECTIONS_MIN - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_MIN
JDBC_CONNECTIONS_WAIT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_WAIT
JDBC_CONNECTOR - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jdbc.connector" property.
Allows a custom connector to be used to define how to connect to the database.
JDBC_DRIVER - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
JDBC Driver class name.
JDBC_DRIVER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.jdbc.driver" property specifies the JDBC DriverManager class name used for internal connection pooling when a data source is not being used.
JDBC_FETCH_SIZE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.jdbc.fetch-size"
JDBC_FIRST_RESULT - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.jdbc.first-result"
JDBC_FORCE_BIND_PARAMETERS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property "eclipselink.jdbc.force-bind-parameters" enables parameter binding in the creation of JDBC prepared statements.
JDBC_MAX_ROWS - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.jdbc.max-rows"
JDBC_PASSWORD - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
DataSource or JDBC DriverManager password.
JDBC_PASSWORD - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.jdbc.password" property specifies the data source or JDBC password.
JDBC_PROPERTY - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jdbc.property." property allows passing of JDBC driver specific connection properties.
JDBC_READ_CONNECTIONS_INITIAL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_INITIAL
JDBC_READ_CONNECTIONS_MAX - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_MAX
JDBC_READ_CONNECTIONS_MIN - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_MIN
JDBC_READ_CONNECTIONS_SHARED - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_SHARED
JDBC_RESULT_SET_ACCESS_OPTIMIZATION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jdbc.result-set-access-optimization" property allows to set whether a query should by default use ResultSet Access optimization.
JDBC_SEQUENCE_CONNECTION_POOL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_SEQUENCE
JDBC_SEQUENCE_CONNECTION_POOL_DATASOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
JDBC_SEQUENCE_CONNECTION_POOL_INITIAL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_INITIAL
JDBC_SEQUENCE_CONNECTION_POOL_MAX - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_MAX
JDBC_SEQUENCE_CONNECTION_POOL_MIN - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_MIN
JDBC_TIMEOUT - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.jdbc.timeout"
JDBC_URL - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
JDBC Connection String.
JDBC_URL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.jdbc.url" property specifies the JDBC URL used for internal connection pooling when a data source is not being used.
JDBC_USER - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
DataSource or JDBC DriverManager user name.
JDBC_USER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.jdbc.user" property specifies the data source or JDBC user name.
JDBC_WRITE_CONNECTIONS_INITIAL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_INITIAL
JDBC_WRITE_CONNECTIONS_MAX - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_MAX
JDBC_WRITE_CONNECTIONS_MIN - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
as of EclipseLink 2.2 replaced by PersistenceUnitProperties.CONNECTION_POOL_MIN
JDBC20_BATCH_WRITING_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
jdbcType - Variable in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
jdbcType() - Method in annotation type org.eclipse.persistence.annotations.StoredProcedureParameter
(Optional) The JDBC type code, this is dependent on the type returned from the procedure.
JDBCType - Interface in org.eclipse.persistence.platform.database.jdbc
PUBLIC: Marker interface for JDBC type metadata
jdbcTypeName() - Method in annotation type org.eclipse.persistence.annotations.StoredProcedureParameter
(Optional) The JDBC type name, this may be required for ARRAY or STRUCT types.
JDBCTypes - Enum in org.eclipse.persistence.platform.database.jdbc
PUBLIC: JDBC types
JDBCTypeWrapper - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: a helper class that holds DatabaseType's.
JDBCTypeWrapper() - Constructor for class org.eclipse.persistence.internal.sessions.factories.JDBCTypeWrapper
 
JDBCTypeWrapper(DatabaseType) - Constructor for class org.eclipse.persistence.internal.sessions.factories.JDBCTypeWrapper
 
JGeometry - Static variable in class org.eclipse.persistence.config.StructConverterType
 
JGROUPS - Static variable in class org.eclipse.persistence.config.CacheCoordinationProtocol
 
JMS - Static variable in class org.eclipse.persistence.config.CacheCoordinationProtocol
 
JMSProcessingExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for JMSProcessingException messages.
JMSProcessingExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.JMSProcessingExceptionResource
Default constructor.
JMSPublishing - Static variable in class org.eclipse.persistence.config.CacheCoordinationProtocol
 
JMSPublishingHelper - Class in org.eclipse.persistence.sessions.coordination.jms
This helper class allows access to abstract JMSPublishingTransportManager internals when processing JMS messages for RCM, and can be expanded upon to include other EclipseLink JMS functionality.
JMSPublishingTransportManager - Class in org.eclipse.persistence.sessions.coordination.jms
Purpose: Provide a transport implementation for the Remote Command Module (RCM) that publishes to a JMS topic.
JMSPublishingTransportManager(RemoteCommandManager) - Constructor for class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
PUBLIC: Creates a JMSPublishingOnlyTopicTransportManager
JMSPublishingTransportManagerConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.transport
INTERNAL:
JMSPublishingTransportManagerConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.transport.JMSPublishingTransportManagerConfig
 
JMSTopicRemoteConnection - Class in org.eclipse.persistence.internal.sessions.coordination.jms
Purpose: Define the implementation of the abstract RemoteConnection for JMS.
JMSTopicRemoteConnection(RemoteCommandManager) - Constructor for class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
Creates local connections that do not use a TopicConnection or TopicSession, useful only for processing already received JMS messages
JMSTopicRemoteConnection(RemoteCommandManager, TopicConnectionFactory, Topic, boolean, boolean) - Constructor for class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: Constructor creating either a local or external connection.
JMSTopicTransportManager - Class in org.eclipse.persistence.sessions.coordination.jms
Purpose: Provide a transport implementation for the Remote Command Module (RCM) that both publishes and subscribes to a JMS topic.
JMSTopicTransportManager(RemoteCommandManager) - Constructor for class org.eclipse.persistence.sessions.coordination.jms.JMSTopicTransportManager
 
JMSTopicTransportManagerConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.transport
INTERNAL:
JMSTopicTransportManagerConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.transport.JMSTopicTransportManagerConfig
Default constructor.
JMX_MBEANSERVER_INDEX_DEFAULT_FOR_MULTIPLE_SERVERS - Static variable in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
The default indexed MBeanServer instance to use when multiple MBeanServer instances exist on the platform - usually only in JBoss
JMX_REGISTER_DEV_MBEAN_PROPERTY - Static variable in class org.eclipse.persistence.platform.server.ServerPlatformBase
This System property "eclipselink.register.dev.mbean" when set to true will enable registration/unregistration of the DevelopmentServices MBean
JMX_REGISTER_RUN_MBEAN_PROPERTY - Static variable in class org.eclipse.persistence.platform.server.ServerPlatformBase
This System property "eclipselink.register.run.mbean" when set to true will enable registration/unregistration of the RuntimeServices MBean
JMX_REGISTRATION_PREFIX - Static variable in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
This is the prefix for all MBeans that are registered with their specific session name appended
JMXEnabledPlatform - Interface in org.eclipse.persistence.platform.server
PUBLIC: This interface must be implemented by server platform classes that have JMX/MBean functionality enabled in EclipseLink.
As of EclipseLink
JMXServerPlatformBase - Class in org.eclipse.persistence.platform.server
PUBLIC: Subclass of org.eclipse.persistence.platform.server.ServerPlatformBase in support of the JMXEnabledPlatform interface
JMXServerPlatformBase(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.JMXServerPlatformBase
INTERNAL: Default Constructor: Initialize so that runtime services and JTA are enabled.
JNDI_NAME_IS_INVALID - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
JNDI_NAMING_SERVICE - Static variable in class org.eclipse.persistence.sessions.coordination.TransportManager
Valid values for naming service type
JNDI_TRANSACTION_MANAGER_NAME - Static variable in class org.eclipse.persistence.transaction.sap.SAPNetWeaverTransactionController
 
JNDI_TRANSACTION_MANAGER_NAME_AS4 - Static variable in class org.eclipse.persistence.transaction.jboss.JBossTransactionController
 
JNDI_TRANSACTION_MANAGER_NAME_AS7 - Static variable in class org.eclipse.persistence.transaction.jboss.JBossTransactionController
 
JNDI_TRANSACTION_SYNCHRONIZATION_REGISTRY - Static variable in class org.eclipse.persistence.transaction.jboss.JBossTransactionController11
JBoss specific JNDI name of TransactionSynchronizationRegistry instance.
JNDI_TRANSACTION_SYNCHRONIZATION_REGISTRY - Static variable in class org.eclipse.persistence.transaction.JTA11TransactionController
Common JNDI name of TransactionSynchronizationRegistry instance.
JNDI_TRANSACTION_SYNCHRONIZATION_REGISTRY - Static variable in class org.eclipse.persistence.transaction.wls.WebLogicTransactionController11
WLS specific JNDI name of TransactionSynchronizationRegistry instance.
JNDIConnector - Class in org.eclipse.persistence.sessions
Specifies the J2EE DataSource lookup options.
JNDIConnector() - Constructor for class org.eclipse.persistence.sessions.JNDIConnector
PUBLIC: Construct a Connector with no settings.
JNDIConnector(String) - Constructor for class org.eclipse.persistence.sessions.JNDIConnector
PUBLIC: Construct a Connector with the datasource name.
JNDIConnector(Context, String) - Constructor for class org.eclipse.persistence.sessions.JNDIConnector
PUBLIC: Construct a Connector with the datasource name.
JNDIConnector(DataSource) - Constructor for class org.eclipse.persistence.sessions.JNDIConnector
PUBLIC: Construct a Connector with the datasource object.
jndiLookup(String) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
PUBLIC: Look up a given name in JNDI.
jndiLookupException(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
JNDINamingServiceConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.transport.naming
INTERNAL:
JNDINamingServiceConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
 
join(Expression, Expression) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Defines a join between the two objects based on the specified ON clause.
join(Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
Defines a join between this expression and the target expression based on the ON clause.
JOIN - org.eclipse.persistence.annotations.BatchFetchType
This is the default form of batch reading.
JOIN_EXISTING_TRANSACTION - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
Set to "true" this property forces persistence context to read through JTA-managed ("write") connection in case there is an active transaction.
JOIN_EXISTING_TRANSACTION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.transaction.join-existing" property set to "true" forces persistence context to read through JTA-managed ("write") connection in case there is an active transaction.
JOIN_EXPRESSIONS_NOT_APPLICABLE_ON_NON_OBJECT_REPORT_ITEM - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
joinCriteria - Variable in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
 
joinedAggregateMappings - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Stores AggregateObjectMapping expressions used within local join expressions
joinedAttributeExpressions - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Stores the joined attributes added through the query
joinedAttributeManager - Variable in class org.eclipse.persistence.internal.queries.ReportItem
Stores the Join information for this item
joinedAttributeManager - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Stores the helper object for dealing with joined attributes
JoinedAttributeManager - Class in org.eclipse.persistence.internal.queries
Purpose: A common class to be used by ObjectLevelReadQueries and ReportItems.
JoinedAttributeManager() - Constructor for class org.eclipse.persistence.internal.queries.JoinedAttributeManager
 
JoinedAttributeManager(ClassDescriptor, ExpressionBuilder, ObjectBuildingQuery) - Constructor for class org.eclipse.persistence.internal.queries.JoinedAttributeManager
 
joinedAttributeMappings - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
indexed list of mappings corresponding to
joinedAttributes - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Cache mapping that use joining.
joinedAttributes - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
PERF: Cache the local joined attribute expressions.
joinedMappingExpressions - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Stores the joined attributes as specified in the descriptor
joinedMappingIndexes - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Used internally for joining.
joinedMappingQueries - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Used internally for joining.
joinedMappingQueryClones - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
PERF: Stores the cloned joinedMappingQueries.
joinExpressionsNotApplicableOnNonObjectReportItem(String, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
joinFetch - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Define if the relationship should always be join fetched.
JoinFetch - Annotation Type in org.eclipse.persistence.annotations
A JoinFetch annotation can be used on any relationship mapping, (OneToOne, ManyToOne, OneToMany, ManyToMany, BasicCollection, BasicMap).
JoinFetchType - Enum in org.eclipse.persistence.annotations
An enum type that is used within the JoinFetch annotation.
JOINING_ACROSS_INHERITANCE_WITH_MULTIPLE_TABLES - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
joiningAcrossInheritanceClassWithMultipleTablesNotSupported(DatabaseQuery, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
joinRelationTableField(Expression, Expression) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Adds to the passed expression a single relation table field joined to source field.
joinSource - Variable in class org.eclipse.persistence.internal.expressions.ObjectExpression
Defines that this expression has been joined to the source expression.
JPA - org.eclipse.persistence.logging.LogCategory
 
JPA - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
JPA_FETCH_GRAPH - Static variable in class org.eclipse.persistence.config.QueryHints
"jakarta.persistence.fetchgraph"
JPA_LOAD_GRAPH - Static variable in class org.eclipse.persistence.config.QueryHints
"jakarta.persistence.loadgraph"
JPA10 - Static variable in class org.eclipse.persistence.config.ParserValidationType
 
JPA20 - Static variable in class org.eclipse.persistence.config.ParserValidationType
 
JPA21 - Static variable in class org.eclipse.persistence.config.ParserValidationType
 
JPA22 - Static variable in class org.eclipse.persistence.config.ParserValidationType
 
JPA30 - Static variable in class org.eclipse.persistence.config.ParserValidationType
 
JPA31 - Static variable in class org.eclipse.persistence.config.ParserValidationType
 
JPAClassLoaderHolder - Class in org.eclipse.persistence.internal.helper
INTERNAL: This class is a composite object containing the classLoader and a flag that is true if the classLoader returned is temporary.
JIRA EJBTHREE-572 requires that we use the real classLoader in place of the getNewTempClassLoader().
JPAClassLoaderHolder(ClassLoader) - Constructor for class org.eclipse.persistence.internal.helper.JPAClassLoaderHolder
INTERNAL: Create an instance of JPAClassLoaderHolder that wraps aClassLoader that is an original call to get*ClassLoader().
JPAClassLoaderHolder(ClassLoader, boolean) - Constructor for class org.eclipse.persistence.internal.helper.JPAClassLoaderHolder
INTERNAL: Create an instance of JPAClassLoaderHolder that wraps aClassLoader and the inUse boolean.
JPAConversionManager - Class in org.eclipse.persistence.internal.helper
Purpose: Extension to the existing conversion manager to support the EJB 3.0 spec.
JPAConversionManager() - Constructor for class org.eclipse.persistence.internal.helper.JPAConversionManager
 
jpaQueries - Variable in class org.eclipse.persistence.sessions.Project
List of queries from JPA that need special processing before execution.
jpaQueriesProcessed - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Stores predefined not yet parsed JPQL queries.
JPAQueryBuilder - Interface in org.eclipse.persistence.queries
This interface defines the entry point for implementing a JPQL query parsing system in EclipseLink.
JPARS - org.eclipse.persistence.logging.LogCategory
 
JPARS - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
JPARSErrorCodes - Class in org.eclipse.persistence.exceptions
 
JPARSExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
 
JPARSExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.JPARSExceptionResource
Default constructor.
jpaTablePerTenantQueries - Variable in class org.eclipse.persistence.sessions.Project
List of queries from JPA that may special processing and handling before execution.
JPQL_PARSER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jpql.parser" property allows the JPQL parser to be configured.
JPQL_TOLERATE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.tolerate-invalid-jpql" property allows an EntityManager to be created even in the event that an application has invalid JPQL statements declared in annotations or xml.
JPQL_VALIDATION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jpql.validation" property allows the JPQL parser validation level to be configured.
JPQLCall - Class in org.eclipse.persistence.queries
Purpose: Used as an abstraction of a database invocation.
JPQLCall() - Constructor for class org.eclipse.persistence.queries.JPQLCall
PUBLIC: Create a new JPQLCall.
JPQLCall(String) - Constructor for class org.eclipse.persistence.queries.JPQLCall
PUBLIC: Create a new JPQLCall with an jpqlString.
JPQLCallQueryMechanism - Class in org.eclipse.persistence.internal.queries
INTERNAL
JPQLCallQueryMechanism() - Constructor for class org.eclipse.persistence.internal.queries.JPQLCallQueryMechanism
 
JPQLCallQueryMechanism(DatabaseQuery) - Constructor for class org.eclipse.persistence.internal.queries.JPQLCallQueryMechanism
Initialize the state of the query
JPQLCallQueryMechanism(DatabaseQuery, JPQLCall) - Constructor for class org.eclipse.persistence.internal.queries.JPQLCallQueryMechanism
INTERNAL Initialize the state of the query
JPQLException - Exception in org.eclipse.persistence.exceptions
Purpose: EJBQL parsing and resolution problems will raise this exception
JPQLException() - Constructor for exception org.eclipse.persistence.exceptions.JPQLException
INTERNAL Only TopLink can throw and create these excpetions
JPQLException(String) - Constructor for exception org.eclipse.persistence.exceptions.JPQLException
INTERNAL Only TopLink can throw and create these excpetions
JPQLException(String, Exception) - Constructor for exception org.eclipse.persistence.exceptions.JPQLException
INTERNAL Only TopLink can throw and create these excpetions
JPQLException(String, Exception, int) - Constructor for exception org.eclipse.persistence.exceptions.JPQLException
INTERNAL Only TopLink can throw and create these excpetions
JPQLExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for EJBQLException.
JPQLExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.JPQLExceptionResource
Default constructor.
jpqlParseCache - Variable in class org.eclipse.persistence.sessions.Project
PERF: Provide an JPQL parse cache to optimize dynamic JPQL.
JPQLQueryHelper - Class in org.eclipse.persistence.internal.jpa.jpql
This helper can perform various operations over a JPQL query.
JPQLQueryHelper() - Constructor for class org.eclipse.persistence.internal.jpa.jpql.JPQLQueryHelper
Creates a new JPQLQueryHelper which uses the latest JPQL grammar.
JPQLQueryHelper(JPQLGrammar) - Constructor for class org.eclipse.persistence.internal.jpa.jpql.JPQLQueryHelper
Creates a new JPQLQueryHelper.
jpqlString - Variable in class org.eclipse.persistence.queries.JPQLCall
 
JSON - Static variable in annotation type org.eclipse.persistence.annotations.Convert
Constant name for the reserved JSON converter.
JSON_DISABLE_NESTED_ARRAY_NAME - Static variable in class org.eclipse.persistence.internal.oxm.OXMSystemProperties
Disable generation of "item" name in nested arrays in JSON.
JSON_TYPE_ATTRIBUTE_NAME - Static variable in class org.eclipse.persistence.internal.oxm.OXMSystemProperties
Override default type property name for JSON as MOXy type discriminator.
JSON_TYPE_COMPATIBILITY - Static variable in class org.eclipse.persistence.internal.oxm.OXMSystemProperties
If we should treat unqualified type property in JSON as MOXy type discriminator.
JSON_USE_XSD_TYPES_PREFIX - Static variable in class org.eclipse.persistence.internal.oxm.OXMSystemProperties
If there should be xsd prefix when using simple types, e.g.
JSON_VALUE_WRAPPER_REQUIRED - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
JsonArrayBuilderResult - Class in org.eclipse.persistence.oxm.json
 
JsonArrayBuilderResult() - Constructor for class org.eclipse.persistence.oxm.json.JsonArrayBuilderResult
 
JsonArrayBuilderResult(JsonArrayBuilder) - Constructor for class org.eclipse.persistence.oxm.json.JsonArrayBuilderResult
 
JsonBuilderRecord - Class in org.eclipse.persistence.oxm.record
 
JsonBuilderRecord() - Constructor for class org.eclipse.persistence.oxm.record.JsonBuilderRecord
 
JsonBuilderRecord(JsonArrayBuilder) - Constructor for class org.eclipse.persistence.oxm.record.JsonBuilderRecord
 
JsonBuilderRecord(JsonObjectBuilder) - Constructor for class org.eclipse.persistence.oxm.record.JsonBuilderRecord
 
JsonBuilderRecord.Level - Class in org.eclipse.persistence.oxm.record
Instances of this class are used to maintain state about the current level of the JSON message being marshalled.
jsonDisableNestedArrayName - Static variable in class org.eclipse.persistence.internal.oxm.OXMSystemProperties
 
JSONException - Exception in org.eclipse.persistence.exceptions
Purpose: This class provides an implementation of EclipseLinkException specific to the EclipseLink JSON handling (marshall, unmarshall, Jersey provider)
JSONException(String) - Constructor for exception org.eclipse.persistence.exceptions.JSONException
 
JSONException(String, Exception) - Constructor for exception org.eclipse.persistence.exceptions.JSONException
 
JSONExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: Purpose:
JSONExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.JSONExceptionResource
Default constructor.
JSONFormattedWriterRecord - Class in org.eclipse.persistence.oxm.record
Use this type of MarshalRecord when the marshal target is a Writer and the JSON should be formatted with carriage returns and indenting.
JSONFormattedWriterRecord() - Constructor for class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
 
JSONFormattedWriterRecord(OutputStream) - Constructor for class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
 
JSONFormattedWriterRecord(OutputStream, String) - Constructor for class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
 
JSONFormattedWriterRecord(Writer) - Constructor for class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
 
JSONFormattedWriterRecord(Writer, String) - Constructor for class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
 
JsonGeneratorRecord - Class in org.eclipse.persistence.oxm.record
 
JsonGeneratorRecord(JsonGenerator, String) - Constructor for class org.eclipse.persistence.oxm.record.JsonGeneratorRecord
 
JsonGeneratorResult - Class in org.eclipse.persistence.oxm.json
 
JsonGeneratorResult(JsonGenerator) - Constructor for class org.eclipse.persistence.oxm.json.JsonGeneratorResult
 
JsonGeneratorResult(JsonGenerator, String) - Constructor for class org.eclipse.persistence.oxm.json.JsonGeneratorResult
 
JsonObjectBuilderResult - Class in org.eclipse.persistence.oxm.json
 
JsonObjectBuilderResult() - Constructor for class org.eclipse.persistence.oxm.json.JsonObjectBuilderResult
 
JsonObjectBuilderResult(JsonObjectBuilder) - Constructor for class org.eclipse.persistence.oxm.json.JsonObjectBuilderResult
 
JsonParserSource - Class in org.eclipse.persistence.oxm.json
Object to be used with Unmarshaller to unmarshal JsonParser objects Usage: JsonParserSource source = new JsonParserSource(jsonParser); Object unmarshalled = jaxbUnmarshaller.unmarshal(source);
JsonParserSource(JsonParser) - Constructor for class org.eclipse.persistence.oxm.json.JsonParserSource
 
JsonPlatformManager - Class in org.eclipse.persistence.internal.databaseaccess
Java service manager and service loader for DatabaseJsonPlatform interface.
JsonPlatformProvider - Interface in org.eclipse.persistence.internal.databaseaccess.spi
Java service provider interface for database platform JSOn extension.
JsonRecord<T extends JsonRecord.Level> - Class in org.eclipse.persistence.oxm.record
 
JsonRecord() - Constructor for class org.eclipse.persistence.oxm.record.JsonRecord
 
JsonRecord.JsonRecordContentHandler - Class in org.eclipse.persistence.oxm.record
This class will typically be used in conjunction with an XMLFragmentReader.
JsonRecord.Level - Class in org.eclipse.persistence.oxm.record
Instances of this class are used to maintain state about the current level of the JSON message being marshalled.
JSONSerializer - Class in org.eclipse.persistence.sessions.serializers
Uses EclipseLink Moxy to convert an object to JSON.
JSONSerializer() - Constructor for class org.eclipse.persistence.sessions.serializers.JSONSerializer
 
JSONSerializer(JAXBContext) - Constructor for class org.eclipse.persistence.sessions.serializers.JSONSerializer
 
JSONSerializer(String) - Constructor for class org.eclipse.persistence.sessions.serializers.JSONSerializer
 
JsonStructureSource - Class in org.eclipse.persistence.oxm.json
Object to be used with Unmarshaller to unmarshal jakarta.json.JsonStructure objects (ie: jakarta.json.JsonObject or jakarta.json.JsonArray) Usage: JsonStructureSource source = new JsonStructureSource(jsonObject); Object unmarshalled = jaxbUnmarshaller.unmarshal(source);
JsonStructureSource(JsonStructure) - Constructor for class org.eclipse.persistence.oxm.json.JsonStructureSource
 
jsonTypeAttributeName - Static variable in class org.eclipse.persistence.internal.oxm.OXMSystemProperties
 
jsonTypeCompatiblity - Static variable in class org.eclipse.persistence.internal.oxm.OXMSystemProperties
 
JsonTypeConfiguration - Class in org.eclipse.persistence.internal.oxm
Handles Json type configuration.
JsonTypeConfiguration() - Constructor for class org.eclipse.persistence.internal.oxm.JsonTypeConfiguration
 
jsonUseXsdTypesPrefix - Static variable in class org.eclipse.persistence.internal.oxm.OXMSystemProperties
 
jsonValuePropertyRequired(Object) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: An exception occurred marshalling json
JSONWithPadding<T> - Class in org.eclipse.persistence.oxm
JSONWithPadding is used to hold an Object along with the corresponding callback name to marshal.
JSONWithPadding() - Constructor for class org.eclipse.persistence.oxm.JSONWithPadding
 
JSONWithPadding(T) - Constructor for class org.eclipse.persistence.oxm.JSONWithPadding
 
JSONWithPadding(T, String) - Constructor for class org.eclipse.persistence.oxm.JSONWithPadding
 
JSONWriterRecord - Class in org.eclipse.persistence.oxm.record
Use this type of MarshalRecord when the marshal target is a Writer and the JSON should not be formatted with carriage returns or indenting.
JSONWriterRecord() - Constructor for class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
JSONWriterRecord(OutputStream) - Constructor for class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
JSONWriterRecord(OutputStream, String) - Constructor for class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
JSONWriterRecord(Writer) - Constructor for class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
JSONWriterRecord(Writer, String) - Constructor for class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
JSONWriterRecord.JSONWriterRecordContentHandler - Class in org.eclipse.persistence.oxm.record
This class will typically be used in conjunction with an XMLFragmentReader.
JSONWriterRecord.Level - Class in org.eclipse.persistence.oxm.record
Instances of this class are used to maintain state about the current level of the JSON message being marshalled.
JSONWriterRecord.Output - Interface in org.eclipse.persistence.oxm.record
 
JSONWriterRecord.OutputStreamOutput - Class in org.eclipse.persistence.oxm.record
 
JTA_CONTROLLER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jta.controller" property allows to override JTA transaction controller class of ServerPlatform.
JTA_DATASOURCE - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
JTA DataSource.
JTA_DATASOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.jtaDataSource" property specifies the JTA data source name that will look up a valid DataSource.
JTA_PERSISTENCE_UNIT_INFO_MISSING_JTA_DATA_SOURCE - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
JTA11TransactionController - Class in org.eclipse.persistence.transaction
Purpose: TransactionController extensions for JTA 1.1
JTA11TransactionController() - Constructor for class org.eclipse.persistence.transaction.JTA11TransactionController
PUBLIC: Return a new controller for use with acquired JTA 1.1 compliant TransactionSynchronizationRegistry.
JTA11TransactionController(TransactionSynchronizationRegistry, TransactionManager) - Constructor for class org.eclipse.persistence.transaction.JTA11TransactionController
PUBLIC: Return a new controller for use with supplied JTA 1.1 compliant synchronization objects registry.
jtaPersistenceUnitInfoMissingJtaDataSource(String) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
JTASynchronizationListener - Class in org.eclipse.persistence.transaction
Purpose: Synchronization object implementation for JTA 1.0
JTASynchronizationListener() - Constructor for class org.eclipse.persistence.transaction.JTASynchronizationListener
PUBLIC: Used to create factory instances only.
JTASynchronizationListener(UnitOfWorkImpl, AbstractSession, Object, AbstractTransactionController) - Constructor for class org.eclipse.persistence.transaction.JTASynchronizationListener
INTERNAL: Constructor for creating listener instances (expects all required state info)
JTATransactionController - Class in org.eclipse.persistence.transaction
Purpose: TransactionController implementation for JTA 1.0
JTATransactionController() - Constructor for class org.eclipse.persistence.transaction.JTATransactionController
PUBLIC: Return a new controller for use with a JTA 1.0 compliant TransactionManager.
JTATransactionController(TransactionManager) - Constructor for class org.eclipse.persistence.transaction.JTATransactionController
PUBLIC: Return a new controller for use with a JTA 1.0 compliant TransactionManager.
JTS_EXCEPTION_RAISED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
JtsAfterCompletion - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
JtsBeforeCompletion - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
jtsExceptionRaised(Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 

K

KEEP_ALL_AS_ELEMENT - org.eclipse.persistence.oxm.mappings.UnmarshalKeepAsElementPolicy
 
KEEP_NONE_AS_ELEMENT - org.eclipse.persistence.oxm.mappings.UnmarshalKeepAsElementPolicy
 
KEEP_UNKNOWN_AS_ELEMENT - org.eclipse.persistence.oxm.mappings.UnmarshalKeepAsElementPolicy
 
keepInRow - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
Indicates whether the field should be kept in the record after the object is created.
keepInRow() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
key - Variable in class org.eclipse.persistence.descriptors.changetracking.MapChangeEvent
INTERNAL: The value of the key that was updated.
key - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
The key holds the vector of primary key values for the object.
key - Variable in class org.eclipse.persistence.internal.sessions.remote.ObjectDescriptor
A primary key
key - Variable in class org.eclipse.persistence.mappings.Association
 
key - Variable in class org.eclipse.persistence.queries.ReportQueryResult
If an objectLevel distinct is used then generate unique key for this result
KEY - org.eclipse.persistence.internal.mappings.converters.AttributeNamePrefix
INTERNAL: Attribute name prefix is "key".
KEY_PARAMETER_TYPE_INCORRECT - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
keyAtValue(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.TableAliasLookup
 
keyColumn() - Method in annotation type org.eclipse.persistence.annotations.BasicMap
Deprecated.
(Optional) The name of the data column that holds the direct map key.
keyConverter() - Method in annotation type org.eclipse.persistence.annotations.BasicMap
Deprecated.
(Optional) Specify the key converter.
keyField - Variable in class org.eclipse.persistence.internal.queries.MapContainerPolicy
 
keyFrom(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the key for the specified element..
keyFrom(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return the key for the specified element.
keyFrom(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Return the key for the specified element.
keyFromEntry(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
Get the key from the passed in Map.Entry This method will be overridden by ContainerPolicies that allows maps.
keyFromEntry(Object) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
Get the key from the passed in Map.Entry.
keyFromIterator(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
keyFromIterator(Object) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
 
keyFromObject(Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Extract and return the primary key from the object.
keyGroup - Variable in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
keyGroups - Variable in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
KeyIsElementAccessor(String, DatabaseField, DatabaseMapping) - Constructor for class org.eclipse.persistence.descriptors.CMPPolicy.KeyIsElementAccessor
 
KeyIterator() - Constructor for class org.eclipse.persistence.queries.ReportQueryResult.KeyIterator
 
keyMapping - Variable in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
 
keyMethod - Variable in class org.eclipse.persistence.internal.queries.MapContainerPolicy
 
keyName - Variable in class org.eclipse.persistence.internal.queries.MapContainerPolicy
The Method which is called on each value added to the Map and whose result is used as key to the value.
keyName - Variable in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
keyQuery - Variable in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
 
keys - Variable in class org.eclipse.persistence.internal.expressions.TableAliasLookup
 
keys() - Method in class org.eclipse.persistence.indirection.IndirectMap
 
keys() - Method in class org.eclipse.persistence.internal.expressions.TableAliasLookup
 
keys() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
keys() - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Allow for the CacheKeys to be iterated on.
keys() - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Allow for the cache keys to be iterated on.
keys() - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Allow for the CacheKeys to be iterated on.
keys() - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Return an empty enumerator.
keys() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Returns an Enumeration of the DatabaseField objects.
keys() - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Allow for the CacheKey elements to be iterated.
keys(boolean) - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Allow for the CacheKey elements to be iterated.
keys(boolean) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Allow for the CacheKeys to be iterated on.
keys(boolean) - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Return an empty enumerator.
keys(boolean) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Allow for the CacheKey elements to be iterated.
KEYS_MUST_MATCH - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
keySet() - Method in class org.eclipse.persistence.eis.EISMappedRecord
Forward the request to the record.
keySet() - Method in class org.eclipse.persistence.indirection.IndirectMap
 
keySet() - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Returns a set view of the keys contained in this IdentityWeakHashMap.
keySet() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
keySet() - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
Unmodifiable set of keys
keySet() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Returns a set of the keys.
keySet() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
PUBLIC: Return the set of element names from the DOM.
keySet() - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Returns a set of the keys.
KeySet() - Constructor for class org.eclipse.persistence.internal.sessions.AbstractRecord.KeySet
Default constructor.
KeySet() - Constructor for class org.eclipse.persistence.queries.ReportQueryResult.KeySet
 
keyTableForMapKey - Variable in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
 
keyTableForMapKey - Variable in class org.eclipse.persistence.mappings.OneToOneMapping
 
keyType - Variable in class org.eclipse.persistence.mappings.TypedAssociation
 
KRYO - Static variable in annotation type org.eclipse.persistence.annotations.Convert
Constant name for the reserved Kryo converter.

L

last - Variable in class org.eclipse.persistence.internal.identitymaps.CacheIdentityMap
Provide handles on the linked list
last() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
Moves the cursor to the last row in the result set
last() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Moves the cursor to the last row in the result set
LAST_ERROR_CODE - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
lastAccessedIdentityMap - Variable in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
PERF: Optimize the object retrieval from the identity map.
lastCallAppended - Variable in class org.eclipse.persistence.internal.databaseaccess.DynamicSQLBatchWritingMechanism
 
lastCallAppended - Variable in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
 
lastDay() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the date with the last date in the months of this source date.
lastDay() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
LastDay - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
lastDescriptorAccessed - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Last descriptor accessed, use to optimize descriptor lookup.
lastDumpTime - Variable in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
lastElement() - Method in class org.eclipse.persistence.indirection.IndirectList
 
lastElement() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
lastElement() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
lastElement() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
lastFieldIdx - Variable in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
lastIndexOf(Object) - Method in class org.eclipse.persistence.indirection.IndirectList
 
lastIndexOf(Object) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
lastIndexOf(Object) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
lastIndexOf(Object) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
lastIndexOf(Object, int) - Method in class org.eclipse.persistence.indirection.IndirectList
 
lastIndexOf(Object, int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
lastIndexOf(Object, int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
lastIndexOf(Object, int) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
lastJoinedAttributeBaseExpression - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Stores the last used base expression while adding joined attribute expression.
lastTable - Variable in class org.eclipse.persistence.expressions.Expression
Temporary values for table aliasing
lastTable - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
lastUpdatedQueryId - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
This attribute is the system time in milli seconds that the object was last refreshed on
lastUsed - Variable in class org.eclipse.persistence.internal.expressions.TableAliasLookup
 
lastUsedMergeManager - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Used to store the list of locks that this UnitOfWork has acquired for this merge
latestCollection - Variable in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
Used for change tracking when user sets entire collection.
launchContainerRunnable(Runnable) - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: launchContainerRunnable(Runnable runnable): Use the container library to start the provided Runnable.
launchContainerRunnable(Runnable) - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: launchContainerRunnable(Runnable runnable): Use the container library to start the provided Runnable.
launchContainerThread(Thread) - Method in class org.eclipse.persistence.platform.server.NoServerPlatform
INTERNAL: launchContainerThread(Thread thread): Do nothing because container Threads are not launchable in this platform
LAX - Static variable in class org.eclipse.persistence.internal.oxm.schema.model.AnyAttribute
 
LAZY_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
lazyRelationshipLoaded(Object, ValueHolderInterface, ForeignReferenceMapping) - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Notify the cache that a lazy relationship has been triggered in the object and the cache may need to be updated
lazyRelationshipLoaded(Object, ValueHolderInterface, ForeignReferenceMapping) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Notify the cache that a lazy relationship has been triggered in the object and the cache may need to be updated
lazyRelationshipLoaded(Object, ValueHolderInterface, ForeignReferenceMapping) - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Notify the cache that a lazy relationship has been triggered in the object and the cache may need to be updated
lazyRelationshipLoaded(Object, ValueHolderInterface, ForeignReferenceMapping) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Notify the cache that a lazy relationship has been triggered in the object and the cache may need to be updated
leafElementType - Variable in class org.eclipse.persistence.oxm.XMLField
 
least() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
least() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the smallest of two values.
Builds Symfoware equivalent to LEAST(x, y).
Symfoware: CASE WHEN x <= y THEN x ELSE y END
Least - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
LEFT_BRACE - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
Left brace.
LEFT_BRACKET - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
Left bracket.
LEFT_FETCH - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.left-join-fetch"
leftJoin(Expression, Expression) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Defines an outer join between the two objects based on the specified ON clause.
leftJoin(Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
Defines a join between this expression and the target expression based on the ON clause.
leftPad() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
leftPad(int, Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the string padded with the substring to the size.
leftPad(Object, Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the string padded with the substring to the size.
LeftPad - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
leftTrim() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the string left trimmed for white space.
leftTrim() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
leftTrim() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
INTERNAL: Build FB equivalent to LTRIM(string_exp).
leftTrim() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the string left trimmed for white space.
Builds Symfoware equivalent to LTRIM(string_exp).
Symfoware: TRIM(LEADING FROM string_exp)
leftTrim(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the string with the substring trimed from the left.
LeftTrim - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
leftTrim2() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build leftTrim operator that takes one parameter.
leftTrim2() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Build MySQL equivalent to LTRIM(string_exp, character).
leftTrim2() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the string left trimmed for white space.
Builds Symfoware equivalent to LTRIM(string_exp, character).
Symfoware: TRIM(LEADING character FROM string_exp)
LeftTrim2 - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
length - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
 
length - Static variable in enum org.eclipse.persistence.logging.LogCategory
Logging categories enumeration length.
length - Static variable in enum org.eclipse.persistence.logging.LogLevel
Logging levels enumeration length.
length - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
length() - Method in annotation type org.eclipse.persistence.annotations.TenantDiscriminatorColumn
(Optional) The column length for String-based discriminator types.
length() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the size of the string.
length() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
length() - Method in class org.eclipse.persistence.internal.oxm.StrBuffer
 
length() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLParameter
(Optional) The max length of the field value.
length() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Obtains the number of characters in the data string value expression.
Builds Symfoware equivalent to length(string_exp).
Symfoware: CHAR_LENGTH(string_exp)
Length - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
LENGTH - Static variable in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
GlassFish Java SE platform enumeration length.
LENGTH - Static variable in enum org.eclipse.persistence.internal.mappings.converters.AttributeNamePrefix
INTERNAL: Attribute name prefixes enumeration length.
lengthOperator() - Method in class org.eclipse.persistence.platform.database.DB2Platform
Disable binding support.
lessThan() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
 
lessThan(boolean) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than the other value.
lessThan(byte) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than the other value.
lessThan(char) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than the other value.
lessThan(double) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than the other value.
lessThan(float) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than the other value.
lessThan(int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than the other value.
lessThan(long) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than the other value.
lessThan(short) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than the other value.
lessThan(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than the other value.
lessThan(Expression) - Method in class org.eclipse.persistence.expressions.Expression
 
LessThan - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
lessThanEqual() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
 
lessThanEqual(boolean) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than and equal to the other value.
lessThanEqual(byte) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than and equal to the other value.
lessThanEqual(char) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than and equal to the other value.
lessThanEqual(double) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than and equal to the other value.
lessThanEqual(float) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than and equal to the other value.
lessThanEqual(int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than and equal to the other value.
lessThanEqual(long) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than and equal to the other value.
lessThanEqual(short) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than and equal to the other value.
lessThanEqual(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than and equal to the other value.
lessThanEqual(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is less than and equal to the other value.
LessThanEqual - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
lessThanEqualOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
DB2 z/OS requires that at least one argument be a known type
lessThanEqualOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
lessThanOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Set binding support to PARTIAL.
lessThanOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
level - Variable in class org.eclipse.persistence.internal.codegen.AccessLevel
 
level - Variable in class org.eclipse.persistence.logging.AbstractSessionLog
Represents the log level
level - Variable in class org.eclipse.persistence.logging.SessionLogEntry
 
level - Variable in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
Level(boolean, boolean, boolean) - Constructor for class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
Level(boolean, boolean, boolean, JSONWriterRecord.Level) - Constructor for class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
Level(boolean, JsonBuilderRecord.Level, boolean) - Constructor for class org.eclipse.persistence.oxm.record.JsonBuilderRecord.Level
 
Level(boolean, JsonRecord.Level, boolean) - Constructor for class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
LEXICAL_HANDLER_PROPERTY - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
lexicalHandler - Variable in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
LF - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
Line feed.
lifecycle - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
With the new synchronized unit of work, need a lifecycle state variable to track birth, committed, pending_merge and death.
like() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the LIKE operator.
like(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is like other value.
like(String, String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is like other value.
like(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is like other value.
like(Expression, Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is like other value.
Like - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
likeEscape() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the LIKE operator with ESCAPE.
LikeEscape - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
likeIgnoreCase(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is like the other value, ignoring case.
likeIgnoreCase(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is like the other value, ignoring case.
lines - Variable in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
LinkedCacheKey - Class in org.eclipse.persistence.internal.identitymaps
Purpose: Provides the capability to insert CacheKeys into a Linked List.
LinkedCacheKey(Object, Object, Object, long, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.LinkedCacheKey
Initialize the newly allocated instance of this class.
LinkedNode - Class in org.eclipse.persistence.internal.helper.linkedlist
INTERNAL: A custom implementation of a linked list node for use in the ExposedNodeLinkedList.
list - Variable in class org.eclipse.persistence.internal.sessions.factories.NodeListElementEnumerator
 
List - Class in org.eclipse.persistence.internal.oxm.schema.model
 
List() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.List
 
List_Class - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
LIST_ORDER_FIELD_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
LIST_ORDER_FIELD_REQUIRES_INDIRECT_LIST - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
LIST_ORDER_FIELD_REQUIRES_LIST - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
LIST_ORDER_FIELD_TABLE_IS_WRONG - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
LIST_ORDER_FIELD_WRONG_VALUE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
ListContainerPolicy - Class in org.eclipse.persistence.internal.queries
Purpose: A ListContainerPolicy is ContainerPolicy whose container class implements the List interface.
ListContainerPolicy() - Constructor for class org.eclipse.persistence.internal.queries.ListContainerPolicy
INTERNAL: Construct a new policy.
ListContainerPolicy(Class<?>) - Constructor for class org.eclipse.persistence.internal.queries.ListContainerPolicy
INTERNAL: Construct a new policy for the specified class.
ListContainerPolicy(String) - Constructor for class org.eclipse.persistence.internal.queries.ListContainerPolicy
INTERNAL: Construct a new policy for the specified class name.
listenerFactory - Variable in class org.eclipse.persistence.transaction.AbstractTransactionController
Generates listener instances for synchronization
listeners - Variable in class org.eclipse.persistence.sessions.SessionEventManager
 
ListExpressionOperator - Class in org.eclipse.persistence.expressions
INTERNAL: A ListExpressionOperator is used with an ArgumentListFunctionExpression.
ListExpressionOperator() - Constructor for class org.eclipse.persistence.expressions.ListExpressionOperator
 
listFilesIn(File) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return an array of the files in the specified directory.
listIterator() - Method in class org.eclipse.persistence.indirection.IndirectList
 
listIterator() - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
listIterator() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
listIterator() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
 
listIterator(int) - Method in class org.eclipse.persistence.indirection.IndirectList
 
listIterator(int) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
listIterator(int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
listIterator(int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
listIterator(int) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Iterate while waiting at end until complete.
listOrderField - Variable in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
 
listOrderField - Variable in class org.eclipse.persistence.mappings.CollectionMapping
Field holds the order of elements in the list in the db, requires collection of type List, may be not null only in case isListOrderFieldSupported==true
listOrderFieldNotSupported(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Attempt to call setListOrderField method on a mapping that doesn't support listOrderField.
listOrderFieldRequiersIndirectList(ClassDescriptor, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
listOrderFieldRequiersList(ClassDescriptor, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
listOrderFieldTableIsWrong(ClassDescriptor, DatabaseMapping, DatabaseTable, DatabaseTable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
listOrderFieldWrongValue(DatabaseQuery, DatabaseField, List) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
literal(String) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression on the literal.
LITERAL - org.eclipse.persistence.internal.databaseaccess.DatasourceCall.ParameterType
 
LiteralExpression - Class in org.eclipse.persistence.internal.expressions
Used for wrapping literal values.
LiteralExpression() - Constructor for class org.eclipse.persistence.internal.expressions.LiteralExpression
 
LiteralExpression(String, Expression) - Constructor for class org.eclipse.persistence.internal.expressions.LiteralExpression
 
ln() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
ln(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Ln - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
load() - Method in annotation type org.eclipse.persistence.annotations.FetchGroup
(Optional) Indicates whether all relationship attributes specified in the fetch group should be loaded.
load(Object, AttributeItem, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Force instantiation of the load group.
load(Object, AttributeItem, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.AggregateMapping
Force instantiation of the load group.
load(Object, AttributeItem, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.CollectionMapping
Force instantiation of the load group.
load(Object, AttributeItem, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
Force instantiation of the load group.
load(Object, AttributeItem, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Force instantiation of the load group.
load(Object, AttributeGroup) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
This method will load the passed object or collection of objects using the passed AttributeGroup.
load(Object, AttributeGroup, ClassDescriptor, boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
This method will load the passed object or collection of objects using the passed AttributeGroup.
load(Object, AttributeGroup, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Force instantiation to any mappings in the load group.
load(SessionManager, ClassLoader) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
INTERNAL: This method instantiates the parser and builds the document based on the schema.
LOAD_GROUP - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.load-group"
LOAD_GROUP_ATTRIBUTE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.load-group.attribute"
loadAll(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Force instantiation of all indirections.
loadAll(Object, AbstractSession, IdentityHashSet) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
loadAll(Object, AbstractSession, IdentityHashSet) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Force instantiation of all indirections.
loadAll(Object, AbstractSession, IdentityHashSet) - Method in class org.eclipse.persistence.mappings.AggregateMapping
Force instantiation of all indirections.
loadAll(Object, AbstractSession, IdentityHashSet) - Method in class org.eclipse.persistence.mappings.CollectionMapping
Force instantiation of all indirections.
loadAll(Object, AbstractSession, IdentityHashSet) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
Force instantiation of all indirections.
loadAll(Object, AbstractSession, IdentityHashSet) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
Force instantiation of all indirections.
loadAllValuesFromResultSet() - Method in class org.eclipse.persistence.internal.sessions.ResultSetRecord
Obtains all the value from resultSet and removes it.
loadAllValuesFromResultSet() - Method in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
Obtains all the value from resultSet and removes it.
loadBatchReadAttributes(ClassDescriptor, Object, CacheKey, AbstractRecord, ObjectBuildingQuery, JoinedAttributeManager, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
loadClass(String) - Static method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Load the class using the default managers class loader.
loadClass(String, ClassLoader) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
Load the given class name with the given loader.
loadConfigsForMappingWorkbench(ClassLoader) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
INTERNAL: This method is to be used to load config objects for the Mapping Workbench only.
loadConfigsForMappingWorkbench(ClassLoader, boolean) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
INTERNAL: This method is to be used to load config objects for the Mapping Workbench only.
loadDocument(ClassLoader) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
INTERNAL: Load a session.xml document.
loadDocument(ClassLoader, boolean) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
INTERNAL: Load a session.xml document.
loadDriverClass(Session) - Method in class org.eclipse.persistence.sessions.DefaultConnector
INTERNAL: Ensure that the driver has been loaded and registered with the DriverManager.
loadDynamicProject(InputStream, DatabaseLogin, DynamicClassLoader) - Static method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Load a dynamic project from deployment XML creating dynamic types for all descriptors where the provided class name does not exist.
loadDynamicProject(String, DatabaseLogin, DynamicClassLoader) - Static method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Load a dynamic project from deployment XML creating dynamic types for all descriptors where the provided class name does not exist.
loadDynamicProject(Project, DatabaseLogin, DynamicClassLoader) - Static method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
 
loader - Variable in class org.eclipse.persistence.internal.helper.ConversionManager
 
loadFactor - Variable in class org.eclipse.persistence.indirection.IndirectMap
Store load factor for lazy init.
loadFactor - Variable in class org.eclipse.persistence.indirection.IndirectSet
Store load factor for lazy init.
loadFactor - Variable in class org.eclipse.persistence.internal.helper.IdentityHashSet
 
loadFactor - Variable in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
 
loadGroup - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Specifies indirection that should be instantiated before returning result
LoadGroup - Class in org.eclipse.persistence.queries
Purpose: Used to load specified relationship attributes and nested relationship attributes.
LoadGroup() - Constructor for class org.eclipse.persistence.queries.LoadGroup
 
LoadGroup(String) - Constructor for class org.eclipse.persistence.queries.LoadGroup
 
loadJoinedAttributes(ClassDescriptor, Object, CacheKey, AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
loadNext() - Method in class org.eclipse.persistence.queries.ScrollableCursor
Load the next object
loadPrevious() - Method in class org.eclipse.persistence.queries.ScrollableCursor
Load the previous object.
loadProjectConfig(ProjectConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Load a projectConfig from the session.xml file.
loadResultIntoSelectionObject() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Allow for the selection object of the query to be refreshed or put into the EclipseLink cache.
lobValueExceedsLimit(Object) - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
INTERNAL: Return if the LOB value size is larger than the limit, i.e.
lobValueLimits - Variable in class org.eclipse.persistence.platform.database.Oracle8Platform
The LOB value limits when the Locator is required for the writing
LOBValueWriter - Class in org.eclipse.persistence.internal.helper
INTERNAL:
LOBValueWriter(Accessor) - Constructor for class org.eclipse.persistence.internal.helper.LOBValueWriter
This is the default constructor for the class.
lobWriter - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
 
LOCAL_DATE - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
LOCAL_DATETIME - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
LOCAL_TIME - Static variable in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
 
LOCAL_TIME - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
localBase - Variable in class org.eclipse.persistence.internal.expressions.ConstantExpression
 
localBase - Variable in class org.eclipse.persistence.internal.expressions.LiteralExpression
 
localBase - Variable in class org.eclipse.persistence.internal.expressions.ParameterExpression
The opposite side of the relation, this is used for conversion of the parameter using the others mapping.
localConnection - Variable in class org.eclipse.persistence.sessions.coordination.TransportManager
The remote command connection to this transport
localContextProperties - Variable in class org.eclipse.persistence.sessions.coordination.TransportManager
Properties to obtain the context used for local JNDI access
localDate() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This gives access to the local date only on the database through expression.
localDate() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
LocalDate - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
localDateTime() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This gives access to the local date and time on the database through expression.
localDateTime() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
localDateTime() - Static method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL specific localDateTime operator.
LocalDateTime - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
localName - Variable in class org.eclipse.persistence.internal.oxm.Root
 
localTime - Variable in class org.eclipse.persistence.tools.profiler.Profile
 
localTime() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This gives access to the local time only on the database through expression.
localTime() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
localTime() - Static method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL specific localTime operator.
LocalTime - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
locate() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build locate operator i.e.
locate() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Evaluates the location of the "tofind" text within the string_exp text.
Builds Symfoware equivalent to locate(string_exp, tofind).
Symfoware: POSITION(tofind IN string_exp)
locate(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the position of str in this
locate(Object, Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the position of str in this, starting the search at fromIndex.
locate(String, int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the position of str in this, starting the search at fromIndex.
Locate - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
locate2() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build locate operator with 3 params i.e.
locate2() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Evaluates the location of the "tofind" text within the "string_exp" text, starting from the given start position.
Builds Symfoware equivalent to locate(string_exp, tofind, startpos).
Symfoware: LOCATE(tofind IN string_exp, startpos)
Locate2 - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
locate2Operator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
locate2Operator() - Static method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: create the Locate2 Operator for this platform
locateOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
locateOperator() - Static method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Build the Sybase equivalent to Locate
locator - Variable in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
locator - Variable in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
LOCATOR_CLASS - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
LOCATOR_CLASS_NAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
LocatorImpl() - Constructor for class org.eclipse.persistence.internal.oxm.record.DOMReader.LocatorImpl
 
Lock - Static variable in class org.eclipse.persistence.config.PessimisticLock
 
LOCK - Static variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
 
LOCK_END - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
LOCK_MAPPING_CANNOT_BE_READONLY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
LOCK_MAPPING_MUST_BE_READONLY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
LOCK_NOWAIT - Static variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
 
LOCK_ON_MERGE - Static variable in class org.eclipse.persistence.internal.sessions.MergeManager
Backdoor to disable merge locks.
LOCK_QUERIES_PROPERTY - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
LOCK_RESULT_PROPERTY - Static variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: This is the key for accessing unregistered and locked result in the query's properties.
LOCK_START_PREFIX - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
LOCK_START_PREFIX_WHERE - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
LOCK_START_SUFFIX - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
lockableMappings - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
lockAttribute - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
attribute name corresponding to optimistic lock field, set only if optimistic locking is used
lockedByMergeManager - Variable in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
lockedExpressions - Variable in class org.eclipse.persistence.internal.expressions.ForUpdateOfClause
 
lockFields - Variable in class org.eclipse.persistence.descriptors.SelectedFieldsLockingPolicy
 
lockFieldsByTable - Variable in class org.eclipse.persistence.descriptors.SelectedFieldsLockingPolicy
 
lockingClause - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
Used for pessimistic locking.
lockingMode - Variable in class org.eclipse.persistence.descriptors.PessimisticLockingPolicy
 
lockMapping - Variable in class org.eclipse.persistence.descriptors.VersionLockingPolicy
PERF: Cache the lock mapping if mapped with a direct mapping.
lockModeType - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Used when specifying a lock mode for the query
lockNotifyParent(Object, UnitOfWorkChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
INTERNAL:
LockNoWait - Static variable in class org.eclipse.persistence.config.PessimisticLock
 
lockOnChangeMode - Variable in class org.eclipse.persistence.descriptors.VersionLockingPolicy
 
lockRelationTableQuery - Variable in class org.eclipse.persistence.mappings.RelationTableMechanism
 
lockThread - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
save the currentThread for later comparison to the activeThread in case they don't match
lockValueFromObject(Object) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Retrieves the lock value from the object.
lockValueStored - Variable in class org.eclipse.persistence.descriptors.VersionLockingPolicy
 
log - Variable in class org.eclipse.persistence.eis.EISConnectionSpec
 
log() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
log(int, String) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(int, String) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Log a message that does not need to be translated.
log(int, String, Object) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(int, String, Object) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Log a message with one parameter that needs to be translated.
log(int, String, Object[]) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(int, String, Object[]) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: This method is called when the log request is from somewhere session is not available.
log(int, String, Object[], boolean) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(int, String, Object[], boolean) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: This method is called when the log request is from somewhere session is not available.
log(int, String, Object, Object) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(int, String, Object, Object) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Log a message with two parameters that needs to be translated.
log(int, String, Object, Object, Object) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(int, String, Object, Object, Object) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Log a message with three parameters that needs to be translated.
log(int, String, Object, Object, Object, Object) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(int, String, Object, Object, Object, Object) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Log a message with four parameters that needs to be translated.
log(int, String, String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
log(int, String, String, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
log(int, String, String, Object) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(int, String, String, Object) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Log a message with one parameter that needs to be translated.
log(int, String, String, Object[]) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
log(int, String, String, Object[]) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(int, String, String, Object[]) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: This method is called when the log request is from somewhere session is not available.
log(int, String, String, Object[], boolean) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(int, String, String, Object[], boolean) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: This method is called when the log request is from somewhere session is not available.
log(int, String, String, Object[], Accessor) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
log(int, String, String, Object[], Accessor, boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
log(int, String, String, Object, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
log(int, String, String, Object, Object) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(int, String, String, Object, Object) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Log a message with two parameters that needs to be translated.
log(int, String, String, Object, Object, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
log(int, String, String, Object, Object, Object) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(int, String, String, Object, Object, Object) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Log a message with three parameters that needs to be translated.
log(int, String, String, Object, Object, Object, Object) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(int, String, String, Object, Object, Object, Object) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Log a message with four parameters that needs to be translated.
log(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
log(SessionLogEntry) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Log the log entry.
log(SessionLogEntry) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
log(SessionLogEntry) - Method in class org.eclipse.persistence.logging.DefaultSessionLog
Log the entry.
log(SessionLogEntry) - Method in class org.eclipse.persistence.logging.JavaLog
PUBLIC:
log(SessionLogEntry) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: EclipseLink will call this method whenever something needs to be logged (messages, SQL, etc.).
log(SessionLogEntry) - Method in class org.eclipse.persistence.platform.server.ServerLog
PUBLIC:
log(SessionLogEntry) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Log the log entry.
Log - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
LOG_DEBUG - Static variable in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
 
LOG_ERROR - Static variable in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
 
LOG_INFO - Static variable in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
 
LOG_IO_ERROR - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
LOG_LEVEL_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
LOG_WARNING - Static variable in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
 
LogCategory - Enum in org.eclipse.persistence.logging
EclipseLink categories used for logging name space.
LogConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.log
INTERNAL:
LogConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.log.LogConfig
 
logDebug(String, Object[]) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
INTERNAL: Convenience logging methods.
logDebugAfterPublish(Object[], String) - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: Called from executeCommandInternal to log debugInfo right after sending the message.
logDebugBeforePublish(String) - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: Called from executeCommandInternal to log debugInfo right before sending the message.
logDebugJMSTopic(Message) - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL:
logDebugOnReceiveMessage(String) - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: Called when a message is received to log debugInfo: { toString(), messageId }.
logDebugWithoutLevelCheck(String, Object[]) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
logError(String, Object[]) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
LogFormatter - Class in org.eclipse.persistence.logging
Print a brief summary of a TopLink LogRecord in a human readable format.
LogFormatter() - Constructor for class org.eclipse.persistence.logging.LogFormatter
 
loggerCatagories - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
LoggerType - Class in org.eclipse.persistence.config
Logger type persistence property values.
LoggerType() - Constructor for class org.eclipse.persistence.config.LoggerType
 
Logging - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
LOGGING_CONNECTION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property "eclipselink.logging.connection" indicates if the connection in use should have its identity included in each log message.
LOGGING_EXCEPTIONS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property "eclipselink.logging.exceptions" indicates if exception stack traces should be included in each log message.
By default stack trace is logged for SEVERE all the time and at FINER level for WARNING or less.
LOGGING_FILE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.logging.file" property configures a file location where the log will be output to instead of standard out.
LOGGING_FILE_NAME_CANNOT_BE_EMPTY - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
LOGGING_LEVEL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.logging.level" property allows the default logging levels to be specified.
LOGGING_LOCALIZATION_STRING - Static variable in class org.eclipse.persistence.logging.JavaLog
 
LOGGING_LOGGER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.logging.logger" property specifies the type of logger.
LOGGING_PARAMETERS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
By default sql bind parameters are displayed in exceptions and logs when the log level is FINE or greater.
LOGGING_SESSION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property "eclipselink.logging.session" indicates if the session in use should have its identity included in each log message.
LOGGING_THREAD - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property "eclipselink.logging.thread" indicates if current thread should have its identity included in each log message.
LOGGING_TIMESTAMP - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.logging.timestamp" property configures if the current time stamp should be included in each log message.
LoggingLocalization - Class in org.eclipse.persistence.internal.localization
Purpose: This is for any logging related messages
LoggingLocalization() - Constructor for class org.eclipse.persistence.internal.localization.LoggingLocalization
 
LoggingOptionsConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.log
INTERNAL:
LoggingOptionsConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.log.LoggingOptionsConfig
 
logicalDelete(ModifyQuery, boolean) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL: Performs a logical delete (update) on the historical schema.
logicalDelete(ModifyQuery, boolean, boolean) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL: Performs a logical delete (update) on the historical schema.
LogicalExpression - Class in org.eclipse.persistence.internal.expressions
Used for logical AND and OR.
LogicalExpression() - Constructor for class org.eclipse.persistence.internal.expressions.LogicalExpression
 
LogicalExpression_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
logicalInsert(ObjectLevelModifyQuery, boolean) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL: Perform a logical insert into the historical schema, creating a new version of an object.
LogicalOperator - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
Operator types
login - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Store the login information that connected this accessor.
login - Variable in class org.eclipse.persistence.sessions.server.ConnectionPolicy
The login information used to create a JDBC connection or acquire one from an external pool/data-source.
login - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
login() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Connect to the database using the predefined login.
login() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Connect to the database using the predefined login.
login() - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Connect to the database using the predefined login.
login() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Connect to the database using the predefined login.
login(String, String) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Connect to the database using the given user name and password.
login(String, String) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Connect to the database using the predefined login.
login(String, String) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Connect to the database using the given user name and password.
login(Login) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Connect to the database using the given login.
login(Login) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Connect to the database using the given login.
Login<PLATFORM extends CorePlatform> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
Login - Interface in org.eclipse.persistence.sessions
Purpose: Define the information required to connect to an EclipseLink session.
LOGIN_BEFORE_ALLOCATING_CLIENT_SESSIONS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
loginAndDetectDatasource() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Connect to the database using the predefined login.
loginAndDetectDatasource() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Connect to the database using the predefined login.
loginAndDetectDatasource() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Connect to the database using the predefined login.
loginBeforeAllocatingClientSessions() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
LoginConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.login
INTERNAL:
LoginConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
logInfo(String, Object[]) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
LoginTime - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
logIOError(IOException) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
LogLevel - Enum in org.eclipse.persistence.logging
Log levels for EclipseLink logging.
logln(String) - Method in class org.eclipse.persistence.tools.PackageRenamer
 
logMessage(int, String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: RemoteCommandManager method.
logMessage(int, String) - Method in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
PUBLIC: Log a message to the application log output stream.
logMessage(int, String, Object[]) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
INTERNAL:
logMessage(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
Log a untranslated message to the EclipseLink log at FINER level.
logMessage(String) - Method in interface org.eclipse.persistence.sessions.Session
Log a untranslated message to the EclipseLink log at FINER level.
logMessageWithoutLevelCheck(int, String, Object[]) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
INTERNAL: Use this method in case the necessary logLevel has been confirmed by calling commandProcessor.shouldLogMessages method
logOperator() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Create the 10 based log operator for this platform.
logOperator() - Static method in class org.eclipse.persistence.platform.database.OraclePlatform
Create the log operator for this platform
logOperator() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the log10 operator.
Builds Symfoware equivalent to LOG(x).
Symfoware: (LN(x)/LN(10))
logout() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Disconnect from the database.
logout() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Disconnect from all databases.
logout() - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Disconnect from the database.
logout() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Logout the session, close the remote connection and release the hold resources
logout() - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Shutdown the server session, also shutdown all of the connection pools.
LOGOUT_WHILE_TRANSACTION_IN_PROGRESS - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
logoutWhileTransactionInProgress() - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
logParameter(StringBuilder, DatasourceCall.ParameterType, PLSQLargument, AbstractRecord, DatabasePlatform) - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
logParameter(StringBuilder, DatasourceCall.ParameterType, PLSQLargument, AbstractRecord, DatabasePlatform) - Method in enum org.eclipse.persistence.internal.helper.DatabaseType.DatabaseTypeHelper
 
logParameter(StringBuilder, DatasourceCall.ParameterType, PLSQLargument, AbstractRecord, DatabasePlatform) - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
logParameter(StringBuilder, DatasourceCall.ParameterType, PLSQLargument, AbstractRecord, DatabasePlatform) - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
logParameter(StringBuilder, DatasourceCall.ParameterType, PLSQLargument, AbstractRecord, DatabasePlatform) - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
INTERNAL: Append the parameter for logging purposes.
logParameter(StringBuilder, DatasourceCall.ParameterType, PLSQLargument, AbstractRecord, DatabasePlatform) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
logProfile() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
PUBLIC: Set whether after each query execution the profile result should be logged.
logProfileSummary() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
PUBLIC: Log a profile summary.
logProfileSummaryByClass() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
PUBLIC: Log a profile summary by class.
logProfileSummaryByQuery() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
PUBLIC: Log a profile summary by query.
logSessionString - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
When logging the name of the session is typed: class name + system hashcode.
logThrowable(int, String, Throwable) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
logThrowable(int, String, Throwable) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
logThrowable(int, String, Throwable) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Log a throwable with level.
logThrowable(int, Throwable) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
logThrowable(int, Throwable) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Log a Throwable with level.
logTxStateTrace(AbstractSession, String, Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
 
logTxTrace(AbstractSession, String, Object[]) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
 
logWarning(String, Object[]) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
logWarningWithoutLevelCheck(String, Object[]) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
LONG - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
LONG - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
LONG_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
longestTime - Variable in class org.eclipse.persistence.tools.profiler.Profile
 
LONGVARBINARY_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
LONGVARCHAR_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
lookup(Session) - Static method in class org.eclipse.persistence.dynamic.DynamicClassLoader
Lookup the DynamicConversionManager for the given session.
lookupActiveUnitOfWork() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return the unit of work associated with the active external transaction.
lookupActiveUnitOfWork(Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Return the unit of work associated with the active external transaction.
lookupField - Variable in class org.eclipse.persistence.internal.sessions.AbstractRecord
Optimize field creation for field name lookup.
lookupType - Variable in class org.eclipse.persistence.sessions.JNDIConnector
Deprecated.
LowLevelProcessor<A,​V> - Interface in org.eclipse.persistence.internal.cache
Able to process computable tasks.
LT - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
ltrim2Operator() - Method in class org.eclipse.persistence.platform.database.DB2Platform
DB2 does not support untyped parameter binding for <operand2>
ltrim2Operator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
ltrim2Operator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Enable binding since DB2 disables it
ltrimOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.

M

m_classLoader - Variable in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
 
m_comparator - Variable in class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
 
m_descriptor - Variable in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
 
m_hasCheckedForUnmappedFields - Variable in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
 
m_localResources - Variable in class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
 
m_logLevels - Variable in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
 
m_lookForParentMapping - Variable in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
 
m_mappedQueryKeyFields - Variable in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
 
m_name - Variable in class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPoolConfig
 
m_parentClass - Variable in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
 
m_parentDescriptor - Variable in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
 
m_parentMapping - Variable in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
 
m_query - Variable in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
 
m_queryKeyFields - Variable in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
 
m_sessions - Variable in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
 
m_shouldHandleUnmappedFields - Variable in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
 
m_unmappedFieldsQuery - Variable in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
 
m_unmappedQueryKeyFields - Variable in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
 
m_updateClauses - Variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
m_updateClauses - Variable in class org.eclipse.persistence.queries.UpdateAllQuery
 
main - Variable in class org.eclipse.persistence.descriptors.ReturningPolicy
The following attributes are initialized by initialize() method.
main(String[]) - Static method in class org.eclipse.persistence.tools.PackageRenamer
Main method to run the PackageRenamer
main(String[]) - Static method in class org.eclipse.persistence.Version
 
MAIN_SIZE - Static variable in class org.eclipse.persistence.descriptors.ReturningPolicy
 
MAINTAIN_CACHE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.maintain-cache"
maintainCache() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Set for the identity map (cache) to be maintained.
makeVectorFromObject(Object) - Static method in class org.eclipse.persistence.internal.helper.Helper
Make a Vector from the passed object.
manager - Static variable in class org.eclipse.persistence.sessions.factories.SessionManager
 
ManualQueryKeyExpression - Class in org.eclipse.persistence.internal.expressions
This class represents a "query key" that isn't really there in the descriptors.
ManualQueryKeyExpression() - Constructor for class org.eclipse.persistence.internal.expressions.ManualQueryKeyExpression
 
ManualQueryKeyExpression(String, Expression) - Constructor for class org.eclipse.persistence.internal.expressions.ManualQueryKeyExpression
 
ManualQueryKeyExpression(String, Expression, ClassDescriptor) - Constructor for class org.eclipse.persistence.internal.expressions.ManualQueryKeyExpression
 
ManyToManyMapping - Class in org.eclipse.persistence.mappings
Purpose: Many to many mappings are used to represent the relationships between a collection of source objects and a collection of target objects.
ManyToManyMapping() - Constructor for class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Default constructor.
ManyToManyQueryKey - Class in org.eclipse.persistence.mappings.querykeys
Purpose:Represents a m-m join query.
ManyToManyQueryKey() - Constructor for class org.eclipse.persistence.mappings.querykeys.ManyToManyQueryKey
 
ManyToOneMapping - Class in org.eclipse.persistence.mappings
Purpose: Define the relationship to be a ManyToOne.
ManyToOneMapping() - Constructor for class org.eclipse.persistence.mappings.ManyToOneMapping
PUBLIC: Default constructor.
Map - Static variable in class org.eclipse.persistence.config.ResultType
A Map of key value pairs is returned.
MAP - Static variable in class org.eclipse.persistence.queries.DataReadQuery
A Map (DatabaseRecord) is returned for each row.
Map_Class - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
Map_Entry_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
MAP_ENTRY_EXPRESSION_FOR_NON_COLLECTION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
MAP_ENTRY_EXPRESSION_FOR_NON_MAP - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
MAP_KEY_CANNOT_USE_INDIRECTION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MAP_KEY_IS_NULL - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
MAP_KEY_NOT_COMPARABLE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
MAP_KEY_NOT_DECLARED_IN_ITEM_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
mapBooleans() - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
PUBLIC: This is a very specific protocol which maps fieldValues "T" and "F" to true and false respectively.
MapChangeEvent - Class in org.eclipse.persistence.descriptors.changetracking
Purpose: Define a change event for Map types.
MapChangeEvent(Object, String, Object, Object, Object, int, boolean) - Constructor for class org.eclipse.persistence.descriptors.changetracking.MapChangeEvent
PUBLIC: Create a MapChangeEvent for an object based on the property name, the updated Map, the new Key and the new Value and change type (add or remove)
MapChangeEvent_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
MapComponentMapping - Interface in org.eclipse.persistence.mappings.foundation
A MapComponentMapping is any mapping that can be used as the key or the value in a mapping that uses a MappedKeyMapContainerPolicy.
MapContainerPolicy - Class in org.eclipse.persistence.internal.queries
Purpose: A MapContainerPolicy is ContainerPolicy whose container class implements the Map interface.
MapContainerPolicy() - Constructor for class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Construct a new policy.
MapContainerPolicy(Class<?>) - Constructor for class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Construct a new policy for the specified class.
MapContainerPolicy(String) - Constructor for class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Construct a new policy for the specified class name.
MapContainerPolicy.MapContainerPolicyIterator - Class in org.eclipse.persistence.internal.queries
INTERNAL: This inner class is used to iterate through the Map.Entry s of a Map.
MapContainerPolicyIterator(Map) - Constructor for class org.eclipse.persistence.internal.queries.MapContainerPolicy.MapContainerPolicyIterator
 
mapEntry() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a Map.Entry containing the key and the value from a mapping that maps to a java.util.Map This expression can only be used as a return value in a ReportQuery and cannot be used as part of the WHERE clause in any query EclipseLink: eb.get("mapAttribute").mapEntry()
MapEntryExpression - Class in org.eclipse.persistence.internal.expressions
 
MapEntryExpression() - Constructor for class org.eclipse.persistence.internal.expressions.MapEntryExpression
 
MapEntryExpression(Expression) - Constructor for class org.eclipse.persistence.internal.expressions.MapEntryExpression
 
mapEntryExpressionForNonCollection(Expression, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
mapEntryExpressionForNonMap(Expression, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
mapGenders() - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
PUBLIC: This is a very specific protocol which maps fieldValues "F" and "M" to "Female" and "Male" respectively.
mapKey() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return the key from a mapping that maps to a java.util.Map This expression can be used either in as a return value in a ReportQuery or in the WHERE clause in a query EclipseLink: eb.get("mapAttribute").mapKey()
mapKeyCannotUseIndirection(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Proxy property corresponding to the specified proxy type was not found.
MapKeyConvert - Annotation Type in org.eclipse.persistence.annotations
The MapKeyConvert annotation specifies that a named converter should be used with the corresponding mapped attribute key column.
mapKeyHasChanged(Object, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Return whether the element's user-defined Map key has changed since it was cloned from the original version.
mapKeyHasChanged(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Return whether the element's user-defined Map key has changed since it was cloned from the original version.
mapKeyHasChanged(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Return whether the element's user-defined Map key has changed since it was cloned from the original version.
mapKeyHasChanged(Object, AbstractSession) - Method in interface org.eclipse.persistence.mappings.structures.ArrayCollectionMapping
Return whether the element's user-defined Map key has changed since it was cloned from the original version.
mapKeyIsNull(Object, Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
MapKeyMapping - Interface in org.eclipse.persistence.mappings.foundation
MapKeyMapping is implemented by DatabaseMappings that can be used to map the key in a map that uses a MappedKeyMapContainerPolicy.
mapKeyNotComparable(Object, Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
mapKeyNotDeclaredInItemClass(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
MapNamespacePrefixMapper - Class in org.eclipse.persistence.internal.oxm.record.namespaces
Implementation of NamespacePrefixMapper.
MapNamespacePrefixMapper(Map<String, String>) - Constructor for class org.eclipse.persistence.internal.oxm.record.namespaces.MapNamespacePrefixMapper
 
mapOwner - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
MAPPED - Static variable in class org.eclipse.persistence.descriptors.ReturningPolicy
 
MAPPED - Static variable in class org.eclipse.persistence.eis.EISDescriptor
Define the valid data formats that the descriptor can map to.
mappedBy - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Stores JPA metadata about whether another mapping is the owning mapping.
mappedBy() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlInverseReference
 
mappedClass - Variable in class org.eclipse.persistence.descriptors.CMPPolicy
Class originally mapped, before anything was generated.
MappedInteraction - Class in org.eclipse.persistence.eis.interactions
Defines the specification for a call to a JCA interaction using Mapped records.
MappedInteraction() - Constructor for class org.eclipse.persistence.eis.interactions.MappedInteraction
Default constructor.
MappedKeyMapContainerPolicy - Class in org.eclipse.persistence.internal.queries
A MappedKeyMapContainerPolicy should be used for mappings to implementers of Map.
MappedKeyMapContainerPolicy() - Constructor for class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Construct a new policy.
MappedKeyMapContainerPolicy(Class<?>) - Constructor for class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Construct a new policy for the specified class.
MappedKeyMapContainerPolicy(String) - Constructor for class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Construct a new policy for the specified class name.
mappedSuperclassDescriptors - Variable in class org.eclipse.persistence.sessions.Project
Mapped Superclasses (JPA 2) collection of parent non-relational descriptors keyed on MetadataClass without creating a compile time dependency on JPA.
mapper - Variable in class org.eclipse.persistence.internal.oxm.Marshaller
 
mapping - Variable in class org.eclipse.persistence.descriptors.CMPPolicy.KeyIsElementAccessor
 
mapping - Variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
mapping - Variable in class org.eclipse.persistence.history.HistoryPolicy
 
mapping - Variable in class org.eclipse.persistence.internal.dynamic.ValuesAccessor
 
mapping - Variable in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
Cache the mapping for performance.
mapping - Variable in class org.eclipse.persistence.internal.indirection.BatchValueHolder
 
mapping - Variable in class org.eclipse.persistence.internal.indirection.CacheBasedValueHolder
 
mapping - Variable in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
 
mapping - Variable in class org.eclipse.persistence.internal.indirection.ProtectedValueHolder
 
mapping - Variable in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
The mapping for the attribute.
mapping - Variable in class org.eclipse.persistence.internal.oxm.Reference
 
mapping - Variable in class org.eclipse.persistence.internal.queries.ReportItem
Mapping which relates field to attribute, used to convert value and determine reference descriptor
mapping - Variable in class org.eclipse.persistence.internal.sessions.ChangeRecord
This attribute stores the mapping along with the attribute so that the mapping does not need to be looked up
mapping - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
 
mapping - Variable in class org.eclipse.persistence.mappings.converters.ClassInstanceConverter
 
mapping - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
mapping - Variable in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
 
mapping - Variable in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
 
mapping - Variable in class org.eclipse.persistence.mappings.transformers.MethodBasedAttributeTransformer
 
mapping - Variable in class org.eclipse.persistence.mappings.transformers.MethodBasedFieldTransformer
 
Mapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
MAPPING_ANNOTATIONS_APPLIED_TO_TRANSIENT_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MAPPING_DOES_NOT_OVERRIDE_VALUEFROMROWINTERNALWITHJOIN - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MAPPING_FILE_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MAPPING_FOR_EXPRESSION_DOES_NOT_SUPPORT_JOINING - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
MAPPING_FOR_FIELDRESULT_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
MAPPING_FOR_SEQUENCE_NUMBER_FIELD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
MAPPING_METADATA_APPLIED_TO_METHOD_WITH_ARGUMENTS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
mappingAnnotationsAppliedToTransientAttribute(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
mappingCanNotBeReadOnly(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
MappingCompare - Class in org.eclipse.persistence.internal.helper
INTERNAL: Use to Sort The mappings in ClassDescriptor, Mappings are either DirectToField, which must be at the top or other Avoid using this class as sun.misc is not part of many VM's like Netscapes.
MappingCompare() - Constructor for class org.eclipse.persistence.internal.helper.MappingCompare
 
mappingCriteria(Expression) - Method in class org.eclipse.persistence.internal.expressions.ManualQueryKeyExpression
 
mappingCriteria(Expression) - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
INTERNAL: Mapping criteria will be provided by the base expression
mappingCriteria(Expression) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
mappingCriteria(Expression) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
mappingDoesNotOverrideValueFromRowInternalWithJoin(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
mappingFileNotFound(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
mappingForAttributeIsMissing(String, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
mappingForExpressionDoesNotSupportJoining(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
mappingForFieldResultNotFound(String[], int) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
mappingForSequenceNumberField(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
mappingLogicalDelete(ModifyQuery, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL: Performs a logical delete (update) on the historical schema.
mappingLogicalInsert(DataModifyQuery, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL: Performs a logical insert into the historical schema.
mappingMetadataAppliedToMethodWithArguments(Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
MappingNodeValue - Class in org.eclipse.persistence.internal.oxm
A node value corresponding to mapping.
MappingNodeValue() - Constructor for class org.eclipse.persistence.internal.oxm.MappingNodeValue
 
mappingQueries - Variable in class org.eclipse.persistence.queries.BatchFetchPolicy
PERF: Used internally to store the prepared mapping queries.
mappings - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
mappings() - Method in class org.eclipse.persistence.internal.jpa.jpql.ConstructorQueryMappings
Returns a non-null Iterable over the ordered list of DatabaseMapping objects that represents the parameter arguments defined in the constructor expression.
mappingsByAttribute - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Mappings keyed by attribute name.
mappingsByField - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Mappings keyed by database field.
mappingsPostCalculateChanges - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
Mappings that require postCalculateChanges method to be called
mappingsPostCalculateChangesOnDeleted - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
Mappings that require postCalculateChangesOnDeleted method to be called
mappingsRequiringInitialization - Variable in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
These properties require initialization when a new instance is created.
mapResponses() - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
PUBLIC: This is a very specific protocol which maps fieldValues "Y" and "N" to "Yes" and "No" respectively.
mapsIdMappings - Variable in class org.eclipse.persistence.mappings.AggregateObjectMapping
List of maps id mappings that need to be set to read only at initialize time on their cloned aggregate mappings.
mapsIdValue - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
A mapsId value.
mapTableIndexToExpression(Expression, TreeMap, List<DatabaseTable>) - Static method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: The method searches for expressions that join two tables each in a given expression.
mapTableToExpression(Expression, Vector) - Static method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: The method searches for expressions that join two tables each in a given expression.
mapThreadToThreadName(List<Thread>) - Method in class org.eclipse.persistence.internal.helper.type.CacheKeyToThreadRelationships
Map a list of threads to their thread names
MariaDB - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
MariaDBPlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides MariaDB specific behavior.
MariaDBPlatform() - Constructor for class org.eclipse.persistence.platform.database.MariaDBPlatform
 
mark(int) - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Mark the present position in the stream.
markCommitCompleted(Object) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Mark the commit of the object as being fully completed.
marker - Variable in class org.eclipse.persistence.queries.CursoredStream
Marker for backing up.
markIgnoreCommit(Object) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
 
markInProgress() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
markNotVisited() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
markPostModifyCommitInProgress(Object) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Add an object as being in progress of being committed.
markPreModifyCommitInProgress(Object) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Add an object as being in progress of being committed.
markShallowCommit(Object) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Mark the object as shallow committed.
markSupported() - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Tests if this input stream supports the mark and reset methods.
markTransactionForRollback() - Method in interface org.eclipse.persistence.sessions.ExternalTransactionController
INTERNAL: Marks the external transaction for rollback only.
markTransactionForRollback() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Mark the external transaction for rollback.
markTransactionForRollback_impl() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Mark the external transaction for rollback.
markTransactionForRollback_impl() - Method in class org.eclipse.persistence.transaction.JTA11TransactionController
INTERNAL: Mark the external transaction for rollback.
markTransactionForRollback_impl() - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Mark the external transaction for rollback.
markVisited() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
marshal(Object, OutputStream) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
PUBLIC: Convert the given object to XML and update the given outputStream with that XML Document
marshal(Object, Writer) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
PUBLIC: Convert the given object to XML and update the given writer with that XML Document
marshal(Object, Result) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
PUBLIC: Convert the given object to XML and update the given result with that XML Document
marshal(Object, Result) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
PUBLIC: Convert the given object to XML and update the given result with that XML Document
marshal(Object, AbstractSession, MarshalRecord) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
Convert the given object to XML and update the given marshal record with that XML Document.
marshal(Object, MarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Convert the given object to XML and update the given marshal record with that XML Document.
marshal(Object, MarshalRecord, ABSTRACT_SESSION, DESCRIPTOR, boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Convert the given object to XML and update the given marshal record with that XML Document.
marshal(Object, Node) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
PUBLIC:
marshal(Object, Node) - Method in class org.eclipse.persistence.oxm.XMLBinder
 
marshal(Object, ContentHandler) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
PUBLIC: Convert the given object to XML and update the given contentHandler with that XML Document
marshal(Object, ContentHandler, LexicalHandler) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
PUBLIC: Convert the given object to XML and update the given contentHandler with that XML Document
marshal(NodeValue, XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalContext
Perform a marshal using the NodeValue parameter.
marshal(NodeValue, XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectMarshalContext
 
marshal(NodeValue, XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedMarshalContext
 
marshal(NodeValue, XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, XPathFragment) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalContext
 
marshal(NodeValue, XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectMarshalContext
 
marshal(NodeValue, XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedMarshalContext
 
marshal(MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, Marshaller, MarshalContext, XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.CollectionGroupingElementNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.FieldTransformerNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL:
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.TypeNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyObjectMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceObjectMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
Handle the marshal operation for this NodeValue.
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
Override the method in XPathNode such that the marshaller can be set on the marshalRecord - this is required for XMLConverter usage.
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLDirectMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
Override the method in XPathNode such that the marshaller can be set on the marshalRecord - this is required for XMLConverter usage.
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectReferenceMappingNodeValue
Handle the marshal operation for this NodeValue's XMLField.
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathObjectMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, Marshaller) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL: This method is no longer required as now MarshalRecord maintains a reference to the XMLMarshaller.
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.FieldTransformerNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL: Override this method if the NodeValue is applicable to sequenced objects.
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyObjectMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceObjectMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLDirectMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectReferenceMappingNodeValue
Handle the marshal operation for this NodeValue's XMLField.
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathObjectMappingNodeValue
 
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, MarshalContext, XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL:
marshal(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, MarshalContext, XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
MARSHAL_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
marshalAttributes(MarshalRecord, Object, CoreAbstractSession) - Method in interface org.eclipse.persistence.internal.oxm.ObjectBuilder
 
marshalAttributes(MarshalRecord, Object, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
marshalAttributes(MarshalRecord, Object, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
MarshalContext - Interface in org.eclipse.persistence.internal.oxm.record
The MarshalContext allows mappings to be marshalled differently depending on the type of object.
marshalException(Exception) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
marshaller - Variable in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
Marshaller<CHARACTER_ESCAPE_HANDLER extends CharacterEscapeHandler,​CONTEXT extends Context,​MARSHALLER_LISTENER extends Marshaller.Listener,​MEDIA_TYPE extends MediaType,​NAMESPACE_PREFIX_MAPPER extends NamespacePrefixMapper> - Class in org.eclipse.persistence.internal.oxm
 
Marshaller(CONTEXT) - Constructor for class org.eclipse.persistence.internal.oxm.Marshaller
 
Marshaller(Marshaller) - Constructor for class org.eclipse.persistence.internal.oxm.Marshaller
Copy constructor
Marshaller.Listener - Interface in org.eclipse.persistence.internal.oxm
An implementation of Marshaller.Listener can be set on an Marshaller to provide additional behaviour during marshal operations.
marshalNullRepresentation - Variable in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
This enum instance determines what to write out during a marshal operation.
marshalProperties - Variable in class org.eclipse.persistence.internal.oxm.Marshaller
 
marshalRecord - Variable in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
MarshalRecord<MARSHALLER extends Marshaller> - Class in org.eclipse.persistence.oxm.record
A MarshalRecord encapsulates the marshal target.
MarshalRecord<ABSTRACT_SESSION extends CoreAbstractSession,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​NAMESPACE_RESOLVER extends NamespaceResolver> - Interface in org.eclipse.persistence.internal.oxm.record
This class represents marshal record behaviour that is specific to the SAX platform.
MarshalRecord() - Constructor for class org.eclipse.persistence.oxm.record.MarshalRecord
 
MarshalRecord.CycleDetectionStack<E> - Class in org.eclipse.persistence.internal.oxm.record
A Stack-like List, used to detect object cycles during marshal operations.
MarshalRecordContentHandler - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
MarshalRecordContentHandler(MarshalRecord, NamespaceResolver) - Constructor for class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
MarshalSAXParseException(String, String, String, int, int, Exception, Object) - Constructor for exception org.eclipse.persistence.oxm.record.ValidatingMarshalRecord.MarshalSAXParseException
 
marshalSelfAttributes(MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, Marshaller) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
Marshal any 'self' mapped attributes.
marshalSelfAttributes(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, Marshaller) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL: Marshal any 'self' mapped attributes.
marshalSelfAttributes(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, Marshaller) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
Marshal any 'self' mapped attributes.
marshalSelfAttributes(XPathFragment, MarshalRecord, Object, CoreAbstractSession, NamespaceResolver, Marshaller) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.CollectionGroupingElementNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in interface org.eclipse.persistence.internal.oxm.ContainerValue
Marshal only one of the values from the collection.
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.FieldTransformerNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL: This method provides an optimization in cases where the value has already been calculated.
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.TypeNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyObjectMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceObjectMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLDirectMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectReferenceMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathMappingNodeValue
 
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext, XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL: This method provides an optimization in cases where the value has already been calculated.
marshalSingleValue(XPathFragment, MarshalRecord, Object, Object, CoreAbstractSession, NamespaceResolver, MarshalContext, XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
marshalWithoutRootElement(ObjectBuilder, Object, Descriptor, Root, boolean) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
INTERNAL:
marshalWithoutRootElement(ObjectBuilder, Object, Descriptor, Root, boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
marshalWithoutRootElement(ObjectBuilder, Object, Descriptor, Root, boolean) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
INTERNAL
matchFieldOrder(ResultSet, DatabaseAccessor, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Allow for the field order to be matched if required.
max - Static variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
 
max() - Method in class org.eclipse.persistence.platform.database.DB2Platform
Disable binding support.
max(Expression, int) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
max(Expression, Object) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
MAX_BATCH_WRITING_SIZE_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
MAX_BLOB - Static variable in class org.eclipse.persistence.platform.database.DerbyPlatform
 
MAX_CLOB - Static variable in class org.eclipse.persistence.platform.database.DerbyPlatform
 
MAX_CONNECTIONS - Static variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
MAX_ROW - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
MAX_SIZE_LESS_THAN_MIN_SIZE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MAX_TRIES - Static variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
MAX_TRIES_EXCEDED_FOR_LOCK_ON_BUILD_OBJECT - Static variable in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
MAX_TRIES_EXCEDED_FOR_LOCK_ON_CLONE - Static variable in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
MAX_TRIES_EXCEDED_FOR_LOCK_ON_MERGE - Static variable in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
MAX_WAIT - Static variable in class org.eclipse.persistence.internal.helper.WriteLockManager
 
MAX_WAIT_TRIES - Static variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
maxBatchSize - Variable in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
Allow for the batch size to be set as many database have strict limits.
maxBatchWritingSize - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allow for the batch size to be set as many database have strict limits.
MaxDB - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
MaxDBPlatform - Class in org.eclipse.persistence.platform.database
Database Platform for SAP MaxDB.
MaxDBPlatform() - Constructor for class org.eclipse.persistence.platform.database.MaxDBPlatform
 
maximum() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This represents the aggregate function Maximum.
maximum() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the MAXIMUM operator.
Maximum - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
maximumNumericValues() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Builds a table of maximum numeric values keyed on java class.
maximumNumericValues() - Method in class org.eclipse.persistence.platform.database.AccessPlatform
Builds a table of maximum numeric values keyed on java class.
maximumNumericValues() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Builds a table of maximum numeric values keyed on java class.
maximumNumericValues() - Method in class org.eclipse.persistence.platform.database.DBasePlatform
Builds a table of minimum numeric values keyed on java class.
maximumNumericValues() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Builds a table of maximum numeric values keyed on java class.
maximumNumericValues() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Builds a table of maximum numeric values keyed on java class.
maximumNumericValues() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Builds a table of maximum numeric values keyed on java class.
maximumNumericValues() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Builds a table of maximum numeric values keyed on java class.
maximumResultSets - Variable in class org.eclipse.persistence.queries.QueryResultsCachePolicy
Specifies the cache size.
maxNumberOfConnections - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
maxNumberOfNonPooledConnections - Variable in class org.eclipse.persistence.sessions.server.ServerSession
 
maxPrecision - Variable in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
maxResults - Variable in class org.eclipse.persistence.queries.ReadQuery
Stores the JPA maxResult settings for a NamedQuery
MAXROW_FIELD - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Following fields are used to bind MaxResults and FirstRow settings into the query instead of using the values stored in the call.
maxRows - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
maxRows - Variable in class org.eclipse.persistence.queries.ReadQuery
Used for retrieve limited rows through the query.
maxScale - Variable in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
maxSize - Variable in class org.eclipse.persistence.internal.helper.ConcurrentFixedCache
 
maxSize - Variable in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
The initial or maximum size of the cache depending upon the concrete implementation.
maxSizeLessThanMinSize() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
MAXTRIES - Static variable in class org.eclipse.persistence.internal.helper.WriteLockManager
 
maxTriesLockOnBuildObjectExceded(Thread, Thread) - Static method in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
maxTriesLockOnCloneExceded(Object) - Static method in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
maxTriesLockOnMergeExceded(Object) - Static method in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
mayHaveNullInPrimaryKey - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
indicates whether part of primary key is unmapped - may happen only in case AggregateObject or AggregateCollection descriptor.
MBeanDevelopmentServices - Class in org.eclipse.persistence.services.mbean
Purpose: Provide a dynamic interface into the EclipseLink Identity Map Manager.
MBeanDevelopmentServices(Session) - Constructor for class org.eclipse.persistence.services.mbean.MBeanDevelopmentServices
 
MBeanDevelopmentServicesMBean - Interface in org.eclipse.persistence.services.mbean
Purpose: Provide a dynamic interface into the EclipseLink Identity Map Manager.
MBeanGlassfishRuntimeServices - Class in org.eclipse.persistence.services.glassfish
Purpose: Provide a dynamic interface into the EclipseLink Session.
MBeanGlassfishRuntimeServices(Session) - Constructor for class org.eclipse.persistence.services.glassfish.MBeanGlassfishRuntimeServices
 
MBeanGlassfishRuntimeServicesMBean - Interface in org.eclipse.persistence.services.glassfish
Purpose: Provide a dynamic interface into the EclipseLink Session.
MBeanJBossRuntimeServices - Class in org.eclipse.persistence.services.jboss
Purpose: Provide a dynamic interface into the EclipseLink Session.
MBeanJBossRuntimeServices(Session) - Constructor for class org.eclipse.persistence.services.jboss.MBeanJBossRuntimeServices
 
MBeanJBossRuntimeServicesMBean - Interface in org.eclipse.persistence.services.jboss
Purpose: Provide a dynamic interface into the EclipseLink Session.
MBeanRuntimeServices - Class in org.eclipse.persistence.services.mbean
Purpose: Provide a dynamic interface into the EclipseLink Session.
MBeanRuntimeServices(Session) - Constructor for class org.eclipse.persistence.services.mbean.MBeanRuntimeServices
 
MBeanRuntimeServicesMBean - Interface in org.eclipse.persistence.services.mbean
Purpose: Provide a dynamic interface into the EclipseLink Session.
mBeanServer - Variable in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
Cache the ServerPlatform MBeanServer for performance
MBeanWebLogicRuntimeServices - Class in org.eclipse.persistence.services.weblogic
Purpose: Provide a dynamic interface into the EclipseLink Session.
MBeanWebLogicRuntimeServices(Session) - Constructor for class org.eclipse.persistence.services.weblogic.MBeanWebLogicRuntimeServices
 
MBeanWebLogicRuntimeServicesMBean - Interface in org.eclipse.persistence.services.weblogic
Purpose: Provide a dynamic interface into the EclipseLink Session.
MBeanWebSphereRuntimeServices - Class in org.eclipse.persistence.services.websphere
Purpose: Provide a dynamic interface into the EclipseLink Session.
MBeanWebSphereRuntimeServices(Session) - Constructor for class org.eclipse.persistence.services.websphere.MBeanWebSphereRuntimeServices
 
MBeanWebSphereRuntimeServicesMBean - Interface in org.eclipse.persistence.services.websphere
Purpose: Provide a dynamic interface into the EclipseLink Session.
mechanism - Variable in class org.eclipse.persistence.mappings.ManyToManyMapping
Mechanism holds relationTable and all fields and queries associated with it.
mechanism - Variable in class org.eclipse.persistence.mappings.OneToOneMapping
Mechanism holds relationTable and all fields and queries associated with it.
mediaType - Variable in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
MediaType - Enum in org.eclipse.persistence.oxm
This enum represents the different media types supported by EclipseLink MOXy.
MediaType - Interface in org.eclipse.persistence.internal.oxm
This interface represents the different media types supported by EclipseLink MOXy.
mediaTypeChanged() - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
mediaTypeChanged() - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
mediaTypeChanged() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
Memoizer<A,​V> - Class in org.eclipse.persistence.internal.cache
Memoizer for computing resource expensive tasks asynchronously & concurrently.
Memoizer() - Constructor for class org.eclipse.persistence.internal.cache.Memoizer
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
Merge - Static variable in class org.eclipse.persistence.config.FlushClearCache
Call to clear method causes to drop from EntityManager cache only the objects that haven't been flushed.
Merge - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
mergeAddRemoveChanges(Object, Object, DirectCollectionChangeRecord, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Merge changes by adding and removing from the change record to the target object, and its delegate object if instance of IndirectCollection.
mergeAttributeValue(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
Merge the attribute values.
mergeBmpAndWsEntities() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: BMP and Websphere CMP entities have to be merged if they are registered in the unit of work.
mergeCascadeParts(ObjectChangeSet, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Merge changes from the source to the target object.
mergeChanges(Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Recursively merge changes in the object dependent on the merge policy.
mergeChanges(CollectionChangeRecord, Object, boolean, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Merge changes from the source to the target object.
mergeChanges(CollectionChangeRecord, Object, boolean, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Merge changes from the source to the target object.
mergeChanges(CollectionChangeRecord, Object, boolean, MergeManager, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Merge changes from the source to the target object.
mergeChanges(CollectionChangeRecord, Object, boolean, MergeManager, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Merge changes from the source to the target object.
MergeChangeSetCommand - Class in org.eclipse.persistence.sessions.coordination
Purpose: Provide a remote command implementation for remote cache merges of changes.
MergeChangeSetCommand() - Constructor for class org.eclipse.persistence.sessions.coordination.MergeChangeSetCommand
 
mergeChangesForRefreshingRemoteObject(Object) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Recursively merge the RMI clone from the server into the client unit of work working copy.
mergeChangesFromChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTERNAL: Merge the changes to all objects to session's cache.
mergeChangesIntoDistributedCache(Object, ObjectChangeSet) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Merge the changes specified within the changeSet into the cache.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: If the mapping has a foreign key, it is order, so must use a different merge.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMappingHelper
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ArrayCollectionMappingHelper
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
INTERNAL: Merge changes from the source to the target object.
mergeChangesIntoObject(Object, ChangeRecord, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
mergeChangesIntoObject(Object, ObjectChangeSet, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Merge changes between the objects, this merge algorithm is dependent on the merge manager.
mergeChangesIntoObject(Object, ObjectChangeSet, Object, MergeManager, AbstractSession, boolean, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Merge changes between the objects, this merge algorithm is dependent on the merge manager.
mergeChangesIntoParent() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Merge the changes to all objects to the parent.
mergeChangesIntoParent() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Merge the changes to all objects to the parent.
mergeChangesIntoSharedCache() - Method in class org.eclipse.persistence.queries.ModifyAllQuery
INTERNAL: After execution we need to merge the changes into the shared cache, unless the query has been tagged to bypass on the store.
mergeChangesOfCloneIntoWorkingCopy(Object) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Recursively merge to rmi clone into the unit of work working copy.
mergeChangesOfOriginalIntoWorkingCopy(Object) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Recursively merge to original from its parent into the clone.
mergeChangesOfWorkingCopyIntoOriginal(Object, ObjectChangeSet) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Recursively merge to clone into the original in its parent.
mergeChangesOfWorkingCopyIntoOriginal(Object, ObjectChangeSet, ClassDescriptor, AbstractSession, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Recursively merge to clone into the original in its parent.
mergeChangesOfWorkingCopyIntoRemote(Object) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Recursively merge changes in the object dependent on the merge policy.
mergeClientIntoServerValueHolder(RemoteValueHolder<?>, MergeManager) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL Replace the client value holder with the server value holder, after copying some of the settings from the client value holder.
mergeClone(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Merge the attributes of the clone into the unit of work copy.
mergeClone(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Merge the attributes of the clone into the unit of work copy.
mergeClone(Object, int, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Merge the attributes of the clone into the unit of work copy.
mergeCloneIntoWorkingCopy() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
This can be used by the user for merging clones from RMI into the unit of work.
mergeClonesAfterCompletion() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: for synchronized units of work, merge changes into parent
mergeCloneWithReferences(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Merge the attributes of the clone into the unit of work copy.
mergeCloneWithReferences(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Merge the attributes of the clone into the unit of work copy.
mergeCloneWithReferences(Object, int) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Merge the attributes of the clone into the unit of work copy.
mergeCloneWithReferences(Object, int, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Merge the attributes of the clone into the unit of work copy.
mergeCloneWithReferences(Object, MergeManager) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Merge the attributes of the clone into the unit of work copy.
mergeCloneWithReferences(Object, MergeManager) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Merge the attributes of the clone into the unit of work copy.
mergeCloneWithReferencesIntoWorkingCopy() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
This is used during the merge of dependent objects referencing independent objects, where you want the independent objects merged as well.
mergedNewObjects - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
Used to keep track of merged new objects.
mergeFrom(AbstractRecord) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: Merge the provided row into this row.
mergeIntoDistributedCache() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
This is used during cache synchronization to merge the changes into the distributed cache.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: If the mapping has a foreign key, it is order, so must use a different merge.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMappingHelper
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Merge the contents of one object into another, this merge algorithm is dependent on the merge manager.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ArrayCollectionMappingHelper
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
INTERNAL: Merge changes from the source to the target object.
mergeIntoObject(Object, boolean, Object, MergeManager, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
mergeIntoObject(Object, ObjectChangeSet, boolean, Object, MergeManager, AbstractSession, boolean, boolean, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Merge the contents of one object into another, this merge algorithm is dependent on the merge manager.
mergeIntoParentCache(CacheKey, CacheKey) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: This method should merge changes from the parent into the child.
mergeIntoParentCache(CacheKey, CacheKey) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: This method should merge changes from the parent into the child.
mergeIntoParentCache(CacheKey, CacheKey) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: This method should merge changes from the parent into the child.
mergeIntoParentCache(UnitOfWorkImpl, Object, Object) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Only applicable when the value is stored in the cache.
mergeIntoParentCache(UnitOfWorkImpl, Object, Object) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Only applicable when the value is stored in the cache.
mergeIntoParentCache(UnitOfWorkImpl, Object, Object) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: This method should merge changes from the parent into the child.
MergeManager - Class in org.eclipse.persistence.internal.sessions
Purpose: Used to manage the merge of two objects in a unit of work.
MergeManager(AbstractSession) - Constructor for class org.eclipse.persistence.internal.sessions.MergeManager
 
mergeManagerForActiveMerge - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
temporarily holds a reference to a merge manager that is calling this UnitOfWork during merge
mergeNewObjectIntoCache(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Merge a change set for a new object into the cache.
mergeObjectChanges(ObjectChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: This method will be used to merge a change set into an UnitOfWorkChangeSet This method returns the local instance of the changeset
mergeObjectChanges(ObjectChangeSet, UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: This method will be used to merge changes from a supplied ObjectChangeSet into this changeSet.
mergeOriginalIntoWorkingCopy() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
This is used to revert changes to objects, or during refreshes.
MergePending - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
mergePolicy - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
Policy that determines merge type (i.e.
mergeRecord(ChangeRecord, UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.AggregateChangeRecord
INTERNAL: This method will be used to merge one record into another
mergeRecord(ChangeRecord, UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.AggregateCollectionChangeRecord
INTERNAL: This method will be used to merge one record into another
mergeRecord(ChangeRecord, UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.ChangeRecord
INTERNAL: This method will be used to merge one record into another
mergeRecord(ChangeRecord, UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This method will be used to merge one record into another.
mergeRecord(ChangeRecord, UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
This method will be used to merge one record into another.
mergeRecord(ChangeRecord, UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
This method will be used to merge one record into another.
mergeRecord(ChangeRecord, UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.DirectToFieldChangeRecord
INTERNAL: This method will be used to merge one record into another.
mergeRecord(ChangeRecord, UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.ObjectReferenceChangeRecord
INTERNAL: This method will be used to merge one record into another
mergeRecord(ChangeRecord, UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.TransformationMappingChangeRecord
INTERNAL: This method will be used to merge one record into another
mergeRemoteValueHolder(Object, Object, MergeManager) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL Replace the client value holder with the server value holder, after copying some of the settings from the client value holder.
mergeRemoteValueHolder(Object, Object, MergeManager) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL Replace the client value holder with the server value holder, after copying some of the settings from the client value holder.
mergeRemoteValueHolder(Object, Object, MergeManager) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL Replace the client value holder with the server value holder, after copying some of the settings from the client value holder.
mergeRemoteValueHolder(Object, Object, MergeManager) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Replace the client value holder with the server value holder after copying some of the settings from the client value holder.
mergeRemoteValueHolder(Object, Object, MergeManager) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL Replace the client value holder with the server value holder, after copying some of the settings from the client value holder.
mergeRemoteValueHolder(Object, Object, MergeManager) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Replace the client value holder with the server value holder, after copying some of the settings from the client value holder.
mergeUnitOfWorkChangeSet(UnitOfWorkChangeSet, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: THis method will be used to merge another changeset into this changeset.
mergeWith(Restriction) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
Overwrites attributes of this restriction with attributes of the argument, if they are not null.
mergeWorkingCopyIntoOriginal() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
This is used during the unit of work commit to merge changes into the parent.
mergeWorkingCopyIntoRemote() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
This is used during the unit of work commit to merge changes into the parent.
message - Variable in class org.eclipse.persistence.logging.SessionLogEntry
 
metaData - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Cache of the connection's java.sql.DatabaseMetaData
metaData - Variable in class org.eclipse.persistence.internal.sessions.ResultSetRecord
 
METADATA - org.eclipse.persistence.logging.LogCategory
 
METADATA - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
METADATA_SOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.metadata-source"property configures the type of MetadataSource implementation to use to read Metadata
METADATA_SOURCE_PROPERTIES_FILE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The property "eclipselink.metadata-source.properties.file" specifies the name of the metadata repository properties file to read from using classloader to find the resource.
METADATA_SOURCE_RCM_COMMAND - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.metadata-source.send-refresh-command" property works with cache coordination for a clustered environment to.
METADATA_SOURCE_XML_FILE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The property "eclipselink.metadata-source.xml.file" specifies the name of the metadata repository xml file to read from using classloader to find the resource
METADATA_SOURCE_XML_URL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The property "eclipselink.metadata-source.xml.URL" specifies the name of the metadata repository xml URL to read from.
metadatalistener - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
the MetadataRefreshListener is used with RCM to force a refresh of the metadata used within EntityManagerFactoryWrappers
MetadataRefreshCommand - Class in org.eclipse.persistence.internal.sessions.coordination
Purpose: A Command implementation used to signal JPA EntityManagerFactory to refresh its metadata.
MetadataRefreshCommand(Map) - Constructor for class org.eclipse.persistence.internal.sessions.coordination.MetadataRefreshCommand
 
MetadataRefreshListener - Interface in org.eclipse.persistence.sessions.coordination
 
METAMODEL - org.eclipse.persistence.logging.LogCategory
 
METAMODEL - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
metamodelIdClassMap - Variable in class org.eclipse.persistence.sessions.Project
Store the IdClass Id attributes for exclusive use by the Metamodel API Keyed on the fully qualified accessible object owner class name.
method - Variable in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
 
method - Variable in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
The method is resolved during initialization, and it is not serialized.
method - Variable in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
 
method() - Method in annotation type org.eclipse.persistence.annotations.CloneCopyPolicy
(Optional) Either method or workingCopyMethod must be specified this defines a method that will be used to create a clone that will be used for comparison by EclipseLink's DeferredChangeDetectionPolicy
method() - Method in annotation type org.eclipse.persistence.annotations.ReadTransformer
The mapped class must have a method with this name which returns a value to be assigned to the attribute (not assigns the value to the attribute).
method() - Method in annotation type org.eclipse.persistence.annotations.WriteTransformer
The mapped class must have a method with this name which returns a value to be written into the database column.
method() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlReadTransformer
The mapped class must have a method with this name which returns a value to be assigned to the attribute (not assigns the value to the attribute).
method() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlWriteTransformer
The mapped class must have a method with this name which returns a value to be written into the XML document.
METHOD_DOES_NOT_EXIST_IN_CONTAINER_CLASS - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
METHOD_DOES_NOT_EXIST_ON_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
METHOD_FAILED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
METHOD_INVOCATION_FAILED - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
METHOD_INVOCATION_FAILED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
METHOD_NOT_VALID - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
MethodAttributeAccessor - Class in org.eclipse.persistence.internal.descriptors
Purpose: A wrapper class for handling cases when the domain object attributes are to be accessed thru the accessor methods.
MethodAttributeAccessor() - Constructor for class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
 
MethodBasedAttributeTransformer - Class in org.eclipse.persistence.mappings.transformers
 
MethodBasedAttributeTransformer() - Constructor for class org.eclipse.persistence.mappings.transformers.MethodBasedAttributeTransformer
 
MethodBasedAttributeTransformer(String) - Constructor for class org.eclipse.persistence.mappings.transformers.MethodBasedAttributeTransformer
 
MethodBasedFieldTransformation - Class in org.eclipse.persistence.internal.descriptors
INTERNAL: This is an implementation of FieldTransformation which stores a method name and uses that name to instantiate a MethodBasedFieldTransformer.
MethodBasedFieldTransformation() - Constructor for class org.eclipse.persistence.internal.descriptors.MethodBasedFieldTransformation
 
MethodBasedFieldTransformer - Class in org.eclipse.persistence.mappings.transformers
 
MethodBasedFieldTransformer(String) - Constructor for class org.eclipse.persistence.mappings.transformers.MethodBasedFieldTransformer
 
MethodBaseQueryRedirector - Class in org.eclipse.persistence.queries
Purpose:
MethodBaseQueryRedirector() - Constructor for class org.eclipse.persistence.queries.MethodBaseQueryRedirector
PUBLIC: Returns a new query redirector.
MethodBaseQueryRedirector(Class<?>, String) - Constructor for class org.eclipse.persistence.queries.MethodBaseQueryRedirector
PUBLIC: Returns a new query redirector based on the static method in methodClass.
methodClass - Variable in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
 
MethodClassExtractor - Class in org.eclipse.persistence.descriptors
Purpose: Used to allow complex inheritance support.
MethodClassExtractor() - Constructor for class org.eclipse.persistence.descriptors.MethodClassExtractor
 
methodClassName - Variable in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
 
MethodDefinition - Class in org.eclipse.persistence.internal.codegen
INTERNAL:
MethodDefinition() - Constructor for class org.eclipse.persistence.internal.codegen.MethodDefinition
 
methodDoesNotExistInContainerClass(String, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
methodDoesNotExistOnExpression(String, Class<?>[]) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
methodFailed(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
methodInvocationFailed(Method, Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
methodInvocationFailed(Method, Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
methodName - Variable in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Allow for clone method to be specified.
methodName - Variable in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
The method invoked on either the descriptor class (in which case it is static) or the factory (in which case it is not static) to build a new instance of the descriptor class.
methodName - Variable in class org.eclipse.persistence.internal.descriptors.MethodBasedFieldTransformation
 
methodName - Variable in class org.eclipse.persistence.mappings.transformers.MethodBasedAttributeTransformer
 
methodName - Variable in class org.eclipse.persistence.mappings.transformers.MethodBasedFieldTransformer
 
methodName - Variable in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
 
methodNotValid(Object, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
methods - Variable in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
millisecond() - Method in annotation type org.eclipse.persistence.annotations.TimeOfDay
(Optional) Millisecond of the day.
MimeTypePolicy - Interface in org.eclipse.persistence.internal.oxm.mappings
Purpose:
MimeTypePolicy - Interface in org.eclipse.persistence.oxm.mappings
Purpose:
min - Static variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
 
min() - Method in class org.eclipse.persistence.platform.database.DB2Platform
Disable binding support.
min(Expression, int) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
min(Expression, Object) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
MIN_CONNECTIONS - Static variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
MIN_ROW - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
MIN_SUPPORTED - Static variable in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Lowest supported Java SE platform.
minimum() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This represents the aggregate function Minimum.
minimum() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the MINIMUM operator.
Minimum - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
minimumNumericValues() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Builds a table of minimum numeric values keyed on java class.
minimumNumericValues() - Method in class org.eclipse.persistence.platform.database.AccessPlatform
Builds a table of minimum numeric values keyed on java class.
minimumNumericValues() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Builds a table of minimum numeric values keyed on java class.
minimumNumericValues() - Method in class org.eclipse.persistence.platform.database.DBasePlatform
Builds a table of minimum numeric values keyed on java class.
minimumNumericValues() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Builds a table of minimum numeric values keyed on java class.
minimumNumericValues() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Builds a table of minimum numeric values keyed on java class.
minimumNumericValues() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Builds a table of minimum numeric values keyed on java class.
minimumNumericValues() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Builds a table of minimum numeric values keyed on java class.
minimumTimeIncrement() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Returns the minimum time increment supported by the platform.
minimumTimeIncrement() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
INTERNAL: Returns the minimum time increment supported by the platform.
minNumberOfConnections - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
minScale - Variable in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
minute() - Method in annotation type org.eclipse.persistence.annotations.TimeOfDay
(Optional) Minute of the day.
MISC - org.eclipse.persistence.logging.LogCategory
 
MISC - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
MISSING_CLASS_FOR_INDICATOR_FIELD_VALUE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
MISSING_CLASS_INDICATOR_FIELD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
MISSING_CONNECTION_POOL - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
MISSING_CONTEXT_PROPERTY_FOR_PROPERTY_PARAMETER_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
MISSING_CONTEXT_STRING_FOR_CONTEXT - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MISSING_CONVERT_ATTRIBUTE_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MISSING_DEPENDENCY_FOR_BINARY_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
MISSING_DESCRIPTOR - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MISSING_FIELD_TYPE_FOR_DDL_GENERATION_OF_CLASS_TRANSFORMATION_ - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MISSING_FOREIGN_KEY_TRANSLATION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
MISSING_ID_FOR_IDREF - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
MISSING_INDIRECT_CONTAINER_CONSTRUCTOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
MISSING_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MISSING_MAPPING_CONVERT_ATTRIBUTE_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MISSING_MAPPING_FOR_FIELD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
MISSING_PARTITION_POLICY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
MISSING_PROPERTIES_FILE_FOR_METADATA_SOURCE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MISSING_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
MISSING_PROPERTY_IN_PROP_ORDER - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
MISSING_REF_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
MISSING_SERVER_PLATFORM_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
MISSING_TRANSFORMER_METHOD_FOR_DDL_GENERATION_OF_CLASS_TRANSFORMATION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MISSING_XML_FILE_FOR_METADATA_SOURCE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
missingClassForIndicatorFieldValue(Object, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
missingClassIndicatorField(XMLRecord, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
missingClassIndicatorField(AbstractRecord, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
missingConnectionPool(String, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
missingContextPropertyForPropertyParameterExpression(DatabaseQuery, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
missingContextStringForContext(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
missingConvertAttributeName(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
missingDescriptor(Class<?>) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Raised for missing descriptors for lazy registration.
missingDescriptor(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
missingDescriptor(SessionEvent) - Method in class org.eclipse.persistence.internal.sessions.factories.MissingDescriptorListener
 
missingDescriptor(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
missingDescriptor(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the session if a descriptor is missing for a class being persisted.
MissingDescriptor - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
missingDescriptorException - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
missingDescriptorException(String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
MissingDescriptorListener - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: Event listener class used to lazy-load the descriptors for EIS and XDB, as they have external jar dependencies that may not be on the classpath.
MissingDescriptorListener() - Constructor for class org.eclipse.persistence.internal.sessions.factories.MissingDescriptorListener
Default constructor.
missingFieldTypeForDDLGenerationOfClassTransformation(ClassDescriptor, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
missingForeignKeyTranslation(ForeignReferenceMapping, DatabaseField) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
missingIDForIDRef(String, Object[]) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
missingIndirectContainerConstructor(Class<?>) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
missingMappingConvertAttributeName(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
missingMappingException - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
missingMappingException(String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
missingMappingForAttribute(ClassDescriptor, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
Create a validation exception for the look up of a mapping on a descriptor for an unknown attribute name.
missingMappingForField(DatabaseField, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
missingPartitioningPolicy(String, ClassDescriptor, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
missingPropertiesFileForMetadataRepositoryConfig(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
missingProperty(String) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
missingPropertyInPropOrder(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
missingPropertyInPropOrder(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
missingRefAttribute() - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when an sdo:ref attribute is missing during xmlhelper.load
missingServerPlatformException(String, String) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
missingSource() - Static method in exception org.eclipse.persistence.exceptions.StaticWeaveException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
missingTarget() - Static method in exception org.eclipse.persistence.exceptions.StaticWeaveException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
missingTransformerMethodForDDLGenerationOfClassTransformation(ClassDescriptor, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
missingXMLMetadataRepositoryConfig() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
mod() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
mod() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the remainder of a division.
Builds Symfoware equivalent to Oracle's MOD(x, y).
Note that it returns x when y is 0, and the sign of the remainder is taken from x.
mod(Expression, int) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
mod(Expression, Object) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Mod - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
mode - Variable in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
mode() - Method in annotation type org.eclipse.persistence.annotations.StoredProcedureParameter
(Optional) The direction of the stored procedure parameter.
modificationDeferralLevel - Variable in class org.eclipse.persistence.descriptors.CMPPolicy
The object deferral level.
MODIFY - org.eclipse.persistence.internal.databaseaccess.DatasourceCall.ParameterType
 
MODIFY_ALL_QUERIES_NOT_SUPPORTED_WITH_OTHER_WRITES - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
modifyAllQueries - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
lazy initialization done in storeModifyAllQuery.
ModifyAllQuery - Class in org.eclipse.persistence.queries
PUBLIC: Query used to perform a bulk delete using the expression framework.
ModifyAllQuery() - Constructor for class org.eclipse.persistence.queries.ModifyAllQuery
PUBLIC:
ModifyAllQuery(Class<?>) - Constructor for class org.eclipse.persistence.queries.ModifyAllQuery
PUBLIC: Create a new update all query for the class specified.
ModifyAllQuery(Class<?>, Expression) - Constructor for class org.eclipse.persistence.queries.ModifyAllQuery
PUBLIC: Create a new update all query for the class and the selection criteria specified.
ModifyQuery - Class in org.eclipse.persistence.queries
Purpose: Abstract class for all modify queries.
ModifyQuery() - Constructor for class org.eclipse.persistence.queries.ModifyQuery
Default constructor.
modifyRow - Variable in class org.eclipse.persistence.internal.expressions.SQLModifyStatement
 
modifyRow - Variable in class org.eclipse.persistence.queries.ModifyQuery
 
modOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
modOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
modOperator() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Override the default MOD operator.
modOperator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
Override the default MOD operator.
MONITOR_HEADER - Static variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
MONITOR_PREFIX - Static variable in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
 
MONITORING - org.eclipse.persistence.logging.LogCategory
 
MONITORING - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
monitorName - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Return the name to use for the query in performance monitoring.
monthsBetween() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
monthsBetween() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the decimal number of months between the two dates.
Builds Symfoware equivalent to monthsBetween(Date, Date).
Symfoware: SPAN_DATE(Date, Date, 'MONTH')
monthsBetween(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the decimal number of months between the two dates.
MonthsBetween - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
monthsBetweenOperator() - Static method in class org.eclipse.persistence.platform.database.FirebirdPlatform
INTERNAL: Use MONTH function for MONTH_BETWEEN.
monthsBetweenOperator() - Static method in class org.eclipse.persistence.platform.database.H2Platform
INTERNAL: Use MONTH function for MONTH_BETWEEN.
moreRowsDetected(DatabaseCall) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Raised for stored proc output parameters.
moreRowsDetected(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
moreRowsDetected(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the session after read object query detected more than a single row back from the database.
MoreRowsDetected - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
moveFirst(LinkedNode) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
Allows a node to be efficiently moved first.
MOXY - org.eclipse.persistence.logging.LogCategory
 
MOXY - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
MULTICAST_GROUP_ADDRESS_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
MULTICAST_GROUP_ADDRESS_RMI_CLUSTERING - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
MULTICAST_PORT_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
MULTICAST_PORT_RMI_CLUSTERING_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
multicastGroupAddress - Variable in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
Defines the IP address of the multicast group
multicastPort - Variable in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
Defines the port the multicast socket will be using
MULTIPART - Variable in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
MULTIPLE_ANY_ATTRIBUTE_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
MULTIPLE_CALLBACK_METHODS_DEFINED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MULTIPLE_CLASSES_FOR_THE_SAME_DISCRIMINATOR - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MULTIPLE_CONTEXT_PROPERTY_FOR_TENANT_DISCRIMINATOR_FIELD - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MULTIPLE_COPY_POLICY_ANNOTATIONS_ON_SAME_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MULTIPLE_CURSORS_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MULTIPLE_EMBEDDED_ID_ANNOTATIONS_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MULTIPLE_OBJECT_VALUES_FOR_DATA_VALUE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MULTIPLE_OUT_PARAMS_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MULTIPLE_OUTPUT_ARGUMENTS_ONLY_FOR_SIMPLE_XML - Static variable in exception org.eclipse.persistence.exceptions.DBWSException
 
MULTIPLE_PROJECTS_SPECIFIED_IN_PROPERTIES - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MULTIPLE_ROWS_DETECTED_FROM_SINGLE_OBJECT_READ - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
MULTIPLE_TABLE_INSERT_ORDER_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
MULTIPLE_TABLE_PRIMARY_KEY_MUST_BE_FULLY_QUALIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
MULTIPLE_TABLE_PRIMARY_KEY_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
MULTIPLE_TARGET_FOREIGN_KEY_TABLES - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
MULTIPLE_UNIQUE_CONSTRAINTS_WITH_SAME_NAME_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MULTIPLE_WRITE_MAPPINGS_FOR_FIELD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
MULTIPLE_XMLELEMREF - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
multipleAnyAttributeMapping(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
multipleClassesForTheSameDiscriminator(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
multipleContextPropertiesForSameTenantDiscriminatorFieldSpecified(String, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
multipleCopyPolicyAnnotationsOnSameClass(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Cause: An annotation or XML document specifies a CloneCopyPolicy, bug does not supply either a method or working copy method
multipleCursorsNotSupported(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
multipleEmbeddedIdAnnotationsFound(Object, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
multipleFieldIdentifiers - Variable in class org.eclipse.persistence.queries.FieldResult
Stores passed in field name split on the '.' character
multipleLifecycleCallbackMethodsForSameLifecycleEvent(Object, Method, Method) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
multipleObjectValuesForDataValue(Object, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
multipleOutParamsNotSupported(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
multipleOutputArgumentsOnlySupportedForSimpleXML() - Static method in exception org.eclipse.persistence.exceptions.DBWSException
INTERNAL: Exception when processing DBWS metadata and the descriptor cannot be located for the operation
multipleResourceException() - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
multipleResultSets() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredProcedureQuery
(Optional) Defines if the stored procedure returns multiple result sets.
multipleRowsDetectedFromReadObjectQuery() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
multipleTableForeignKeys - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
multipleTableInsertOrder - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
multipleTableInsertOrderMismatch(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
multipleTableJoinExpression - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
multipleTablePrimaryKeyMustBeFullyQualified(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
multipleTablePrimaryKeyNotSpecified(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
multipleTargetForeignKeyTables(ClassDescriptor, DatabaseMapping, Collection) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
multipleUniqueConstraintsWithSameNameSpecified(String, String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
multipleVariableDeclaration - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
multipleVariableDeclaration(String, int, int, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
multipleVPDIdentifiersSpecified(String, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
multipleWriteMappingsForField(String, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
multipleXmlElementRef(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
multiply() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
multiply(Expression, int) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
multiply(Expression, Object) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Multiply - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
multiplyOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Set binding support to PARTIAL.
Multitenant - Annotation Type in org.eclipse.persistence.annotations
Multitenant specifies that a given entity is shared amongst multiple tenants of a given application.
MULTITENANT_PROPERTY_DEFAULT - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
The "eclipselink.tenant-id" property specifies the default context property used to populate multitenant entities.
MULTITENANT_PROPERTY_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.tenant-id" property specifies the default context property used to populate multitenant entities.
MULTITENANT_PROPERTY_FOR_NON_SHARED_EMF_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
MULTITENANT_SCHEMA_PROPERTY_DEFAULT - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
The "eclipselink.tenant-schema-id" property specifies the context property used to distinguish tenants when using global schema per tenant multitenant strategy.
MULTITENANT_SCHEMA_PROPERTY_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.tenant-schema-id" property specifies the context property used to distinguish tenants when using global schema per tenant multitenant strategy.
MULTITENANT_SHARED_CACHE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property "eclipselink.multitenant.tenants-share-cache" specifies that multitenant entities will share the L2 cache.
MULTITENANT_SHARED_EMF - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property "eclipselink.multitenant.shared-emf" is used to indicate that multitenant entities will be used within a shared entity manager factory.
MULTITENANT_STRATEGY - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.multitenant.strategy" property specifies the global, project wide multitenancy strategy.
multitenantContextProperties - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Stores the set of multitenant context properties this session requires
multitenantContextPropertyForNonSharedEMFNotSpecified(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
multitenantPolicy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
multitenantPolicy - Variable in class org.eclipse.persistence.sessions.Project
 
MultitenantPolicy - Interface in org.eclipse.persistence.descriptors
A multitenant interface.
MultitenantPrimaryKeyAccessor - Class in org.eclipse.persistence.internal.descriptors
Purpose: A wrapper class for handling cases when the domain object has a property to map to the database field.
MultitenantPrimaryKeyAccessor() - Constructor for class org.eclipse.persistence.internal.descriptors.MultitenantPrimaryKeyAccessor
 
MultitenantPrimaryKeyMapping - Class in org.eclipse.persistence.mappings
Purpose: Maps a multitenant property to the corresponding database field type.
MultitenantPrimaryKeyMapping() - Constructor for class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
Constructor
MultitenantType - Enum in org.eclipse.persistence.annotations
An enum that is used within the Multitenant annotation.
MUST_HAVE_MAPPING_WHEN_IN_OBJECT - Static variable in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
MUST_INSTANTIATE_VALUEHOLDERS - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
MUST_MAP_TO_TEXT - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
MUST_USE_CURSOR_STREAM_POLICY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
mustBeReadOnlyMappingWhenStoredInCache(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
mustDeleteReferenceObjectsOneByOne - Variable in class org.eclipse.persistence.mappings.CollectionMapping
Store if the mapping can batch delete reference objects.
mustDeleteReferenceObjectsOneByOne() - Method in class org.eclipse.persistence.mappings.CollectionMapping
ADVANCED: Return whether the reference objects must be deleted one by one, as opposed to with a single DELETE statement.
mustHaveMappingWhenStoredInObject(Class<?>) - Static method in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
mustInstantiateValueholders() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
mustMapToText(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
mustUseCursorStreamPolicy() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
Mutable - Annotation Type in org.eclipse.persistence.annotations
A Mutable annotation can be used on a @Basic mapping.
MySQL - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
MySQL4 - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
MySQLPlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides MySQL specific behavior.
MySQLPlatform() - Constructor for class org.eclipse.persistence.platform.database.MySQLPlatform
 

N

name - Variable in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Name of the group.
name - Variable in class org.eclipse.persistence.descriptors.partitioning.PartitioningPolicy
The persistent unit unique name for the policy.
name - Variable in class org.eclipse.persistence.eis.EISConnectionSpec
 
name - Variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
name - Variable in class org.eclipse.persistence.internal.codegen.CodeDefinition
 
name - Variable in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
name - Variable in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
The name of the query key.
name - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
Column name of the field.
name - Variable in class org.eclipse.persistence.internal.helper.DatabaseTable
 
name - Variable in class org.eclipse.persistence.internal.queries.ReportItem
Name given for item, can be used to retrieve value from result.
name - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Used to identify a session when using the session broker.
name - Variable in class org.eclipse.persistence.mappings.querykeys.QueryKey
 
name - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
name - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Queries can be given a name and registered with a descriptor to allow common queries to be reused.
name - Variable in class org.eclipse.persistence.queries.SQLResultSetMapping
Stores the name of this SQLResultSetMapping.
name - Variable in class org.eclipse.persistence.sequencing.Sequence
 
name - Variable in class org.eclipse.persistence.sessions.JNDIConnector
 
name - Variable in class org.eclipse.persistence.sessions.Project
 
name - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
name - Variable in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
 
name - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
name - Variable in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
name - Variable in class org.eclipse.persistence.tools.schemaframework.TableCreator
 
name - Variable in class org.eclipse.persistence.tools.schemaframework.UniqueKeyConstraint
 
name() - Method in annotation type org.eclipse.persistence.annotations.CollectionTable
Deprecated.
(Optional) The name of the collection table.
name() - Method in annotation type org.eclipse.persistence.annotations.Converter
(Required) Name this converter.
name() - Method in annotation type org.eclipse.persistence.annotations.FetchAttribute
(Required) The fetch attribute name.
name() - Method in annotation type org.eclipse.persistence.annotations.FetchGroup
(Required) The fetch group name.
name() - Method in annotation type org.eclipse.persistence.annotations.HashPartitioning
The name of the partition policy, names must be unique for the persistence unit.
name() - Method in annotation type org.eclipse.persistence.annotations.Index
The name of the INDEX, defaults to INDEX_<table-name>
name() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredFunctionQuery
(Required) Unique name that references this stored function query.
name() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredProcedureQuery
(Required) Unique name that references this stored procedure query.
name() - Method in annotation type org.eclipse.persistence.annotations.ObjectTypeConverter
(Required) Name this converter.
name() - Method in annotation type org.eclipse.persistence.annotations.Partitioning
The name of the partition policy, names must be unique for the persistence unit.
name() - Method in annotation type org.eclipse.persistence.annotations.PinnedPartitioning
The name of the partition policy, names must be unique for the persistence unit.
name() - Method in annotation type org.eclipse.persistence.annotations.Property
Property name.
name() - Method in annotation type org.eclipse.persistence.annotations.RangePartitioning
The name of the partition policy, names must be unique for the persistence unit.
name() - Method in annotation type org.eclipse.persistence.annotations.ReplicationPartitioning
The name of the partition policy, names must be unique for the persistence unit.
name() - Method in annotation type org.eclipse.persistence.annotations.RoundRobinPartitioning
The name of the partition policy, names must be unique for the persistence unit.
name() - Method in annotation type org.eclipse.persistence.annotations.SerializedConverter
(Required) Name this converter.
name() - Method in annotation type org.eclipse.persistence.annotations.StoredProcedureParameter
(Optional) Stored procedure parameter name.
name() - Method in annotation type org.eclipse.persistence.annotations.Struct
(Required) The database name of the database structure type.
name() - Method in annotation type org.eclipse.persistence.annotations.StructConverter
(Required) Name this converter.
name() - Method in annotation type org.eclipse.persistence.annotations.TenantDiscriminatorColumn
(Optional) The name of column to be used for the tenant discriminator.
name() - Method in annotation type org.eclipse.persistence.annotations.TypeConverter
(Required) Name this converter.
name() - Method in annotation type org.eclipse.persistence.annotations.UnionPartitioning
The name of the partition policy, names must be unique for the persistence unit.
name() - Method in annotation type org.eclipse.persistence.annotations.UuidGenerator
The name of the UUID generator, names must be unique for the persistence unit.
name() - Method in annotation type org.eclipse.persistence.annotations.ValuePartitioning
The name of the partition policy, names must be unique for the persistence unit.
name() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNamedObjectGraph
The name of this object graph.
name() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNamedSubgraph
required: the name of the subgraph
name() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlProperty
Property name.
name() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredFunctionQuery
(Required) Unique name that references this stored procedure query.
name() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredProcedureQuery
(Required) Unique name that references this stored procedure query.
name() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.OracleArray
(Required) The name of the VARRAY type in the database.
name() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.OracleObject
(Required) The name of the OBJECT type in the database.
name() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLParameter
(Required) Stored procedure parameter name.
name() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLRecord
(Required) The name of the record type in the database.
name() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLTable
(Required) The name of the record type in the database.
NAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
NAME_COLLISION - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
NAME_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
nameCollision(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
NAMED - org.eclipse.persistence.queries.DatabaseQuery.ParameterType
 
NAMED_ARGUMENT_NOT_FOUND_IN_QUERY_PARAMETERS - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
namedArgumentNotFoundInQueryParameters(String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
NamedPLSQLStoredFunctionQueries - Annotation Type in org.eclipse.persistence.platform.database.oracle.annotations
A NamedPLSQLStoredFunctionQueries annotation allows the definition of multiple NamedPLSQLStoredFunctionQuery.
NamedPLSQLStoredFunctionQuery - Annotation Type in org.eclipse.persistence.platform.database.oracle.annotations
A NamedPLSQLStoredFunctionQuery annotation allows the definition of queries that call PLSQL stored functions as named queries.
NamedPLSQLStoredProcedureQueries - Annotation Type in org.eclipse.persistence.platform.database.oracle.annotations
A NamedPLSQLStoredProcedureQueries annotation allows the definition of multiple NamedPLSQLStoredProcedureQuery.
NamedPLSQLStoredProcedureQuery - Annotation Type in org.eclipse.persistence.platform.database.oracle.annotations
A PLSQLNamedStoredProcedureQuery annotation allows the definition of queries that call PLSQL stored procedures as named queries.
NamedStoredFunctionQueries - Annotation Type in org.eclipse.persistence.annotations
A NamedStoredFunctionQueries annotation allows the definition of multiple NamedStoredFunctionQuery.
NamedStoredFunctionQuery - Annotation Type in org.eclipse.persistence.annotations
A NamedStoredFunctionQuery annotation allows the definition of queries that call stored functions as named queries.
NamedStoredProcedureQueries - Annotation Type in org.eclipse.persistence.annotations
A NamedStoredProcedureQueries annotation allows the definition of multiple NamedStoredProcedureQuery.
NamedStoredProcedureQuery - Annotation Type in org.eclipse.persistence.annotations
A NamedStoredProcedureQuery annotation allows the definition of queries that call stored procedures as named queries.
nameFieldName - Variable in class org.eclipse.persistence.sequencing.TableSequence
Hold the name of the column in the sequence table which specifies the sequence name
nameForComparisons - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
If this is set, it will be used in determining equality (unless delimiters are used) and the hashcode.
nameIsText - Variable in class org.eclipse.persistence.internal.oxm.XPathFragment
 
nameIsText() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
names - Variable in class org.eclipse.persistence.queries.ReportQuery
Collection of names for use by results.
names - Variable in class org.eclipse.persistence.queries.ReportQueryResult
Item names to lookup result values
nameSpace - Variable in class org.eclipse.persistence.logging.SessionLogEntry
 
Namespace - Class in org.eclipse.persistence.internal.oxm
INTERNAL: This class represents a Namespace.
Namespace() - Constructor for class org.eclipse.persistence.internal.oxm.Namespace
 
Namespace(String, String) - Constructor for class org.eclipse.persistence.internal.oxm.Namespace
 
NAMESPACE_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
NAMESPACE_PREFIXES_FEATURE - Static variable in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
NAMESPACE_RESOLVER_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
namespaceAware - Variable in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
namespaceAware - Variable in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
namespaceDeclaration(String, String) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
namespaceDeclaration(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
namespaceDeclaration(String, String) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
namespaceDeclaration(String, String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
namespaceDeclaration(String, String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
namespaceDeclaration(String, String) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Add the specified namespace declaration
namespaceDeclaration(String, String) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
Marshal a namespace declaration for the given prefix and url
namespaceDeclaration(String, String) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
namespaceDeclarations - Variable in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
namespaceDeclarations(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
INTERNAL: Add the namespace declarations to the XML document.
namespaceDeclarations(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
INTERNAL:
namespaceDeclarations(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
namespaceDeclarations(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
INTERNAL: Add the namespace declarations to the XML document.
namespaceDeclarations(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
namespaceDeclarations(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
namespaceDeclarations(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
namespaceNotFound(String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
NamespacePrefixMapper - Class in org.eclipse.persistence.internal.oxm
Purpose:Provides a means to customise the namespace prefixes used while marshalling An implementation of this class can be set on an instance of XMLMarshaller to allow for each instance of XMLMarshaller to use different namespace prefixes.
NamespacePrefixMapper - Class in org.eclipse.persistence.oxm
Purpose:Provides a means to customise the namespace prefixes used while marshalling An implementation of this class can be set on an instance of XMLMarshaller to allow for each instance of XMLMarshaller to use different namespace prefixes.
NamespacePrefixMapper() - Constructor for class org.eclipse.persistence.internal.oxm.NamespacePrefixMapper
Default constructor.
NamespacePrefixMapper() - Constructor for class org.eclipse.persistence.oxm.NamespacePrefixMapper
Default constructor.
NamespacePrefixMapperWrapper - Class in org.eclipse.persistence.internal.oxm.record.namespaces
INTERNAL:
NamespacePrefixMapperWrapper(Object) - Constructor for class org.eclipse.persistence.internal.oxm.record.namespaces.NamespacePrefixMapperWrapper
 
namespaceQualifyFragment(Element) - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
 
NamespaceResolvableProject - Class in org.eclipse.persistence.internal.sessions.factories
 
NamespaceResolvableProject() - Constructor for class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
NamespaceResolvableProject(NamespaceResolverWithPrefixes) - Constructor for class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
namespaceResolver - Variable in class org.eclipse.persistence.eis.EISDescriptor
Allow namespaces to be specified for XML type descriptors.
namespaceResolver - Variable in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
NamespaceResolver - Class in org.eclipse.persistence.internal.oxm
It is common for an XML document to include one or more namespaces.
NamespaceResolver - Class in org.eclipse.persistence.oxm
It is common for an XML document to include one or more namespaces.
NamespaceResolver() - Constructor for class org.eclipse.persistence.internal.oxm.NamespaceResolver
Default constructor, creates a new NamespaceResolver.
NamespaceResolver() - Constructor for class org.eclipse.persistence.oxm.NamespaceResolver
Default constructor
NamespaceResolver(NamespaceResolver) - Constructor for class org.eclipse.persistence.internal.oxm.NamespaceResolver
Copy Constructor
NamespaceResolver(NamespaceResolver) - Constructor for class org.eclipse.persistence.oxm.NamespaceResolver
Copy constructor
namespaceResolverNotSpecified(String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
NamespaceResolverStorage - Class in org.eclipse.persistence.internal.oxm
 
NamespaceResolverStorage() - Constructor for class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
 
NamespaceResolverStorage(int) - Constructor for class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
 
NamespaceResolverWithPrefixes - Class in org.eclipse.persistence.internal.sessions.factories
 
NamespaceResolverWithPrefixes() - Constructor for class org.eclipse.persistence.internal.sessions.factories.NamespaceResolverWithPrefixes
Default constructor
namespaceUri - Variable in class org.eclipse.persistence.internal.oxm.Root
 
namespaceURI - Variable in class org.eclipse.persistence.internal.oxm.Namespace
 
namespaceXPath - Variable in class org.eclipse.persistence.sessions.factories.OracleDirectToXMLTypeMappingHelper
 
NAMING_INTO_INDEXED - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jpa.naming_into_indexed" property defines if stored procedure parameters passed by name should be transformed into positional/index based passing if property value will be true.
namingIntoIndexed - Variable in class org.eclipse.persistence.sessions.Project
Flag that allows transform named stored procedure parameters into positional/index based
namingIntoIndexed() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Return true is allowed to transform named stored procedure parameters into positional/index based.
namingServiceType - Variable in class org.eclipse.persistence.sessions.coordination.TransportManager
The type of naming service used to look up other connections
NATIVE_CONNECTION - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.jdbc.native-connection"
NATIVE_QUERY_UPPERCASE_COLUMNS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jdbc.uppercase-columns" property configures native SQL queries are used, the JDBC meta-data may return column names in lower case on some platforms.
NATIVE_SEQUENCING_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
NATIVE_SQL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jdbc.native-sql" property specifies whether generic SQL should be used or platform specific 'native' SQL.
NATIVE_SQL_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
NATIVE_SQL_QUERIES_ARE_DISABLED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
NativeSequence - Class in org.eclipse.persistence.sequencing
Purpose: Define a database's native sequencing mechanism.
NativeSequence() - Constructor for class org.eclipse.persistence.sequencing.NativeSequence
 
NativeSequence(boolean) - Constructor for class org.eclipse.persistence.sequencing.NativeSequence
 
NativeSequence(String) - Constructor for class org.eclipse.persistence.sequencing.NativeSequence
Create a new sequence with the name.
NativeSequence(String, boolean) - Constructor for class org.eclipse.persistence.sequencing.NativeSequence
 
NativeSequence(String, int) - Constructor for class org.eclipse.persistence.sequencing.NativeSequence
Create a new sequence with the name and sequence pre-allocation size.
NativeSequence(String, int, boolean) - Constructor for class org.eclipse.persistence.sequencing.NativeSequence
 
NativeSequence(String, int, int) - Constructor for class org.eclipse.persistence.sequencing.NativeSequence
 
NativeSequence(String, int, int, boolean) - Constructor for class org.eclipse.persistence.sequencing.NativeSequence
 
NativeSequenceConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.sequencing
INTERNAL:
NativeSequenceConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.sequencing.NativeSequenceConfig
 
nativeSQLQueriesAreDisabled(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
Natural - org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
NaturalN - org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
NCHAR_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
NCNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
NCNAME_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
nearestNeighbor() - Static method in class org.eclipse.persistence.internal.expressions.SpatialExpressionOperators
ExpressionOperator for the MDSYS.SDO_NN Spatial Operator on the Oracle Database Use of this operator requires the Java spatial classes
NEED_TO_IMPLEMENT_CHANGETRACKER - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NEED_TO_IMPLEMENT_FETCHGROUPTRACKER - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NEED_TO_MAP_JAVA_SQL_TIMESTAMP - Static variable in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
needToImplementChangeTracker(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
needToImplementFetchGroupTracker(Class<?>, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
needToMapJavaSqlTimestampWhenStoredInObject() - Static method in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
negate() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
negate(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Negate - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
NEGATIVE - org.eclipse.persistence.annotations.IdValidation
null, 0 and negative values are not allowed for ids extending Number and primitive int and long ids.
NEGATIVE_INFINITY - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
NEGATIVE_INTEGER - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
NEGATIVE_INTEGER_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
NESTED_UOW_NOT_SUPPORTED_FOR_ATTRIBUTE_TRACKING - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NESTED_UOW_NOT_SUPPORTED_FOR_MODIFY_ALL_QUERY - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
nestedAggregateToSourceFields - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Map the name of an attribute of the reference descriptor mapped with AggregateCollectionMapping to aggregateToSourceFieldNames that should be applied to this mapping.
nestedArray - Variable in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
nestedFieldTranslations - Variable in class org.eclipse.persistence.mappings.AggregateObjectMapping
Map of nested attributes that need to apply an override name to their a nested aggregate mapping's database field.
nestedMapping - Variable in class org.eclipse.persistence.mappings.structures.NestedTableMapping
 
NestedParticle - Interface in org.eclipse.persistence.internal.oxm.schema.model
Purpose: Interface to represent a Choice or Sequence
NestedTable - Class in org.eclipse.persistence.internal.expressions
 
NestedTable() - Constructor for class org.eclipse.persistence.internal.expressions.NestedTable
 
NestedTable(QueryKeyExpression) - Constructor for class org.eclipse.persistence.internal.expressions.NestedTable
 
NestedTableDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Allow for creation of nested table types.
NestedTableDefinition() - Constructor for class org.eclipse.persistence.tools.schemaframework.NestedTableDefinition
 
NestedTableMapping - Class in org.eclipse.persistence.mappings.structures
Purpose: Nested tables are similar to VARRAYs except internally they store their information in a separate table from their parent structure's table.
NestedTableMapping() - Constructor for class org.eclipse.persistence.mappings.structures.NestedTableMapping
PUBLIC: Default constructor.
nestedType - Variable in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
Defines the database type of the value contained in the collection type.
nestedType - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCollection
Defines the database type of the value contained in the collection type.
nestedType() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.OracleArray
(Required) The name of the database type this VARRAY holds onto.
nestedType() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLTable
(Required) The name of the database OBJECT TYPE or VARRAY type that mirrors the record's structure.
nestedTypeField - Variable in class org.eclipse.persistence.mappings.structures.ObjectRelationalDatabaseField
 
nestedUOWNotSupportedForAttributeTracking() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
nestedUOWNotSupportedForModifyAllQuery() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
nestLevel - Variable in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
nestTime - Variable in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
NetWeaver_7_1_PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
NetWeaver_7_1_PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.NetWeaver_7_1_PlatformConfig
 
newAggregateCollectionMapping() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return a new aggregate collection/element collection mapping for this type of descriptor.
newAggregateCollectionMapping() - Method in class org.eclipse.persistence.eis.EISDescriptor
Return a new aggregate collection/element collection mapping for this type of descriptor.
newAggregateCollectionMapping() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
Return a new aggregate collection/element collection mapping for this type of descriptor.
newAggregateMapping() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return a new aggregate/embedded mapping for this type of descriptor.
newAggregateMapping() - Method in class org.eclipse.persistence.eis.EISDescriptor
Return a new aggregate/embedded mapping for this type of descriptor.
newAggregateMapping() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
Return a new aggregate/embedded mapping for this type of descriptor.
newAggregates - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
newDerivedExpressionNamed(String) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
newDerivedField(DatabaseField) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL:
newDerivedTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL:
newDirectCollectionMapping() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return a new direct collection/element collection mapping for this type of descriptor.
newDirectCollectionMapping() - Method in class org.eclipse.persistence.eis.EISDescriptor
Return a new direct collection/element collection mapping for this type of descriptor.
newDirectCollectionMapping() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
Return a new direct collection/element collection mapping for this type of descriptor.
newDirectMapping() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return a new direct/basic mapping for this type of descriptor.
newDirectMapping() - Method in class org.eclipse.persistence.eis.EISDescriptor
Return a new direct/basic mapping for this type of descriptor.
newDirectMapping() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
Return a new direct/basic mapping for this type of descriptor.
newDynamicEntity() - Method in interface org.eclipse.persistence.dynamic.DynamicType
 
newDynamicEntity() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
newDynamicEntity(String) - Method in class org.eclipse.persistence.dynamic.DynamicHelper
 
newExpressionForArgument(Expression, Object) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create a new expression.
newExpressionForArguments(Expression, List) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: The general case.
newExpressionForArgumentWithBaseLast(Expression, Object) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create a new expression.
newGroup(String, CoreAttributeGroup) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Subclass may create different types.
newGroup(String, CoreAttributeGroup) - Method in class org.eclipse.persistence.queries.AttributeGroup
Subclass may create different types.
newGroup(String, CoreAttributeGroup) - Method in class org.eclipse.persistence.queries.FetchGroup
 
newGroup(String, CoreAttributeGroup) - Method in class org.eclipse.persistence.queries.LoadGroup
 
newGroup(String, CoreAttributeGroup) - Method in class org.eclipse.persistence.sessions.CopyGroup
 
newInstance() - Static method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
newInstance(int) - Static method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
newInstance(int, int) - Static method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
newInstance(short) - Static method in class org.eclipse.persistence.internal.expressions.ForUpdateClause
 
newInstance(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Return a new instance of the class registered in this unit of work.
newInstance(Class<?>) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Return a new instance of the class registered in this unit of work.
newInstance(Integer) - Static method in class org.eclipse.persistence.internal.expressions.ForUpdateClause
 
newInstance(Collection<? extends E>) - Static method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
newInstanceFromClass(Class<T>) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Get a new instance of a class using the default constructor.
newItem(CoreAttributeGroup, String) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Subclass may create different types.
newItem(CoreAttributeGroup, String) - Method in class org.eclipse.persistence.queries.AttributeGroup
Subclass may create different types.
newItem(AttributeGroup, String) - Method in class org.eclipse.persistence.queries.AttributeGroup
Subclass may create different types.
newKey - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
newManualDerivedExpressionNamed(String, ClassDescriptor) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
newManyToManyMapping() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return a new one to many mapping for this type of descriptor.
newManyToManyMapping() - Method in class org.eclipse.persistence.eis.EISDescriptor
Return a new one to many mapping for this type of descriptor.
newManyToOneMapping() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return a new many to one mapping for this type of descriptor.
newManyToOneMapping() - Method in class org.eclipse.persistence.eis.EISDescriptor
Return a new many to one mapping for this type of descriptor.
newObjectChangeSets - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
 
newObjectEvent(Object, Object, Mapping) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
An EclipseLink specific callback into the Reader.
newObjectEvent(Object, Object, Mapping) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
newObjectsCache - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
newObjectsCloneToMergeOriginal - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Stores a map from the clone to the original merged object, as a different instance is used as the original for merges.
newObjectsCloneToOriginal - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
newObjectsInParent - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
used to store a list of the new objects in the parent
newObjectsInParentOriginalToClone - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
newObjectsOriginalToClone - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
newOneToManyMapping() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return a new one to many mapping for this type of descriptor.
newOneToManyMapping() - Method in class org.eclipse.persistence.eis.EISDescriptor
Return a new one to many mapping for this type of descriptor.
newOneToOneMapping() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return a new one to one mapping for this type of descriptor.
newOneToOneMapping() - Method in class org.eclipse.persistence.eis.EISDescriptor
Return a new one to one mapping for this type of descriptor.
newPlatformUnmarshaller(XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.platform.SAXPlatform
INTERNAL:
newPlatformUnmarshaller(XMLUnmarshaller, Map<String, Boolean>) - Method in class org.eclipse.persistence.oxm.platform.SAXPlatform
INTERNAL:
newPlatformUnmarshaller(XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.platform.DOMPlatform
INTERNAL:
newPlatformUnmarshaller(XMLUnmarshaller, Map<String, Boolean>) - Method in class org.eclipse.persistence.oxm.platform.DOMPlatform
INTERNAL:
newPlatformUnmarshaller(XML_UNMARSHALLER) - Method in class org.eclipse.persistence.oxm.platform.XMLPlatform
INTERNAL:
newPlatformUnmarshaller(XML_UNMARSHALLER, Map<String, Boolean>) - Method in interface org.eclipse.persistence.internal.oxm.record.XMLPlatform
 
newPlatformUnmarshaller(XML_UNMARSHALLER, Map<String, Boolean>) - Method in class org.eclipse.persistence.oxm.platform.XMLPlatform
INTERNAL:
newProxyInstance(Class<?>, Class<?>[], ValueHolderInterface<T>) - Static method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionHandler
INTERNAL: Utility method to create a new proxy object.
newReadAllQuery(String) - Method in class org.eclipse.persistence.dynamic.DynamicHelper
Helper method to simplify creating a native ReadAllQuery using the entity type name (descriptor alias)
newReadObjectQuery(String) - Method in class org.eclipse.persistence.dynamic.DynamicHelper
Helper method to simplify creating a native ReadObjectQuery using the entity type name (descriptor alias)
newReportQuery(String, ExpressionBuilder) - Method in class org.eclipse.persistence.dynamic.DynamicHelper
Helper method to simplify creating a native ReportQuery using the entity type name (descriptor alias)
newServiceDiscovered(ServiceId) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
INTERNAL: A new service has been detected by the discovery manager.
newSize - Variable in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
newSynchronizationListener(UnitOfWorkImpl, AbstractSession, Object, AbstractTransactionController) - Method in class org.eclipse.persistence.transaction.JTASynchronizationListener
INTERNAL: Create and return the Synchronization listener object that can be registered to receive JTA transaction notification callbacks.
newSynchronizationListener(UnitOfWorkImpl, AbstractSession, Object, AbstractTransactionController) - Method in interface org.eclipse.persistence.transaction.SynchronizationListenerFactory
INTERNAL: Create and return the synchronization listener object that can be registered to receive transaction notification callbacks.
newTime() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
newTime(String, String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: funcation return a date converted to a new timezone.
NewTime - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
newTransportManager(String, RemoteCommandManager) - Static method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Creates a new instance of org.eclipse.persistence.sessions.coordination.rmi.RMITransportManager class.
newUnidirectionalOneToManyMapping() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Return a new one to many mapping for this type of descriptor.
newUnidirectionalOneToManyMapping() - Method in class org.eclipse.persistence.eis.EISDescriptor
Return a new one to many mapping for this type of descriptor.
newValue - Variable in class org.eclipse.persistence.internal.sessions.DirectToFieldChangeRecord
 
newValue - Variable in class org.eclipse.persistence.internal.sessions.ObjectReferenceChangeRecord
This is the object change set that the attribute points to.
newXMLParser() - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
Return a concrete implementation of the XML parser abstraction that is compatible with the XML Platform.
newXMLParser(Map<String, Boolean>) - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
Return a concrete implementation of the XML parser abstraction that is compatible with the XML Platform, based on these parser features.
newXMLTransformer() - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
Return a concrete implementation of the XML transformer abstraction that is compatible with the XML Platform.
next - Variable in class org.eclipse.persistence.internal.identitymaps.LinkedCacheKey
Handle on next element in cache
next() - Method in class org.eclipse.persistence.internal.mappings.converters.AttributeNameTokenizer.TokensIterator
INTERNAL: Return the next attribute name token from attribute name.
next() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy.MapContainerPolicyIterator
 
next() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordEntryIterator
 
next() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordKeyIterator
 
next() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordValuesIterator
 
next() - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Return the next object from the collection, if beyond the read limit read from the cursor.
next() - Method in class org.eclipse.persistence.queries.ReportQueryResult.EntryIterator
 
next() - Method in class org.eclipse.persistence.queries.ReportQueryResult.KeyIterator
 
next() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: This method differs slightly from conventional read() operation on a Java stream.
next(int) - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Return a Vector of at most numberOfElements of the next objects from the collection.
next(int) - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: This method differs slightly from conventional read() operation on a Java stream.
next(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the next object on the queue.
next(Object) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Return the next object on the queue.
next(Object) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return the next object on the queue.
next(Object) - Method in class org.eclipse.persistence.queries.CursorPolicy
INTERNAL: Return the next object on the queue.
next(Object, ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Return the next object from the iterator.
next(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the next object from the iterator.
nextAccessor(ServerSession, DatabaseQuery) - Method in class org.eclipse.persistence.descriptors.partitioning.RoundRobinPartitioningPolicy
INTERNAL: Return the next connection accessor.
nextDay() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
nextDay(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the date with the next day from the source date as the day name given.
NextDay - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
nextElement() - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMapEnumeration
Get next element of CacheKey content enumeration if this enumeration object has at least one more element to provide.
nextElement() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapEnumeration
Get next CacheKey.getObject() element of CacheKey enumeration if this enumeration object has at least one more element to provide.
nextElement() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapKeyEnumeration
Get next element of CacheKey enumeration if this enumeration object has at least one more element to provide.
nextElement() - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Return the next object from the collection, if beyond the read limit read from the cursor.
nextElement() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Return the next object from the collection, if beyond the read limit read from the cursor.
nextElements(int) - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Return a Vector of at most numberOfElements of the next objects from the collection.
nextEntry(Object) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Return the next object on the queue.
nextEntry(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the next object on the queue.
nextEntry(Object) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return the next object on the queue.
nextEntry(Object, ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Return the next object on the queue.
nextEntry(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the next object on the queue.
nextEntry(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return the next object on the queue.
nextIndex() - Method in class org.eclipse.persistence.descriptors.partitioning.RoundRobinPartitioningPolicy
INTERNAL: Return the next pool index to use.
nextIndex() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Retrieves the next row index (against the current row)
nextKey - Variable in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMapEnumeration
Next key to be returned.
nextNode() - Method in class org.eclipse.persistence.internal.sessions.factories.NodeListElementEnumerator
 
nextObject - Variable in class org.eclipse.persistence.queries.ScrollableCursor
 
nextRow - Variable in class org.eclipse.persistence.queries.Cursor
Store the next row, for 1-m joining.
nil - Variable in class org.eclipse.persistence.internal.oxm.Root
 
NIL - Static variable in interface org.eclipse.persistence.internal.oxm.record.XMLRecord
Nil: This is used to indicate that this field represents xsi:nil="true"
NIL - Static variable in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL: Nil: This is used to indicate that this field represents xsi:nil="true"
nilComplex(XPathFragment, NAMESPACE_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
nilComplex(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
INTERNAL:
nilComplex(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
nilComplex(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Used when an nil attribute should be written
nillable() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlElementNillable
(Optional) Customize the element declaration to be nillable.
nilSimple(NAMESPACE_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
nilSimple(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
INTERNAL:
nilSimple(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
nilSimple(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Used when an nil attribute should be written
NL - Static variable in class org.eclipse.persistence.internal.helper.Helper
Store newline string
NO_APP_INFO_FOR_NULL - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
NO_ATTACHMENT_UNMARSHALLER_SET - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
NO_ATTRBUTE_VALUE_CONVERSION_TO_FIELD_VALUE_PROVIDED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_ATTRIBUTE_TRANSFORMATION_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_ATTRIBUTE_TYPE_SPECIFICATION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_ATTRIBUTES - Static variable in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
NO_ATTRIBUTES_FOR_REPORT_QUERY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
NO_CACHE - Static variable in class org.eclipse.persistence.queries.ModifyAllQuery
Cache usage flags
NO_CALL_OR_INTERACTION_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
NO_CASCADE - Static variable in class org.eclipse.persistence.internal.sessions.MergeManager
 
NO_CASCADE - Static variable in class org.eclipse.persistence.sessions.CopyGroup
Depth level indicating that NO relationships should be included in the copy.
NO_CLAUSE - Static variable in class org.eclipse.persistence.history.AsOfClause
 
NO_CONCRETE_CLASS_INDICATED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
NO_CONN_FACTORY - Static variable in exception org.eclipse.persistence.eis.EISException
 
NO_CONSTRUCTOR_INDIRECT_COLLECTION_CLASS - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_CONVERTER_DATA_TYPE_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_CONVERTER_OBJECT_TYPE_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_CORRESPONDING_SETTER_METHOD_DEFINED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_CURSOR_SUPPORT - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
NO_CUSTOM_QUERY_FOR_RETURNING_POLICY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_DESCRIPTOR_FOR_SUBCLASS - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
NO_DESCRIPTOR_FOUND - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
NO_DESCRIPTOR_WITH_MATCHING_ROOT_ELEMENT - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
NO_ENCODER_FOR_MIME_TYPE - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
NO_EXPIRY - Static variable in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
 
NO_EXPRESSION_BUILDER_CLASS_FOUND - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
NO_FIELD_NAME_FOR_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_FIELD_VALUE_CONVERSION_TO_ATTRIBUTE_VALUE_PROVIDED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_FIELDS - Static variable in class org.eclipse.persistence.mappings.DatabaseMapping
Used to reduce memory for mappings with no fields.
NO_FOREIGN_KEYS_ARE_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_ID_OR_KEY_ON_JOIN_TARGET - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
NO_ID_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
NO_LOCK - Static variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
 
NO_LOCK_CLAUSE - Static variable in class org.eclipse.persistence.internal.expressions.ForUpdateClause
 
NO_MAPPED_BY_ATTRIBUTE_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_MAPPING_FOR_ATTRIBUTENAME - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_MAPPING_FOR_ATTRIBUTENAME_IN_ENTITY_BEAN - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_MAPPING_FOR_MAP_ENTRY_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
NO_MAPPING_FOR_PRIMARY_KEY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_MAX - Static variable in class org.eclipse.persistence.sessions.server.ServerSession
 
NO_NS_SCHEMA_LOCATION - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
NO_OBJECT_FACTORY_OR_JAXB_INDEX_IN_PATH - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
NO_PK_ANNOTATIONS_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_PRIMARY_KEY - Static variable in class org.eclipse.persistence.queries.ReportQuery
 
NO_PROJECT_SPECIFIED_IN_PROPERTIES - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_PROPERTIES_FILE_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_REFERENCE_KEY_IS_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_RELATION_TABLE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_RELATION_TABLE_IN_MANY_TO_MANY_QUERY_KEY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
NO_RELATION_TABLE_MECHANISM - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_RETURN - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
NO_SESSION_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_SESSION_REGISTERED_FOR_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_SESSION_REGISTERED_FOR_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_SESSIONS_XML_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_SOURCE_RELATION_KEYS_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_SUB_CLASS_MATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_SUCH_FIELD_WHILE_INITIALIZING_ATTRIBUTES_IN_INSTANCE_VARIABLE_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_SUCH_METHOD_ON_FIND_OBSOLETE_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_SUCH_METHOD_ON_INITIALIZING_ATTRIBUTE_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_SUCH_METHOD_WHILE_CONSTRUCTOR_INSTANTIATION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_SUCH_METHOD_WHILE_CONSTRUCTOR_INSTANTIATION_OF_FACTORY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_SUCH_METHOD_WHILE_CONVERTING_TO_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_SUCH_METHOD_WHILE_INITIALIZING_ATTRIBUTES_IN_METHOD_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_SUCH_METHOD_WHILE_INITIALIZING_CLASS_EXTRACTION_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_SUCH_METHOD_WHILE_INITIALIZING_COPY_POLICY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_SUCH_METHOD_WHILE_INITIALIZING_INSTANTIATION_POLICY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_SUCH_WRITE_TRANSFORMATION_METHOD - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
NO_TABLES_TO_CREATE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_TARGET_FOREIGN_KEYS_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_TARGET_RELATION_KEYS_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NO_TEMPORAL_TYPE_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_TEMPORARY_CLASSLOADER_AVAILABLE - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
NO_TOPLINK_EJB_JAR_XML_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NO_TYPE_SPECIFIED_FOR_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
NO_VERSION_NUMBER_WHEN_DELETING - Static variable in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
NO_VERSION_NUMBER_WHEN_UPDATING - Static variable in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
NO_WEIGHT - Static variable in class org.eclipse.persistence.mappings.DatabaseMapping
Used to share integer instance to reduce memory.
noAppInfoForNull() - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to lookup an appinfo with a null property or type
noAttachmentUnmarshallerSet(String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
noAttributesForReportQuery(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
Oct 19, 2000 JED Added this method and exception value
noAttributeTransformationMethod(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noAttributeTypeSpecification(String, String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noAttributeValueConversionToFieldValueProvided(Object, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
NoCache - Static variable in class org.eclipse.persistence.config.CacheUsage
Configures a modify-all query to not invalidate the cache.
noCallOrInteractionSpecified() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
NoCascading - Static variable in class org.eclipse.persistence.config.CascadePolicy
 
NoCascading - Static variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
NoCascading - Static variable in class org.eclipse.persistence.queries.DatabaseQuery
 
noConcreteClassIndicated(AbstractRecord, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
noConnectionFactorySpecified() - Static method in exception org.eclipse.persistence.eis.EISException
 
noConstructorIndirectionContainerClass(ContainerIndirectionPolicy, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noConstructorWithString(Exception, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: thrown from InstanceClassConverter
NoConversion - Interface in org.eclipse.persistence.internal.helper
INTERNAL:
NOCONVERSION - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
noConverterDataTypeSpecified(Object, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noConverterObjectTypeSpecified(Object, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noCorrespondingSetterMethodDefined(Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noCursorSupport(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
noCustomQueryForReturningPolicy(String, String, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
node(Node, NAMESPACE_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
node(Node, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
Receive notification of a node.
node(Node, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Receive notification of a node.
node(Node, NamespaceResolver, String, String) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
Receive notification of a node.
node(Node, NamespaceResolver, String, String) - Method in class org.eclipse.persistence.oxm.record.FormattedOutputStreamRecord
Receive notification of a node.
node(Node, NamespaceResolver, String, String) - Method in class org.eclipse.persistence.oxm.record.FormattedWriterRecord
Receive notification of a node.
node(Node, NamespaceResolver, String, String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
node(Node, NamespaceResolver, String, String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
Receive notification of a node.
node(Node, NamespaceResolver, String, String) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Receive notification of a node.
node(Node, NamespaceResolver, String, String) - Method in class org.eclipse.persistence.oxm.record.NodeRecord
 
node(Node, NamespaceResolver, String, String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
Receive notification of a node.
node(Node, NamespaceResolver, String, String) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
node(Node, NamespaceResolver, String, String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
Receive notification of a node.
node(Node, NamespaceResolver, String, String) - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
node(Node, NamespaceResolver, String, String) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
NODE - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
nodeClass - Variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
nodeFor(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
 
nodeFor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
 
NodeListElementEnumerator - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL:
NodeListElementEnumerator(NodeList) - Constructor for class org.eclipse.persistence.internal.sessions.factories.NodeListElementEnumerator
 
NodeOrderingPolicy - Class in org.eclipse.persistence.oxm.documentpreservation
Purpose:Provide a policy that specifies how new XML Elements are added to an existing XML Document.
NodeOrderingPolicy() - Constructor for class org.eclipse.persistence.oxm.documentpreservation.NodeOrderingPolicy
Default constructor.
NodeOrderingPolicyConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.login
 
NodeOrderingPolicyConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.login.NodeOrderingPolicyConfig
Default constructor.
NodeRecord - Class in org.eclipse.persistence.oxm.record
Use this type of MarshalRecord when the marshal target is a Node.
NodeRecord() - Constructor for class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL: Default constructor.
NodeRecord(String) - Constructor for class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL: Create a record with the root element name.
NodeRecord(String, NamespaceResolver) - Constructor for class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL: Create a record with the root element name get the namespace URI from the namespaceResolver.
NodeRecord(String, NamespaceResolver, Node) - Constructor for class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL: Create a record with the local root element name, that is a child of the parent.
NodeRecord(String, Node) - Constructor for class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL: Create a record with the local root element name, that is a child of the parent.
NodeRecord(Node) - Constructor for class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL: Create a record with the element.
NodeRecord.NodeRecordContentHandler - Class in org.eclipse.persistence.oxm.record
This class will typically be used in conjunction with an XMLFragmentReader.
NodeRecordContentHandler(NodeRecord, NamespaceResolver) - Constructor for class org.eclipse.persistence.oxm.record.NodeRecord.NodeRecordContentHandler
 
nodes - Variable in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
 
nodes - Variable in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
NODES - org.eclipse.persistence.oxm.annotations.XmlVirtualAccessMethodsSchema
Virtual properties are written to the schema as individual nodes (default).
noDescriptorForClassFromInheritancePolicy(DatabaseQuery, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
noDescriptorFound(Mapping) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
noDescriptorFound(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
noDescriptorWithMatchingRootElement(String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
NodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
NodeValue() - Constructor for class org.eclipse.persistence.internal.oxm.NodeValue
 
NoDocumentPreservationPolicyConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.login
 
NoDocumentPreservationPolicyConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.login.NoDocumentPreservationPolicyConfig
Default constructor.
noEncoderForMimeType(String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
noEntry - Static variable in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: indicator showing that no entry exists for a given key.
NoExpiryCacheInvalidationPolicy - Class in org.eclipse.persistence.descriptors.invalidation
PUBLIC: A cache invalidation policy in which no objects will expire.
NoExpiryCacheInvalidationPolicy() - Constructor for class org.eclipse.persistence.descriptors.invalidation.NoExpiryCacheInvalidationPolicy
 
noExpressionBuilderFound(Expression) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
noFieldNameForMapping(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noFieldValueConversionToAttributeValueProvided(Object, DatabaseField, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noForeignKeysAreSpecified(ForeignReferenceMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
NoIdentityMap - Class in org.eclipse.persistence.internal.identitymaps
Purpose: Provide the capability to not cache objects at all.
NoIdentityMap(int, ClassDescriptor, AbstractSession, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
 
NoIdentityMap_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
NoIndirectionPolicy - Class in org.eclipse.persistence.internal.indirection
Purpose
NoIndirectionPolicy() - Constructor for class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Construct a new indirection policy.
noKeyOrIDPropertyOnJoinTarget(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: The target class has no ID or Key properties set.
NoLock - Static variable in class org.eclipse.persistence.config.PessimisticLock
 
noMappedByAttributeFound(Object, String, Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noMappingForMapEntryExpression(Expression) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
noMappingForPrimaryKey(DatabaseField, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
NON_ENTITY_AS_TARGET_IN_RELATIONSHIP - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NON_EXISTENT_PROPERTY_IN_PROP_ORDER - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
NON_JTA_DATASOURCE - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
NON JTA DataSource.
NON_JTA_DATASOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.nonJtaDataSource" property specifies the non-JTA data source name that will look up a valid DataSource.
NON_NEGATIVE_INTEGER - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
NON_NEGATIVE_INTEGER_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
NON_PARSE_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
NON_POSITIVE_INTEGER - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
NON_POSITIVE_INTEGER_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
NON_READ_ONLY_MAPPED_TENANT_DISCRIMINATOR_FIELD - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NON_UNIQUE_ENTITY_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NON_UNIQUE_MAPPING_FILE_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NON_UNIQUE_REPOSITORY_FILE_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
noNamespaceSchemaLocation - Variable in class org.eclipse.persistence.internal.oxm.Root
 
Noncacheable - Annotation Type in org.eclipse.persistence.annotations
The NonCacheable annotation is used to configure caching behavior for relationships.
nonDeferredCreateTime - Variable in class org.eclipse.persistence.descriptors.CMPPolicy
This setting will allow customers to control when Toplink will issue the insert SQL for CMP beans.
None - Static variable in class org.eclipse.persistence.config.BatchWriting
 
None - Static variable in class org.eclipse.persistence.config.CommitOrderType
No ordering is done.
None - Static variable in class org.eclipse.persistence.config.ParserValidationType
 
None - Static variable in class org.eclipse.persistence.config.TargetServer
 
None - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
NONE - org.eclipse.persistence.annotations.CacheCoordinationType
Does no cache coordination.
NONE - org.eclipse.persistence.annotations.CacheType
WARNING: Does not preserve object identity and does not cache objects.
NONE - org.eclipse.persistence.annotations.DatabaseChangeNotificationType
No database change events will be processed.
NONE - org.eclipse.persistence.annotations.IdValidation
No identifier validation is performed.
NONE - org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy.LockOnChange
 
NONE - org.eclipse.persistence.sessions.UnitOfWork.CommitOrderType
No ordering is done.
NONE - Static variable in annotation type org.eclipse.persistence.annotations.Convert
Constant name for no converter.
NONE - Static variable in class org.eclipse.persistence.config.CacheType
NONE does not cache any objects.
NONE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "none" specifies that database tables should not be created or dropped.
NONE - Static variable in class org.eclipse.persistence.descriptors.CMPPolicy
defer no changes
NONE - Static variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Specify no join fetch, this is the default.
NONE - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Names of the possible lock mode types, JPA 2.0 only
NONE - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
nonEntityTargetInRelationship(Object, Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noneOf(String, Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Returns an expression equivalent to none of attributeName holding true for criteria.
nonExistantOrderByAlias - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
nonExistantOrderByAlias(String, int, int, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
nonExistentPropertyInPropOrder(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
nonFetchJoinAttributeExpressions - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Stores the non fetchjoin attributes, these are joins that will be represented in the where clause but not in the select.
nonNullString(String) - Static method in class org.eclipse.persistence.internal.helper.StringHelper
Never return null but replace it with "null" String.
nonParseException(Throwable) - Static method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
nonPrimaryKeyMappings - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
All mapping other than primary key mappings.
nonReadOnlyMappedTenantDiscriminatorField(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
NonreflectiveAttributeDefinition - Class in org.eclipse.persistence.internal.codegen
INTERNAL:
NonreflectiveAttributeDefinition() - Constructor for class org.eclipse.persistence.internal.codegen.NonreflectiveAttributeDefinition
 
NonreflectiveMethodDefinition - Class in org.eclipse.persistence.internal.codegen
INTERNAL:
NonreflectiveMethodDefinition() - Constructor for class org.eclipse.persistence.internal.codegen.NonreflectiveMethodDefinition
 
nonSelectFields - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Fields not being selected (can include expressions).
NonSynchronizedProperties - Class in org.eclipse.persistence.internal.helper
Properties subclass that removes the synchronization.
NonSynchronizedProperties(int) - Constructor for class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
NonSynchronizedSubVector<E> - Class in org.eclipse.persistence.internal.helper
SubList that implements Vector.
NonSynchronizedSubVector(Vector<E>, int, int) - Constructor for class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
NonSynchronizedVector<E> - Class in org.eclipse.persistence.internal.helper
Vector subclass that removes the synchronization.
NonSynchronizedVector() - Constructor for class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
NonSynchronizedVector(int) - Constructor for class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
NonSynchronizedVector(int, int) - Constructor for class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
NonSynchronizedVector(Collection<? extends E>) - Constructor for class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
nonUniqueEntityName(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
nonUniqueMappingFileName(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
nonUniqueRepositoryFileName(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
NONVALIDATING - Static variable in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
NONVALIDATING - Static variable in class org.eclipse.persistence.oxm.XMLUnmarshaller
 
NONVALIDATING - Static variable in class org.eclipse.persistence.oxm.XMLValidator
 
NONVALIDATING - Static variable in interface org.eclipse.persistence.platform.xml.XMLParser
 
noObjectFactoryOrJaxbIndexInPath(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
noPrimaryKeyAnnotationsFound(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
NoProfiler - Static variable in class org.eclipse.persistence.config.ProfilerType
 
noPropertiesFileFound(Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noReferenceKeyIsSpecified(ForeignReferenceMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noRelationTable(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noRelationTableInManyToManyQueryKey(ManyToManyQueryKey, Expression) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
noRelationTableMechanism(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
NORMAL - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
Define valid descriptor types.
NORMAL - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
NORMAL_DESCRIPTORS_DO_NOT_SUPPORT_NON_RELATIONAL_EXTENSIONS - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
normalDescriptorsDoNotSupportNonRelationalExtensions(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
normalize(ExpressionNormalizer) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Normalize into a structure that is printable.
normalize(ExpressionNormalizer) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Normalize the expression into a printable structure.
normalize(ExpressionNormalizer) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: Normalize into a structure that is printable.
normalize(ExpressionNormalizer) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: Normalize collection of values if they are expressions.
normalize(ExpressionNormalizer) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL: Normalize the expression into a printable structure.
normalize(ExpressionNormalizer) - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: Normalize the expression into a printable structure.
normalize(ExpressionNormalizer) - Method in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
INTERNAL: Normalize the expression into a printable structure.
normalize(ExpressionNormalizer) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Normalize into a structure that is printable.
normalize(ExpressionNormalizer) - Method in class org.eclipse.persistence.internal.expressions.IndexExpression
INTERNAL: Normalize the expression into a printable structure.
normalize(ExpressionNormalizer) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Normalize the expression into a printable structure.
normalize(ExpressionNormalizer) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
INTERNAL: Check for object comparison as this requires for the expression to be replaced by the object comparison.
normalize(ExpressionNormalizer) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
INTERNAL: The subquery must be normalized with the knowledge of the outer statement for outer references and correct aliasing.
normalize(ExpressionNormalizer) - Method in class org.eclipse.persistence.internal.expressions.TableExpression
INTERNAL: Normalize the expression into a printable structure.
normalize(ExpressionNormalizer, Vector) - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
INTERNAL: For CR#2456 if this is part of an objExp.equal(objExp), do not need to add additional expressions to normalizer both times, and the foreign key join replaces the equal expression.
normalize(ExpressionNormalizer, Expression, List<Expression>) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: For CR#2456 if this is part of an objExp.equal(objExp), do not need to add additional expressions to normalizer both times, and the foreign key join replaces the equal expression.
normalize(ExpressionNormalizer, Expression, List<Expression>) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
normalize(AbstractSession, ClassDescriptor) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Normalize an expression into a printable structure.
normalize(AbstractSession, ClassDescriptor, Map) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Normalize an expression into a printable structure.
NORMALIZED_STRING - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
NORMALIZEDSTRING_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
normalizeForView(AbstractSession, ClassDescriptor, Map) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Normalize an expression mapping all of the descriptor's tables to the view.
normalizeOrderBy(Expression, List<Expression>, Map<Expression, Expression>, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Check the order by for object expressions.
normalizeStringValue(String) - Method in interface org.eclipse.persistence.internal.oxm.ConversionManager
Replaces any CR, Tab or LF characters in the string with a single ' ' character.
normalizeStringValue(String) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Replaces any CR, Tab or LF characters in the string with a single ' ' character.
normalizeSubSelect(ExpressionNormalizer, Map) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
INTERNAL: Normalize this expression now that the parent statement has been normalized.
normalizeSubSelects(Map) - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
INTERNAL: Normalize all subselect expressions found in the course of normalizing the enclosing query.
noRowsModified(ModifyQuery, Object) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Raised for stored proc output parameters.
noRowsModified(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
noRowsModified(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the session after update or delete SQL has been sent to the database but a row count of zero was returned.
NoRowsModified - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
NoServerPlatform - Class in org.eclipse.persistence.platform.server
PUBLIC: This platform is used when EclipseLink is not within any server (Oc4j, WebLogic, ...) This is also the default platform for all newly created DatabaseSessions.
NoServerPlatform(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.NoServerPlatform
INTERNAL: Default Constructor: Initialize so that runtime services and JTA are disabled.
NoServerPlatformDetector - Class in org.eclipse.persistence.platform.server
 
NoServerPlatformDetector() - Constructor for class org.eclipse.persistence.platform.server.NoServerPlatformDetector
Default constructor.
noSessionFound(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noSessionRegisteredForClass(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noSessionRegisteredForName(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noSessionsXMLFound(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noSourceRelationKeysSpecified(ForeignReferenceMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
NOSQL_CONNECTION_FACTORY - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.nosql.connection-factory" property allows the JCA ConnectionFactory to be specified for a NoSQL or EIS adapter.
NOSQL_CONNECTION_SPEC - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.nosql.connection-spec" property allows the connection information for an NoSQL or EIS datasource to be specified.
NOSQL_PASSWORD - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.nosql.property.password" property specifies password for NoSQL connection.
Note that "jakarta.persistence.jdbc.password" is also supported.
NOSQL_PROPERTY - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.nosql.property." property prefix allows setting NoSQL connection properties.
NOSQL_USER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.nosql.property.user" property specifies user name for NoSQL connection.
Note that "jakarta.persistence.jdbc.user" is also supported.
noSubClassMatch(Class<?>, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noSuchFieldWhileInitializingAttributesInInstanceVariableAccessor(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noSuchMethodOnFindObsoleteMethod(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noSuchMethodOnInitializingAttributeMethod(String, DatabaseMapping, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noSuchMethodWhileConstructorInstantiation(ClassDescriptor, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noSuchMethodWhileConstructorInstantiationOfFactory(ClassDescriptor, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noSuchMethodWhileConvertingToMethod(String, DatabaseMapping, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noSuchMethodWhileInitializingAttributesInMethodAccessor(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noSuchMethodWhileInitializingClassExtractionMethod(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noSuchMethodWhileInitializingCopyPolicy(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noSuchMethodWhileInitializingInstantiationPolicy(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noSuchWriteTransformationMethod(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: Write transformation method does not exist, or has the wrong number or type of parameters.
not() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that is the boolean logical negation of the expression.
Not - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
NOT_DESERIALIZABLE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NOT_NULL_AND_NILLABLE - Static variable in exception org.eclipse.persistence.exceptions.BeanValidationException
 
NOT_POOLED - Static variable in class org.eclipse.persistence.sessions.server.ServerSession
 
NOT_SERIALIZABLE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NOT_SET - Static variable in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
 
NOT_SUPPORTED_FOR_DATASOURCE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
noTablesToCreate(Project) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noTargetForeignKeysSpecified(ForeignReferenceMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noTargetIdSpecified(String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when building an ObjectReferenceMapping and referenced object does not have an id property
noTargetRelationKeysSpecified(ForeignReferenceMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
NOTATION - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
NOTATION_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
notBetween() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the NOT BETWEEN operator
notBetween(byte, byte) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not between two other values.
notBetween(char, char) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not between two other values.
notBetween(double, double) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not between two other values.
notBetween(float, float) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not between two other values.
notBetween(int, int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not between two other values.
notBetween(long, long) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not between two other values.
notBetween(short, short) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not between two other values.
notBetween(Object, Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not between two other values.
notBetween(Expression, Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not between two other values.
NotBetween - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
notBetweenOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
DB2 z/OS requires that at least one argument be a known type
notBetweenOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
NotConform - Static variable in class org.eclipse.persistence.config.CacheUsageIndirectionPolicy
If conforming encounters an uninstantiated indirection/lazy object it is assumed to not conform.
notDeserializable(DatabaseMapping, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
noTemporalTypeSpecified(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noTemporaryClassLoaderAvailable(String) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
INTERNAL: The implementation of getNewTempClassLoader is returning null instead of a temporary ClassLoader instance.
notEmpty(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: A logical expression for the collection attributeName not being empty.
notEqual() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
 
notEqual(boolean) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not equal to the other value.
notEqual(byte) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not equal to the other value.
notEqual(char) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not equal to the other value.
notEqual(double) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not equal to the other value.
notEqual(float) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not equal to the other value.
notEqual(int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not equal to the other value.
notEqual(long) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not equal to the other value.
notEqual(short) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not equal to the other value.
notEqual(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not equal to the other value.
notEqual(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not equal to the other value.
NotEqual - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
notEqualOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
DB2 z/OS requires that at least one argument be a known type
notEqualOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
notExists() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the NOT EXISTS operator.
notExists(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a sub query expression.
NotExists - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
notifyEJB30Listeners(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: Notify the EJB 3.0 event listeners.
notifyListener(DescriptorEventListener, DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: Big ugly case statement to notify listeners.
notifyListeners(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: Notify the event listeners.
notifyReferencingDescriptorsOfIsolation(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Configure all descriptors referencing this class to be protected and update their cache settings.
NoTimeout - Static variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
queryTimeout has three possible settings: DefaultTimeout, NoTimeout, and 1..N This applies to both DatabaseQuery.queryTimeout and DescriptorQueryManager.queryTimeout DatabaseQuery.queryTimeout: - DefaultTimeout: get queryTimeout from DescriptorQueryManager - NoTimeout, 1..N: overrides queryTimeout in DescriptorQueryManager DescriptorQueryManager.queryTimeout: - DefaultTimeout: get queryTimeout from parent DescriptorQueryManager.
notIn() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the NOTIN operator.
notIn(boolean[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
notIn(byte[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
notIn(char[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
notIn(double[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
notIn(float[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
notIn(int[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
notIn(long[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
notIn(short[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
notIn(Object[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
notIn(Collection) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
notIn(Expression) - Method in class org.eclipse.persistence.expressions.Expression
 
notIn(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
 
NotIn - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
notInSubQuery() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the NOTIN operator taking a subQuery.
NotInSubQuery - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
notLike() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the NOTLIKE operator.
notLike(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not like the other value.
notLike(String, String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not like the other value.
notLike(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not like the other value.
notLike(Expression, Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value is not like the other value.
NotLike - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
notLikeEscape() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the LIKE operator with ESCAPE.
NotLikeEscape - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
notNull() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression representing a comparison to null
notNull() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the NOTNULL operator.
NotNull - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
notNullAndNillable(String) - Static method in exception org.eclipse.persistence.exceptions.BeanValidationException
 
notOperator() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the NOT operator.
noTopLinkEjbJarXMLFound() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
noTransactionOrRolledBackOrCommited() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Used the EJB 3.0 to determine if a transaction is in a state where an EntityManager can be closed
notSerializable(DatabaseMapping, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
notSkip() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
notSupportedForDatasource() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
NotVisited - Static variable in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
notYetImplemented - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
notYetImplemented(String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
noTypeSpecifiedForProperty(String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when a property does not have a type specified
noVersionNumberWhenDeleting(Object, ObjectLevelModifyQuery) - Static method in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
noVersionNumberWhenUpdating(Object, ObjectLevelModifyQuery) - Static method in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
ns - Variable in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
nsresolver - Variable in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
 
nsresolverList - Variable in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
 
NULL - org.eclipse.persistence.annotations.IdValidation
Only null is invalid All other values are considered valid.
NULL - org.eclipse.persistence.internal.mappings.converters.AttributeNamePrefix
INTERNAL: No attribute name prefix.
NULL - Static variable in class org.eclipse.persistence.internal.sessions.AggregateChangeRecord
 
NULL - Static variable in class org.eclipse.persistence.oxm.record.JsonRecord
 
NULL - Static variable in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
NULL() - Constructor for class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord.NULL
 
NULL_ARGUMENT - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
NULL_CACHE_KEY_FOUND_ON_REMOVAL - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NULL_FOR_NON_NULL_AGGREGATE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NULL_INPUT_STREAM - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
NULL_MAP_KEY - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
NULL_METADATA_FILE - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
NULL_METADATA_SOURCE - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
NULL_NODE - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
NULL_PK_IN_UOW_CLONE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NULL_POINTER_WHILE_CONSTRUCTOR_INSTANTIATION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NULL_POINTER_WHILE_CONSTRUCTOR_INSTANTIATION_OF_FACTORY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NULL_POINTER_WHILE_GETTING_VALUE_THRU_INSTANCE_VARIABLE_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NULL_POINTER_WHILE_GETTING_VALUE_THRU_METHOD_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NULL_POINTER_WHILE_GETTING_VALUE_THRU_METHOD_ACCESSOR_IN_MODULE_ORDER_BREAKS_WEAVING - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NULL_POINTER_WHILE_METHOD_INSTANTIATION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NULL_POINTER_WHILE_METHOD_INSTANTIATION_OF_FACTORY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NULL_POINTER_WHILE_SETTING_VALUE_THRU_INSTANCE_VARIABLE_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NULL_POINTER_WHILE_SETTING_VALUE_THRU_METHOD_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
NULL_PRIMARY_KEY_IN_BUILDING_OBJECT - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
NULL_SESSION_NAME - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
NULL_SOURCE - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
NULL_SQL_TYPE - Static variable in class org.eclipse.persistence.internal.helper.DatabaseField
used to represent the value when it has not being defined
NULL_STRING - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
"null" String.
NULL_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
NULL_TYPE_ON_TYPEMAPPINGINFO - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
NULL_UNDERLYING_VALUEHOLDER_VALUE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
NULL_VALUE - Static variable in class org.eclipse.persistence.internal.helper.Helper
Used to store null values in hashtables, is helper because need to be serializable.
NULL_VALUE_NOT_ALLOWED_FOR_VARIABLE - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
nullable - Variable in class org.eclipse.persistence.internal.descriptors.QueryArgument
 
nullableArguments - Variable in class org.eclipse.persistence.queries.DatabaseQuery
List of arguments to check for null.
nullArgumentException() - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
nullCacheKeyFoundOnRemoval(IdentityMap, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
NullCapableValue - Interface in org.eclipse.persistence.internal.oxm
INTERNAL:
nullForNonNullAggregate(Object, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
nullIf() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
nullIf(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function Test if arguments are equal, returning null if they are and the value of the first expression otherwise.
NullIf - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
nullifOperator() - Method in class org.eclipse.persistence.platform.database.DB2Platform
DB2 requires that at least one argument be a known type
nullInputStream() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception is thrown if the user tries bootstrap from XML Schema but provides a null InputStream parameter.
nullMapKey() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception would typically be used by JAXBContextFactory during externalized metadata processing (i.e.
nullMetadataSource() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception would typically be used by JAXBContextFactory during externalized metadata processing (i.e.
nullMetadataSource(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception would typically be used by JAXBContextFactory during externalized metadata processing (i.e.
nullNode() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception is thrown if the user tries bootstrap from XML Schema but provides a null Node parameter.
nullPointerWhileConstructorInstantiation(ClassDescriptor, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
nullPointerWhileConstructorInstantiationOfFactory(ClassDescriptor, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
nullPointerWhileGettingValueThruInstanceVariableAccessor(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
nullPointerWhileGettingValueThruMethodAccessor(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
nullPointerWhileGettingValueThruMethodAccessorCausedByWeavingNotOccurringBecauseOfModuleOrder(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
nullPointerWhileMethodInstantiation(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
nullPointerWhileMethodInstantiationOfFactory(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
nullPointerWhileSettingValueThruInstanceVariableAccessor(String, Object, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
nullPointerWhileSettingValueThruMethodAccessor(String, Object, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
NullPolicy - Class in org.eclipse.persistence.oxm.mappings.nullpolicy
PUBLIC: Description: This null policy is the default implementation class.
Marshal:
The boolean value of the isSet() state of a node has no effect on whether a node will be written out for a null value - a set is always performed unless the isSetPerformedForAbsentNode flag is set to false for absent nodes.
Unmarshal:
NullPolicy() - Constructor for class org.eclipse.persistence.oxm.mappings.nullpolicy.NullPolicy
Default Constructor
NullPolicy(String, boolean, boolean, boolean) - Constructor for class org.eclipse.persistence.oxm.mappings.nullpolicy.NullPolicy
Specific Constructor to set the Unmarshal flags
NullPolicy(String, boolean, boolean, boolean, XMLNullRepresentationType) - Constructor for class org.eclipse.persistence.oxm.mappings.nullpolicy.NullPolicy
Specific Constructor to set both the Marshal enum and the Unmarshal flags
NullPolicyAttributeAccessor() - Constructor for class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.NullPolicyAttributeAccessor
 
nullPrimaryKeyInBuildingObject(DatabaseQuery, AbstractRecord) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
nullPrimaryKeyInUnitOfWorkClone(Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
nullRepresentationForXml() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlIsSetNullPolicy
 
nullRepresentationForXml() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNullPolicy
 
nullSessionName() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception is thrown if the user tries bootstrap from sessions.xml but provides a null sessionNames parameter.
nullsFirst() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This can only be used within an ordering expression.
nullsFirst() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the NULLS FIRST ordering operator.
NullsFirst - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
nullsLast() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This can only be used within an ordering expression.
nullsLast() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the NULLS LAST ordering operator.
NullsLast - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
nullSource() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception is thrown if the user tries bootstrap from XML Schema but provides a null Source parameter.
nullTypeOnTypeMappingInfo(QName) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception should be used when a TypeMappingInfo is specified but the Type is not set on it.
nullUnderlyingValueHolderValue(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
nullValue - Variable in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
Support specification of the value to use for null.
nullValue - Variable in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
Support specification of the value to use for null.
nullValueFromRow() - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return the null value of the appropriate attribute.
nullValueFromRow() - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return the null value of the appropriate attribute.
nullValueFromRow() - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return the null value of the appropriate attribute.
nullValueFromRow() - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return the null value of the appropriate attribute.
nullValueFromRow() - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Return the null value of the appropriate attribute.
nullValueFromRow() - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the null value of the appropriate attribute.
nullValueInFields - Variable in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: flag for any database field containing a null value
nullValueNotAllowed(String, String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
NUM_OPERATIONS - Static variable in class org.eclipse.persistence.descriptors.ReturningPolicy
 
NUMBER - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
numberOfActiveUnitsOfWork - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Keep track of active units of work.
NumberOfEvents - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
numberOfInstancesEffected - Variable in class org.eclipse.persistence.tools.profiler.Profile
 
numberOfNonPooledConnectionsUsed - Variable in class org.eclipse.persistence.sessions.server.ServerSession
 
numberOfReaders - Variable in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
numberOfWritersWaiting - Variable in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
NUMERIC_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
numSessionsRequiringSequencingCallback - Variable in class org.eclipse.persistence.transaction.AbstractTransactionController
more - the session is a session broker with several members requiring sequencing callbacks.
numSessionsRequiringSequencingCallback() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Indicates how many sessions require sequencing callbacks.
NVARCHAR_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
NVARCHAR2_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
nvl() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Substitute a value when a null value is encountered.
Builds Symfoware equivalent to NVL(string, replace_with).
Symfoware: COALESCE(string, replace_with)
Nvl - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 

O

obj - Variable in class org.eclipse.persistence.internal.databaseaccess.BindCallCustomParameter
 
OBJ_NOT_FOUND_IN_CACHE - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
object - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
object - Variable in class org.eclipse.persistence.internal.indirection.TransformerBasedValueHolder
Stores the object which owns this attribute.
object - Variable in class org.eclipse.persistence.internal.indirection.UnitOfWorkTransformerValueHolder
 
object - Variable in class org.eclipse.persistence.internal.sessions.remote.ObjectDescriptor
The domain object
object - Variable in class org.eclipse.persistence.internal.sessions.remote.Transporter
Object(s) read from the server
object - Variable in class org.eclipse.persistence.queries.DoesExistQuery
 
object - Variable in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
 
OBJECT - org.eclipse.persistence.annotations.ChangeTrackingType
An OBJECT change tracking policy allows an object to calculate for itself whether it has changed.
OBJECT - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
OBJECT_CHANGED_SINCE_LAST_MERGE - Static variable in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
OBJECT_CHANGED_SINCE_LAST_READ_WHEN_DELETING - Static variable in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
OBJECT_CHANGED_SINCE_LAST_READ_WHEN_UPDATING - Static variable in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
Object_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
Deprecated.
OBJECT_COMPARISON_CANNOT_BE_PARAMETERIZED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
OBJECT_CYCLE_DETECTED - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
OBJECT_DOES_NOT_EXIST_IN_CACHE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
OBJECT_NEED_IMPL_TRACKER_FOR_FETCH_GROUP_USAGE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
OBJECT_REFERRED_BY_LINK_DOES_NOT_EXIST - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
OBJECT_TO_INSERT_IS_EMPTY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
OBJECT_TO_MODIFY_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
ObjectAdded - Static variable in class org.eclipse.persistence.mappings.ManyToManyMapping
 
ObjectAdded - Static variable in class org.eclipse.persistence.mappings.OneToManyMapping
 
objectAddedDuringUpdate(ObjectLevelModifyQuery, Object, ObjectChangeSet, Map) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: An object was added to the collection during an update, insert it if private.
objectAddedDuringUpdate(ObjectLevelModifyQuery, Object, ObjectChangeSet, Map) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: An object was added to the collection during an update, insert it if private.
objectAddedDuringUpdate(ObjectLevelModifyQuery, Object, ObjectChangeSet, Map) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: An object was added to the collection during an update, insert it if private.
objectAddedDuringUpdate(ObjectLevelModifyQuery, Object, ObjectChangeSet, Map) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: An object was added to the collection during an update, insert it if private.
ObjectArrayMapping - Class in org.eclipse.persistence.mappings.structures
Purpose: In an object-relational data model, structures can contain "Arrays" or collections of other data-types.
ObjectArrayMapping() - Constructor for class org.eclipse.persistence.mappings.structures.ObjectArrayMapping
 
objectBuilder - Variable in class org.eclipse.persistence.core.descriptors.CoreDescriptor
 
ObjectBuilder - Class in org.eclipse.persistence.internal.descriptors
Purpose: Object builder is one of the behavior class attached to descriptor.
ObjectBuilder<ABSTRACT_RECORD extends CoreAbstractRecord,​ABSTRACT_SESSION extends CoreAbstractSession,​DESCRIPTOR extends CoreDescriptor,​MARSHALLER extends Marshaller> - Interface in org.eclipse.persistence.internal.oxm
 
ObjectBuilder(ClassDescriptor) - Constructor for class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
ObjectBuilding - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
ObjectBuildingQuery - Class in org.eclipse.persistence.queries
Purpose: Abstract class for all read queries that build objects and potentially manipulate the TopLink cache.
ObjectBuildingQuery() - Constructor for class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Initialize the state of the query
objectChangedListOrderDuringUpdate(WriteObjectQuery, int, int, int) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
 
objectChangedListOrderDuringUpdate(WriteObjectQuery, Object, int) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
 
objectChangedSinceLastMerge(Object) - Static method in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
objectChangedSinceLastReadWhenDeleting(Object, ObjectLevelModifyQuery) - Static method in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
objectChangedSinceLastReadWhenUpdating(Object, ObjectLevelModifyQuery) - Static method in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
ObjectChangeListener - Class in org.eclipse.persistence.internal.descriptors.changetracking
Purpose: Define a listener for object change tracking.
ObjectChangeListener() - Constructor for class org.eclipse.persistence.internal.descriptors.changetracking.ObjectChangeListener
INTERNAL: Create a ObjectChangeListener
ObjectChangePolicy - Interface in org.eclipse.persistence.descriptors.changetracking
INTERNAL: Implementers of ObjectChangePolicy implement the code which computes changes sets for the UnitOfWork commit process.
objectChanges - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
This is the collection of ObjectChanges held by this ChangeSet
objectChangeSet - Variable in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
 
objectChangeSet - Variable in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
 
ObjectChangeSet - Class in org.eclipse.persistence.internal.sessions
Purpose: Hold the Records of change for a particular instance of an object.
ObjectChangeSet - Interface in org.eclipse.persistence.sessions.changesets
Purpose: Provides API to the Class that holds all changes made to a particular Object.
ObjectChangeSet() - Constructor for class org.eclipse.persistence.internal.sessions.ObjectChangeSet
The default constructor.
ObjectChangeSet(Object, ClassDescriptor, Object, UnitOfWorkChangeSet, boolean) - Constructor for class org.eclipse.persistence.internal.sessions.ObjectChangeSet
This constructor is used to create an ObjectChangeSet that represents a regular object.
ObjectChangeSet.ObjectChangeSetComparator - Class in org.eclipse.persistence.internal.sessions
Allow change sets to be compared by changes for batching.
ObjectChangeSetComparator() - Constructor for class org.eclipse.persistence.internal.sessions.ObjectChangeSet.ObjectChangeSetComparator
 
objectChangeSetToUOWClone - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
 
ObjectChangeTrackingPolicy - Class in org.eclipse.persistence.descriptors.changetracking
PUBLIC: A ObjectChangeTrackingPolicy allows an object to calculate for itself whether it should has changed by implementing ChangeTracker.
ObjectChangeTrackingPolicy() - Constructor for class org.eclipse.persistence.descriptors.changetracking.ObjectChangeTrackingPolicy
 
objectClass - Variable in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
Object type
objectClassName - Variable in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
 
objectCollection - Variable in class org.eclipse.persistence.queries.Cursor
Internal collection of objects.
objectComparisonsCannotBeParameterized(Expression) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
objectCycleDetected(String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
ObjectDescriptor - Class in org.eclipse.persistence.internal.sessions.remote
Stores object description.
ObjectDescriptor() - Constructor for class org.eclipse.persistence.internal.sessions.remote.ObjectDescriptor
 
objectDescriptors - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
Used only while refreshing objects on remote session
objectDescriptors - Variable in class org.eclipse.persistence.internal.sessions.remote.Transporter
 
objectDoesNotExistInCache(Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
ObjectExpression - Class in org.eclipse.persistence.internal.expressions
Superclass for any object type expressions.
ObjectExpression() - Constructor for class org.eclipse.persistence.internal.expressions.ObjectExpression
 
objectIsEasilyInstantiated(Object) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return whether the specified object can be instantiated without database access.
objectIsEasilyInstantiated(Object) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return whether the specified object can be instantiated without database access.
objectIsEasilyInstantiated(Object) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return whether the specified object can be instantiated without database access.
objectIsEasilyInstantiated(Object) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return whether the specified object can be instantiated without database access.
objectIsEasilyInstantiated(Object) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Return whether the specified object can be instantiated without database access.
objectIsEasilyInstantiated(Object) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return whether the specified object can be instantiated without database access.
objectIsInstantiated(Object) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return whether the specified object is instantiated.
objectIsInstantiated(Object) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return whether the specified object is instantiated.
objectIsInstantiated(Object) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return whether the specified object is instantiated.
objectIsInstantiated(Object) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return whether the specified object is instantiated.
objectIsInstantiated(Object) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Return whether the specified object is instantiated.
objectIsInstantiated(Object) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return whether the specified object is instantiated.
objectIsInstantiatedOrChanged(Object) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return whether the specified object is instantiated, or if it has changes.
objectIsInstantiatedOrChanged(Object) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return whether the specified object is instantiated, or if it has changes.
ObjectLevelModifyQuery - Class in org.eclipse.persistence.queries
Purpose: Abstract class for all object modify queries.
ObjectLevelModifyQuery() - Constructor for class org.eclipse.persistence.queries.ObjectLevelModifyQuery
PUBLIC: Initialize the state of the query.
ObjectLevelReadQuery - Class in org.eclipse.persistence.queries
Purpose: Abstract class for all read queries using objects.
ObjectLevelReadQuery() - Constructor for class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Initialize the state of the query
ObjectMarshalContext - Class in org.eclipse.persistence.internal.oxm.record
An implementation of MarshalContext for handling plain old java objects that are mapped to XML.
objectName - Variable in class org.eclipse.persistence.services.RuntimeServices
 
objectNeedImplTrackerForFetchGroupUsage(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
objectNotFoundInCache(String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
objectOrderChangedDuringUpdate(WriteObjectQuery, Object, int) - Method in class org.eclipse.persistence.mappings.CollectionMapping
 
objectOrderChangedDuringUpdate(WriteObjectQuery, Object, int) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
 
ObjectPersistenceRuntimeXMLProject - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: Define the TopLink OX project and descriptor information to read a OracleAS TopLink 10g (10.0.3) project from an XML file.
ObjectPersistenceRuntimeXMLProject() - Constructor for class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject
INTERNAL: Return a new descriptor project.
ObjectPersistenceRuntimeXMLProject_11_1_1 - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: Define the TopLink OX project and descriptor information to read an AS 11g (11.1.1) project from an XML file.
ObjectPersistenceRuntimeXMLProject_11_1_1() - Constructor for class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
ObjectPersistenceRuntimeXMLProject_11_1_1.IsSetNullPolicyIsSetParametersAttributeAccessor - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: Wrap the isset parameter object array as a Collection.
ObjectPersistenceRuntimeXMLProject_11_1_1.IsSetNullPolicyIsSetParameterTypesAttributeAccessor - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: Wrap the isset parameterType class array as a Collection
ObjectPersistenceRuntimeXMLProject_11_1_1.NullPolicyAttributeAccessor - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: If the policy is the default NullPolicy with defaults set - then represent this default policy by null.
ObjectPersistenceRuntimeXMLProject_11_1_1.ObjectTypeFieldAssociation - Class in org.eclipse.persistence.internal.sessions.factories
Inner class used to map Map containers where the key is String and the value is a DatabaseType.
ObjectPersistenceWorkbenchXMLProject - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: Amend the EclipseLink project and descriptor information to write out an EclipseLink project to an XML file, replacing actual .class references with String equivalents
ObjectPersistenceWorkbenchXMLProject() - Constructor for class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceWorkbenchXMLProject
INTERNAL: Return a new descriptor project.
ObjectReferenceChangeRecord - Class in org.eclipse.persistence.internal.sessions
Purpose: To record the changes for an attribute that references a single Object
ObjectReferenceChangeRecord - Interface in org.eclipse.persistence.sessions.changesets
Purpose: Provides API for the ObjectReferenceChangeRecord.
ObjectReferenceChangeRecord() - Constructor for class org.eclipse.persistence.internal.sessions.ObjectReferenceChangeRecord
INTERNAL: This default constructor.
ObjectReferenceChangeRecord(ObjectChangeSet) - Constructor for class org.eclipse.persistence.internal.sessions.ObjectReferenceChangeRecord
INTERNAL: This Constructor is used to create an ObjectReferenceChangeRecord With an owner
ObjectReferenceMapping - Class in org.eclipse.persistence.mappings
Purpose: Abstract class for 1:1, variable 1:1 and reference mappings
ObjectReferenceMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​UNMARSHAL_RECORD extends UnmarshalRecord,​XML_FIELD extends Field,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
ObjectReferenceMapping() - Constructor for class org.eclipse.persistence.mappings.ObjectReferenceMapping
 
ObjectRelationalDatabaseField - Class in org.eclipse.persistence.mappings.structures
INTERNAL: A database field of object-relational type: either a java.sql.Array, java.sql.Struct, or java.sql.Ref.
ObjectRelationalDatabaseField(String) - Constructor for class org.eclipse.persistence.mappings.structures.ObjectRelationalDatabaseField
 
ObjectRelationalDatabaseField(DatabaseField) - Constructor for class org.eclipse.persistence.mappings.structures.ObjectRelationalDatabaseField
 
ObjectRelationalDataTypeDescriptor - Class in org.eclipse.persistence.mappings.structures
Purpose: Differentiates object-relational descriptors from normal relational descriptors.
ObjectRelationalDataTypeDescriptor() - Constructor for class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
 
ObjectRemoved - Static variable in class org.eclipse.persistence.mappings.ManyToManyMapping
 
ObjectRemoved - Static variable in class org.eclipse.persistence.mappings.OneToManyMapping
 
objectRemovedDuringUpdate(ObjectLevelModifyQuery, Object, Map) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: An object was removed to the collection during an update, delete it if private.
objectRemovedDuringUpdate(ObjectLevelModifyQuery, Object, Map) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: An object was removed to the collection during an update, delete it if private.
objectRemovedDuringUpdate(ObjectLevelModifyQuery, Object, Map) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: An object was removed to the collection during an update, delete it if private.
objectRemovedDuringUpdate(ObjectLevelModifyQuery, Object, Map) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: An object was removed to the collection during an update, delete it if private.
objects - Variable in class org.eclipse.persistence.queries.DeleteAllQuery
List containing objects to be deleted, these should be removed from the identity map after deletion.
objectsAlreadyMerged - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
Used to unravel recursion.
objectsDeletedDuringCommit - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
objectsLockedForClone - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
This collection will be used to store those objects that are currently locked for the clone process.
objectsLockedForClone - Variable in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
 
objectsToDelete - Variable in class org.eclipse.persistence.internal.sessions.CommitManager
List of orphaned objects pending deletion.
objectToInsertIsEmpty(DatabaseTable) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
objectToModifyNotSpecified(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
objectToXML(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
PUBLIC: Convert the given object to an XML Document
objectToXML(Object, DESCRIPTOR, boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
INTERNAL: Convert the given object to an XML Document
objectToXML(Object, XMLDescriptor, boolean) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
INTERNAL: Convert the given object to an XML Document
objectToXML(Object, XMLDescriptor, XMLRecord, boolean, DocumentPreservationPolicy) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
INTERNAL: Convert the given object to an XML Document
objectToXML(Object, Node, DocumentPreservationPolicy) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
 
objectToXML(Object, Node, XMLDescriptor, XMLRecord, boolean, DocumentPreservationPolicy) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
 
objectToXMLNode(Object, ABSTRACT_SESSION, DESCRIPTOR, boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
INTERNAL: Like ObjectToXML but is may also return a document fragment instead of a document in the case of a non-root object.
objectToXMLNode(Object, Node, ABSTRACT_SESSION, DESCRIPTOR, boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
objectToXMLNode(Object, Node, AbstractSession, XMLDescriptor, boolean) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
 
objectType - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
objectType() - Method in annotation type org.eclipse.persistence.annotations.ObjectTypeConverter
(Optional) Specify the type stored on the entity.
objectType() - Method in annotation type org.eclipse.persistence.annotations.TypeConverter
(Optional) Specify the type stored on the entity.
ObjectTypeConverter - Class in org.eclipse.persistence.mappings.converters
Purpose: Object type converter is used to match a fixed number of database data values to Java object value.
ObjectTypeConverter - Annotation Type in org.eclipse.persistence.annotations
The ObjectTypeConverter annotation is used to specify a TopLink org.eclipse.persistence.mappings.converters.ObjectTypeConverter that converts a fixed number of database data value(s) to Java object value(s) during the reading and writing of a mapped attribute An ObjectTypeConverter must be be uniquely identified by name and can be defined at the class, field and property level and can be specified within an Entity, MappedSuperclass and Embeddable class.
ObjectTypeConverter() - Constructor for class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
PUBLIC: Default constructor.
ObjectTypeConverter(DatabaseMapping) - Constructor for class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
PUBLIC: Default constructor.
ObjectTypeConverters - Annotation Type in org.eclipse.persistence.annotations
An ObjectTypeConverters annotation allows the definition of multiple ObjectTypeConverter.
ObjectTypeFieldAssociation() - Constructor for class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.ObjectTypeFieldAssociation
 
ObjectTypeFieldAssociation(String, DatabaseTypeWrapper) - Constructor for class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.ObjectTypeFieldAssociation
 
objectTypeName - Variable in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
objectUnchangedDuringUpdate(ObjectLevelModifyQuery, Object) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: An object is still in the collection, update it as it may have changed.
objectUnchangedDuringUpdate(ObjectLevelModifyQuery, Object, Object) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
 
objectUnchangedDuringUpdate(ObjectLevelModifyQuery, Object, Map, Object) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: An object is still in the collection, update it as it may have changed.
objectUnchangedDuringUpdate(ObjectLevelModifyQuery, Object, Map, Object) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: An object is still in the collection, update it as it may have changed.
ObjectUnmarshalContext - Class in org.eclipse.persistence.internal.oxm.record
An implementation of UnmarshalContext for handling plain old java objects that are mapped to XML.
ObjectUnmarshalContext() - Constructor for class org.eclipse.persistence.internal.oxm.record.ObjectUnmarshalContext
 
objectValue() - Method in annotation type org.eclipse.persistence.annotations.ConversionValue
(Required) Specify the object value.
ObjectVarrayDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Allow for creation of object varray type.
ObjectVarrayDefinition() - Constructor for class org.eclipse.persistence.tools.schemaframework.ObjectVarrayDefinition
 
objID - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoveServerSideRemoteValueHolderCommand
 
occurred(String, AbstractSession) - Method in interface org.eclipse.persistence.sessions.SessionProfiler
INTERNAL: Increase DMS Event sensor occurrence.(DMS)
occurred(String, AbstractSession) - Method in class org.eclipse.persistence.sessions.SessionProfilerAdapter
INTERNAL: Increase DMS Event sensor occurrence.(DMS)
occurred(String, AbstractSession) - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
occurred(String, DatabaseQuery, AbstractSession) - Method in interface org.eclipse.persistence.sessions.SessionProfiler
INTERNAL: Increase DMS Event sensor occurrence.(DMS)
occurred(String, DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.sessions.SessionProfilerAdapter
INTERNAL: Increase DMS Event sensor occurrence.(DMS)
occurred(String, DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
Occurs - Class in org.eclipse.persistence.internal.oxm.schema.model
 
Occurs() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Occurs
 
OFF - org.eclipse.persistence.logging.LogLevel
Logging is turned off.
OFF - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
OFF_LABEL - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
OLD_COMMIT_NOT_SUPPORTED_FOR_ATTRIBUTE_TRACKING - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
OLD_SEQUENCE_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
oldCommitNotSupportedForAttributeTracking() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
OldDescriptorEvent_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
oldKey - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
oldSequenceNotFound() - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when old sequence is not found in the changesummary
oldSize - Variable in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
oldValue - Variable in class org.eclipse.persistence.internal.sessions.AggregateChangeRecord
 
oldValue - Variable in class org.eclipse.persistence.internal.sessions.DirectToFieldChangeRecord
 
oldValue - Variable in class org.eclipse.persistence.internal.sessions.ObjectReferenceChangeRecord
A reference to the old value must also be stored.
oldValue - Variable in class org.eclipse.persistence.internal.sessions.TransformationMappingChangeRecord
 
ON_CONNECTION_ERROR_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
ON_CYCLE_DETECTED - Static variable in class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
onAddDescriptors(Collection<ClassDescriptor>) - Method in interface org.eclipse.persistence.internal.sequencing.SequencingHome
 
onClause - Variable in class org.eclipse.persistence.internal.expressions.ObjectExpression
Allow for an ON clause to be specified on a join condition.
onConnect() - Method in class org.eclipse.persistence.sequencing.DefaultSequence
INTERNAL: This method is called when Sequencing object is created.
onConnect() - Method in class org.eclipse.persistence.sequencing.NativeSequence
INTERNAL:
onConnect() - Method in class org.eclipse.persistence.sequencing.QuerySequence
INTERNAL:
onConnect() - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: This method is called when Sequencing object is created.
onConnect() - Method in class org.eclipse.persistence.sequencing.StandardSequence
 
onConnect() - Method in class org.eclipse.persistence.sequencing.TableSequence
 
onConnect() - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
INTERNAL:
onConnect() - Method in class org.eclipse.persistence.sequencing.UUIDSequence
 
onConnect(Platform) - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: This method is called when Sequencing object is created.
onDisconnect() - Method in class org.eclipse.persistence.sequencing.DefaultSequence
INTERNAL: This method is called when Sequencing object is destroyed..
onDisconnect() - Method in class org.eclipse.persistence.sequencing.NativeSequence
INTERNAL:
onDisconnect() - Method in class org.eclipse.persistence.sequencing.QuerySequence
INTERNAL:
onDisconnect() - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: This method is called when Sequencing object is destroyed.
onDisconnect() - Method in class org.eclipse.persistence.sequencing.StandardSequence
 
onDisconnect() - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
INTERNAL:
onDisconnect() - Method in class org.eclipse.persistence.sequencing.UUIDSequence
 
onDisconnect(Platform) - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: This method is called when Sequencing object is destroyed.
ONE - Static variable in class org.eclipse.persistence.internal.oxm.schema.model.Occurs
 
ONE_TO_ONE_MAPPING_CONFLICT - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ONETOMANY_DEFER_INSERTS - Static variable in class org.eclipse.persistence.config.SystemProperties
This property can be set to false to enable UPDATE call to set foreign key value in the target row in unidirectional 1-Many mapping with not nullable FK.
OneToManyMapping - Class in org.eclipse.persistence.mappings
Purpose: This mapping is used to represent the typical RDBMS relationship between a single source object and collection of target objects; where, on the database, the target objects have references (foreign keys) to the source object.
OneToManyMapping() - Constructor for class org.eclipse.persistence.mappings.OneToManyMapping
PUBLIC: Default constructor.
OneToManyQueryKey - Class in org.eclipse.persistence.mappings.querykeys
Purpose:Represents a 1-m join query.
OneToManyQueryKey() - Constructor for class org.eclipse.persistence.mappings.querykeys.OneToManyQueryKey
 
OneToOneMapping - Class in org.eclipse.persistence.mappings
Purpose: One to one mappings are used to represent a pointer references between two java objects.
OneToOneMapping() - Constructor for class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Default constructor.
OneToOneMapping.ShallowMode - Enum in org.eclipse.persistence.mappings
Mode for writeFromObjectIntoRowInternal method
oneToOneMappingConflict(ClassDescriptor, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
OneToOneQueryKey - Class in org.eclipse.persistence.mappings.querykeys
Purpose: Define an alias to a foreign one to one object.
OneToOneQueryKey() - Constructor for class org.eclipse.persistence.mappings.querykeys.OneToOneQueryKey
Default constructor.
ONLY_FIELDS_ARE_VALID_KEYS_FOR_DATABASE_ROWS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ONLY_ONE_GENERATED_VALURE_IS_ALLOWED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ONLY_ONE_TABLE_CAN_BE_ADDED_WITH_THIS_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
onlyFieldsAreValidKeysForDatabaseRows() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
onlyInstancesExpression - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
onlyOneGeneratedValueIsAllowed(Object, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
onlyOneTableCanBeAddedWithThisMethod(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
onlyRefreshCacheIfNewerVersion() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This method is the equivalent of calling ClassDescriptor.setShouldOnlyRefreshCacheIfNewerVersion(boolean) with an argument of true: it configures a ClassDescriptor to only refresh the cache if the data received from the database by a query is newer than the data in the cache (as determined by the optimistic locking field) and as long as one of the following is true: the ClassDescriptor was configured by calling ClassDescriptor.alwaysRefreshCache() or ClassDescriptor.alwaysRefreshCacheOnRemote(), the query was configured by calling ObjectLevelReadQuery.refreshIdentityMapResult(), or the query was a call to Session.refreshObject(java.lang.Object)
onMessage(Message) - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: Process received JMS message.
onUnfetchedAttribute(FetchGroupTracker, String) - Method in class org.eclipse.persistence.internal.queries.EntityFetchGroup
Called on attempt to get value of an attribute that hasn't been fetched yet.
onUnfetchedAttribute(FetchGroupTracker, String) - Method in class org.eclipse.persistence.queries.FetchGroup
INTERNAL: Called on attempt to get value of an attribute that hasn't been fetched yet.
onUnfetchedAttributeForSet(FetchGroupTracker, String) - Method in class org.eclipse.persistence.internal.queries.EntityFetchGroup
Called on attempt to assign value to an attribute that hasn't been fetched yet.
onUnfetchedAttributeForSet(FetchGroupTracker, String) - Method in class org.eclipse.persistence.queries.FetchGroup
INTERNAL: Called on attempt to assign value to an attribute that hasn't been fetched yet.
OPEN_CDATA - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
OPEN_COMMENT - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
OPEN_ENCODING_ATTRIBUTE - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
OPEN_START_ELEMENT - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
OPEN_XML_PI_AND_VERSION_ATTRIBUTE - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
openLoggingFileException(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.StaticWeaveException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
openStartElement(XPathFragment, NAMESPACE_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
openStartElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
INTERNAL:
openStartElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.FormattedOutputStreamRecord
INTERNAL:
openStartElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.FormattedWriterRecord
INTERNAL:
openStartElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
INTERNAL:
openStartElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
openStartElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
openStartElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Receive notification that an element is being started.
openStartElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL:
openStartElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL:
openStartElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
openStartElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL:
openStartElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
openStartElement(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
openStartGroupingElements(NAMESPACE_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
openStartGroupingElements(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
INTERNAL: Trigger that the grouping elements should be written.
openStartGroupingElements(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
OPERATION_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
OPERATION_PROPERTY_IS_NOT_SET - Static variable in exception org.eclipse.persistence.eis.EISException
 
operationNotSupported(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
operationPropertyIsNotSet() - Static method in exception org.eclipse.persistence.eis.EISException
 
operationStartTimesByThread - Variable in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
operationStartTimesByThread - Variable in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
operationTimings - Variable in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
operationTimings - Variable in class org.eclipse.persistence.tools.profiler.Profile
 
operationTimingsByThread - Variable in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
operator - Variable in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
operator - Variable in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
operator(String, List) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: This can be used for accessing user defined operators that have arguments.
operatorLocate() - Static method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Used by derived platforms (Oracle8Platform and higher) to indicate whether app.
operatorLocate() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Override the default locate operator.
operatorLocate2() - Static method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Override the default locate operator
operatorLocate2() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Override the default locate operator.
operatorOuterJoin() - Static method in class org.eclipse.persistence.platform.database.OraclePlatform
Create the outer join operator for this platform
operatorOuterJoin() - Static method in class org.eclipse.persistence.platform.database.SQLServerPlatform
 
operatorOuterJoin() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
Create the outer join operator for this platform
operatorOuterJoin() - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
TimesTen uses the Oracle where clause style outer join.
OPM_NAMESPACE - Static variable in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
OPM_PREFIX - Static variable in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
OPM_SCHEMA - Static variable in class org.eclipse.persistence.sessions.factories.XMLProjectReader
 
OPTIMISTIC - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
OPTIMISTIC_FORCE_INCREMENT - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
OPTIMISTIC_LOCKING_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
OPTIMISTIC_LOCKING_SELECTED_COLUMN_NAMES_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
OPTIMISTIC_LOCKING_VERSION_ELEMENT_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
OptimisticLockException - Exception in org.eclipse.persistence.exceptions
Purpose: This exception is used when TopLink's optimistic locking feature is used.
OptimisticLockException - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
OptimisticLockException() - Constructor for exception org.eclipse.persistence.exceptions.OptimisticLockException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
OptimisticLockException(String) - Constructor for exception org.eclipse.persistence.exceptions.OptimisticLockException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
OptimisticLockException(String, ObjectLevelModifyQuery) - Constructor for exception org.eclipse.persistence.exceptions.OptimisticLockException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
OptimisticLockExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for OptimisticLockException messages.
OptimisticLockExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.OptimisticLockExceptionResource
Default constructor.
OptimisticLocking - Annotation Type in org.eclipse.persistence.annotations
The OptimisticLocking annotation is used to specify the type of optimistic locking TopLink should use when updating or deleting entities.
optimisticLockingNotSupportedWithStoredProcedureGeneration() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
optimisticLockingPolicy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
optimisticLockingPolicy - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Used in mergeObjectChanges method for writeLock and initialWriteLock comparison of the merged change sets
OptimisticLockingPolicy - Interface in org.eclipse.persistence.internal.descriptors
 
OptimisticLockingPolicy.LockOnChange - Enum in org.eclipse.persistence.internal.descriptors
Advanced:
optimisticLockingSelectedColumnNamesNotSpecified(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
OptimisticLockingType - Enum in org.eclipse.persistence.annotations
An enum that is used within the OptimisticLocking annotation.
optimisticLockingVersionElementNotSpecified(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
optimisticReadLockObjects - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Kept reference of read lock objects
OPTIMIZE_DATA_CONVERSION_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
optimizeData - Variable in class org.eclipse.persistence.internal.sessions.ResultSetRecord
 
optimizeDataConversion() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Enable driver level data conversion optimization.
optimizedClonedExpressions - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
It is used by subselect to re-normalize joins
optional() - Method in annotation type org.eclipse.persistence.annotations.StoredProcedureParameter
(Optional) Define if the parameter is required, or optional and defaulted by the procedure.
optional() - Method in annotation type org.eclipse.persistence.annotations.Transformation
(Optional) The optional element is a hint as to whether the value of the field or property may be null.
optional() - Method in annotation type org.eclipse.persistence.annotations.VariableOneToOne
(Optional) Whether the association is optional.
optional() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlTransformation
(Optional) The optional element is a hint as to whether the value of the field or property may be null.
optional() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLParameter
(Optional) Define if the parameter is required, or optional and defaulted by the procedure.
OPTIONAL - Static variable in class org.eclipse.persistence.internal.oxm.schema.model.Attribute
 
optionalArguments - Variable in class org.eclipse.persistence.queries.StoredProcedureCall
 
OPTIONS_MUST_BE_A_DATAOBJECT - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
optionsMustBeADataObject(Exception, String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: thrown from SDOXMLHelperDelegate
or() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the OR operator.
or(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that is the boolean logical combination of both expressions.
Or - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
Oracle - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
ORACLE_OBJECT_TYPE_NAME_NOT_DEFINED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ORACLE_OBJECT_TYPE_NOT_DEFINED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ORACLE_PROXY_TYPE - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
This property is used to specify proxy type that should be passed to OarcleConnection.openProxySession method.
ORACLE_PROXY_TYPE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.oracle.proxy-type" property is used to specify proxy type that should be passed to OracleConnection.openProxySession method.
ORACLE_VARRAY_MAXIMIM_SIZE_NOT_DEFINED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
Oracle10 - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
Oracle10Platform - Class in org.eclipse.persistence.platform.database
Purpose: Provides Oracle version specific behavior when org.eclipse.persistence.oracle bundle is not available.
Oracle10Platform() - Constructor for class org.eclipse.persistence.platform.database.Oracle10Platform
 
Oracle11 - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
Oracle11Platform - Class in org.eclipse.persistence.platform.database
Purpose: Provides Oracle version specific behavior when org.eclipse.persistence.oracle bundle is not available.
Oracle11Platform() - Constructor for class org.eclipse.persistence.platform.database.Oracle11Platform
 
Oracle12Platform - Class in org.eclipse.persistence.platform.database
Purpose: Provides Oracle version specific behavior when org.eclipse.persistence.oracle bundle is not available.
Oracle12Platform() - Constructor for class org.eclipse.persistence.platform.database.Oracle12Platform
 
Oracle18Platform - Class in org.eclipse.persistence.platform.database
 
Oracle18Platform() - Constructor for class org.eclipse.persistence.platform.database.Oracle18Platform
 
Oracle19Platform - Class in org.eclipse.persistence.platform.database
 
Oracle19Platform() - Constructor for class org.eclipse.persistence.platform.database.Oracle19Platform
 
Oracle21Platform - Class in org.eclipse.persistence.platform.database
 
Oracle21Platform() - Constructor for class org.eclipse.persistence.platform.database.Oracle21Platform
 
Oracle8 - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
Oracle8Platform - Class in org.eclipse.persistence.platform.database
Purpose: Provides Oracle version specific behavior when org.eclipse.persistence.oracle bundle is not available.
Oracle8Platform() - Constructor for class org.eclipse.persistence.platform.database.Oracle8Platform
Default constructor.
Oracle9 - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
Oracle9Platform - Class in org.eclipse.persistence.platform.database
Purpose: Provides Oracle version specific behavior when org.eclipse.persistence.oracle bundle is not available.
Oracle9Platform() - Constructor for class org.eclipse.persistence.platform.database.Oracle9Platform
 
Oracle9Specific - Interface in org.eclipse.persistence.internal.platform.database
Class used to define Oracle specific JDBC types.
OracleArray - Annotation Type in org.eclipse.persistence.platform.database.oracle.annotations
An OracleArray annotation is used to define an Oracle database VARRAY type.
OracleArrays - Annotation Type in org.eclipse.persistence.platform.database.oracle.annotations
An OracleArrays annotation allows the definition of multiple VARRAY types.
OracleArrayType - Class in org.eclipse.persistence.platform.database.oracle.jdbc
 
OracleArrayType() - Constructor for class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
 
OracleArrayTypeWrapper - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: a helper class that holds DatabaseType's.
OracleArrayTypeWrapper() - Constructor for class org.eclipse.persistence.internal.sessions.factories.OracleArrayTypeWrapper
 
OracleArrayTypeWrapper(DatabaseType) - Constructor for class org.eclipse.persistence.internal.sessions.factories.OracleArrayTypeWrapper
 
oracleDateName() - Static method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Oracle equivalent to DATENAME is TO_CHAR.
OracleDirectToXMLTypeMappingHelper - Class in org.eclipse.persistence.sessions.factories
Helper class to abstract the XML mapping for DirectToXMLType.
OracleDirectToXMLTypeMappingHelper() - Constructor for class org.eclipse.persistence.sessions.factories.OracleDirectToXMLTypeMappingHelper
Default constructor.
oracleDriverIs(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
INTERNAL: Return whether the specified Oracle JDBC driver is being used.
OracleJDBC - Static variable in class org.eclipse.persistence.config.BatchWriting
 
ORACLEJDBC10_1_0_2PROXYCONNECTOR_REQUIRES_INT_PROXYTYPE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ORACLEJDBC10_1_0_2PROXYCONNECTOR_REQUIRES_ORACLECONNECTION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ORACLEJDBC10_1_0_2PROXYCONNECTOR_REQUIRES_ORACLECONNECTION_VERSION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
oracleJDBC10_1_0_2ProxyConnectorRequiresIntProxytype() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
oracleJDBC10_1_0_2ProxyConnectorRequiresOracleConnection() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
oracleJDBC10_1_0_2ProxyConnectorRequiresOracleConnectionVersion() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
OracleObject - Annotation Type in org.eclipse.persistence.platform.database.oracle.annotations
An OracleObject annotation is used to define an Oracle database OBJECT type.
OracleObjects - Annotation Type in org.eclipse.persistence.platform.database.oracle.annotations
An OracleObjects annotation allows the definition of multiple Oracle OBJECT types.
OracleObjectType - Class in org.eclipse.persistence.platform.database.oracle.jdbc
 
OracleObjectType() - Constructor for class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
oracleObjectTypeIsNotDefined(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
oracleObjectTypeNameIsNotDefined(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
OracleObjectTypeWrapper - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: a helper class that holds DatabaseType's.
OracleObjectTypeWrapper() - Constructor for class org.eclipse.persistence.internal.sessions.factories.OracleObjectTypeWrapper
 
OracleObjectTypeWrapper(DatabaseType) - Constructor for class org.eclipse.persistence.internal.sessions.factories.OracleObjectTypeWrapper
 
ORACLEOCIPROXYCONNECTOR_REQUIRES_ORACLEOCICONNECTIONPOOL - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
oracleOCIProxyConnectorRequiresOracleOCIConnectionPool() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
OraclePlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides Oracle specific behavior.
OraclePlatform() - Constructor for class org.eclipse.persistence.platform.database.OraclePlatform
 
OraclePLSQLType - Interface in org.eclipse.persistence.platform.database.oracle.plsql
PUBLIC: Marker interface for Oracle PL/SQL types
OraclePLSQLTypes - Enum in org.eclipse.persistence.platform.database.oracle.plsql
PUBLIC: Oracle PL/SQL types
oracleVarrayMaximumSizeNotDefined(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
ORDER_BY_ID - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
ORDER_UPDATES - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
Deprecated.
since 2.6 replaced by PERSISTENCE_CONTEXT_COMMIT_ORDER
ORDER_UPDATES - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Deprecated.
orderByExpressions - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Order by clause for read all queries.
orderByExpressions - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
 
orderByExpressions - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
orderByExpressions - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Used for ordering support.
orderCommits() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
Calculate the commit order.
OrderCorrection - Annotation Type in org.eclipse.persistence.annotations
OrderCorrection annotation may be specified together with OrderColumn annotation.
orderCorrectionType - Variable in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
 
orderCorrectionType - Variable in class org.eclipse.persistence.mappings.CollectionMapping
Specifies what should be done if the list of values read from listOrserField is invalid (there should be no nulls, no duplicates, no "holes").
OrderCorrectionType - Enum in org.eclipse.persistence.annotations
The OrderCorrectionType enum is used with OrderCorrection annotation that could be applied together with OrderColumn annotation.
orderedAddObjectIndices - Variable in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Contains the added values index to the collection.
orderedAddObjects - Variable in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Contains the added values to the collection and their corresponding ChangeSets in order.
OrderedChangeObject - Class in org.eclipse.persistence.internal.sessions
INTERNAL: This is used to keep information on a single collection change for attribute change tracking on ordered lists.
OrderedChangeObject(int, Integer, ObjectChangeSet) - Constructor for class org.eclipse.persistence.internal.sessions.OrderedChangeObject
 
OrderedChangeObject(int, Integer, ObjectChangeSet, Object) - Constructor for class org.eclipse.persistence.internal.sessions.OrderedChangeObject
 
orderedChangeObjectList - Variable in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Contains OrderedChangeObjects representing each change made to the collection.
orderedDescriptors - Variable in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
 
orderedDescriptors - Variable in class org.eclipse.persistence.sessions.Project
 
orderedElements - Variable in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
orderedElements - Variable in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
orderedFields - Variable in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
 
OrderedListContainerPolicy - Class in org.eclipse.persistence.internal.queries
Purpose: A OrderedListContainerPolicy is ContainerPolicy whose container class implements the List interface and is ordered by an @OrderBy.
OrderedListContainerPolicy() - Constructor for class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Construct a new policy.
OrderedListContainerPolicy(Class<?>) - Constructor for class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Construct a new policy for the specified class.
OrderedListContainerPolicy(String) - Constructor for class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Construct a new policy for the specified class name.
orderedPartitions - Variable in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
Use to track order for compute UCP index.
orderedRemoveObjectIndices - Variable in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Contains the removed values index to the collection.
orderedRemoveObjects - Variable in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Contains the removed values to the collection and their corresponding ChangeSets.
orderHasBeenRepaired - Variable in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Indicates whether IndirectList's order has been repaired.
orderHasBeenRepaired - Variable in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
Indicates whether IndirectList's order has been repaired.
orderHasBeenRepaired() - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
 
orderHasBeenRepaired() - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
orderInheritance(CoreAttributeGroup, Map<Object, ? extends CoreAttributeGroup>) - Static method in class org.eclipse.persistence.core.queries.CoreAttributeItem
Will order the subGroups based on hierarchy.
OrderOperator - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
orderSiblingsByExpressions - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
orderSiblingsByExpressions - Variable in class org.eclipse.persistence.queries.ReadAllQuery
 
org.eclipse.persistence - package org.eclipse.persistence
 
org.eclipse.persistence.annotations - package org.eclipse.persistence.annotations
 
org.eclipse.persistence.config - package org.eclipse.persistence.config
 
org.eclipse.persistence.core - module org.eclipse.persistence.core
 
org.eclipse.persistence.core.descriptors - package org.eclipse.persistence.core.descriptors
 
org.eclipse.persistence.core.mappings - package org.eclipse.persistence.core.mappings
 
org.eclipse.persistence.core.mappings.converters - package org.eclipse.persistence.core.mappings.converters
 
org.eclipse.persistence.core.mappings.transformers - package org.eclipse.persistence.core.mappings.transformers
 
org.eclipse.persistence.core.queries - package org.eclipse.persistence.core.queries
 
org.eclipse.persistence.core.sessions - package org.eclipse.persistence.core.sessions
 
org.eclipse.persistence.descriptors - package org.eclipse.persistence.descriptors
 
org.eclipse.persistence.descriptors.changetracking - package org.eclipse.persistence.descriptors.changetracking
 
org.eclipse.persistence.descriptors.copying - package org.eclipse.persistence.descriptors.copying
 
org.eclipse.persistence.descriptors.invalidation - package org.eclipse.persistence.descriptors.invalidation
 
org.eclipse.persistence.descriptors.partitioning - package org.eclipse.persistence.descriptors.partitioning
 
org.eclipse.persistence.dynamic - package org.eclipse.persistence.dynamic
 
org.eclipse.persistence.eis - package org.eclipse.persistence.eis
 
org.eclipse.persistence.eis.interactions - package org.eclipse.persistence.eis.interactions
 
org.eclipse.persistence.eis.mappings - package org.eclipse.persistence.eis.mappings
 
org.eclipse.persistence.exceptions - package org.eclipse.persistence.exceptions
 
org.eclipse.persistence.exceptions.i18n - package org.eclipse.persistence.exceptions.i18n
 
org.eclipse.persistence.expressions - package org.eclipse.persistence.expressions
 
org.eclipse.persistence.history - package org.eclipse.persistence.history
 
org.eclipse.persistence.indirection - package org.eclipse.persistence.indirection
 
org.eclipse.persistence.internal.cache - package org.eclipse.persistence.internal.cache
 
org.eclipse.persistence.internal.codegen - package org.eclipse.persistence.internal.codegen
 
org.eclipse.persistence.internal.core.databaseaccess - package org.eclipse.persistence.internal.core.databaseaccess
 
org.eclipse.persistence.internal.core.descriptors - package org.eclipse.persistence.internal.core.descriptors
 
org.eclipse.persistence.internal.core.helper - package org.eclipse.persistence.internal.core.helper
 
org.eclipse.persistence.internal.core.queries - package org.eclipse.persistence.internal.core.queries
 
org.eclipse.persistence.internal.core.sessions - package org.eclipse.persistence.internal.core.sessions
 
org.eclipse.persistence.internal.databaseaccess - package org.eclipse.persistence.internal.databaseaccess
 
org.eclipse.persistence.internal.databaseaccess.spi - package org.eclipse.persistence.internal.databaseaccess.spi
 
org.eclipse.persistence.internal.descriptors - package org.eclipse.persistence.internal.descriptors
 
org.eclipse.persistence.internal.descriptors.changetracking - package org.eclipse.persistence.internal.descriptors.changetracking
 
org.eclipse.persistence.internal.dynamic - package org.eclipse.persistence.internal.dynamic
 
org.eclipse.persistence.internal.expressions - package org.eclipse.persistence.internal.expressions
 
org.eclipse.persistence.internal.helper - package org.eclipse.persistence.internal.helper
 
org.eclipse.persistence.internal.helper.linkedlist - package org.eclipse.persistence.internal.helper.linkedlist
 
org.eclipse.persistence.internal.helper.type - package org.eclipse.persistence.internal.helper.type
 
org.eclipse.persistence.internal.identitymaps - package org.eclipse.persistence.internal.identitymaps
 
org.eclipse.persistence.internal.indirection - package org.eclipse.persistence.internal.indirection
 
org.eclipse.persistence.internal.jpa.jpql - package org.eclipse.persistence.internal.jpa.jpql
 
org.eclipse.persistence.internal.localization - package org.eclipse.persistence.internal.localization
 
org.eclipse.persistence.internal.mappings.converters - package org.eclipse.persistence.internal.mappings.converters
 
org.eclipse.persistence.internal.oxm - package org.eclipse.persistence.internal.oxm
 
org.eclipse.persistence.internal.oxm.conversion - package org.eclipse.persistence.internal.oxm.conversion
 
org.eclipse.persistence.internal.oxm.mappings - package org.eclipse.persistence.internal.oxm.mappings
 
org.eclipse.persistence.internal.oxm.record - package org.eclipse.persistence.internal.oxm.record
 
org.eclipse.persistence.internal.oxm.record.namespaces - package org.eclipse.persistence.internal.oxm.record.namespaces
 
org.eclipse.persistence.internal.oxm.schema - package org.eclipse.persistence.internal.oxm.schema
 
org.eclipse.persistence.internal.oxm.schema.model - package org.eclipse.persistence.internal.oxm.schema.model
 
org.eclipse.persistence.internal.oxm.unmapped - package org.eclipse.persistence.internal.oxm.unmapped
 
org.eclipse.persistence.internal.platform.database - package org.eclipse.persistence.internal.platform.database
 
org.eclipse.persistence.internal.queries - package org.eclipse.persistence.internal.queries
 
org.eclipse.persistence.internal.security - package org.eclipse.persistence.internal.security
 
org.eclipse.persistence.internal.sequencing - package org.eclipse.persistence.internal.sequencing
 
org.eclipse.persistence.internal.sessions - package org.eclipse.persistence.internal.sessions
 
org.eclipse.persistence.internal.sessions.cdi - package org.eclipse.persistence.internal.sessions.cdi
 
org.eclipse.persistence.internal.sessions.coordination - package org.eclipse.persistence.internal.sessions.coordination
 
org.eclipse.persistence.internal.sessions.coordination.broadcast - package org.eclipse.persistence.internal.sessions.coordination.broadcast
 
org.eclipse.persistence.internal.sessions.coordination.jms - package org.eclipse.persistence.internal.sessions.coordination.jms
 
org.eclipse.persistence.internal.sessions.coordination.rmi - package org.eclipse.persistence.internal.sessions.coordination.rmi
 
org.eclipse.persistence.internal.sessions.factories - package org.eclipse.persistence.internal.sessions.factories
 
org.eclipse.persistence.internal.sessions.factories.model - package org.eclipse.persistence.internal.sessions.factories.model
 
org.eclipse.persistence.internal.sessions.factories.model.event - package org.eclipse.persistence.internal.sessions.factories.model.event
 
org.eclipse.persistence.internal.sessions.factories.model.log - package org.eclipse.persistence.internal.sessions.factories.model.log
 
org.eclipse.persistence.internal.sessions.factories.model.login - package org.eclipse.persistence.internal.sessions.factories.model.login
 
org.eclipse.persistence.internal.sessions.factories.model.platform - package org.eclipse.persistence.internal.sessions.factories.model.platform
 
org.eclipse.persistence.internal.sessions.factories.model.pool - package org.eclipse.persistence.internal.sessions.factories.model.pool
 
org.eclipse.persistence.internal.sessions.factories.model.project - package org.eclipse.persistence.internal.sessions.factories.model.project
 
org.eclipse.persistence.internal.sessions.factories.model.property - package org.eclipse.persistence.internal.sessions.factories.model.property
 
org.eclipse.persistence.internal.sessions.factories.model.rcm - package org.eclipse.persistence.internal.sessions.factories.model.rcm
 
org.eclipse.persistence.internal.sessions.factories.model.rcm.command - package org.eclipse.persistence.internal.sessions.factories.model.rcm.command
 
org.eclipse.persistence.internal.sessions.factories.model.sequencing - package org.eclipse.persistence.internal.sessions.factories.model.sequencing
 
org.eclipse.persistence.internal.sessions.factories.model.session - package org.eclipse.persistence.internal.sessions.factories.model.session
 
org.eclipse.persistence.internal.sessions.factories.model.transport - package org.eclipse.persistence.internal.sessions.factories.model.transport
 
org.eclipse.persistence.internal.sessions.factories.model.transport.discovery - package org.eclipse.persistence.internal.sessions.factories.model.transport.discovery
 
org.eclipse.persistence.internal.sessions.factories.model.transport.naming - package org.eclipse.persistence.internal.sessions.factories.model.transport.naming
 
org.eclipse.persistence.internal.sessions.remote - package org.eclipse.persistence.internal.sessions.remote
 
org.eclipse.persistence.internal.weaving - package org.eclipse.persistence.internal.weaving
 
org.eclipse.persistence.logging - package org.eclipse.persistence.logging
 
org.eclipse.persistence.mappings - package org.eclipse.persistence.mappings
 
org.eclipse.persistence.mappings.converters - package org.eclipse.persistence.mappings.converters
 
org.eclipse.persistence.mappings.converters.spi - package org.eclipse.persistence.mappings.converters.spi
 
org.eclipse.persistence.mappings.foundation - package org.eclipse.persistence.mappings.foundation
 
org.eclipse.persistence.mappings.querykeys - package org.eclipse.persistence.mappings.querykeys
 
org.eclipse.persistence.mappings.structures - package org.eclipse.persistence.mappings.structures
 
org.eclipse.persistence.mappings.transformers - package org.eclipse.persistence.mappings.transformers
 
org.eclipse.persistence.mappings.xdb - package org.eclipse.persistence.mappings.xdb
 
org.eclipse.persistence.oxm - package org.eclipse.persistence.oxm
 
org.eclipse.persistence.oxm.annotations - package org.eclipse.persistence.oxm.annotations
 
org.eclipse.persistence.oxm.attachment - package org.eclipse.persistence.oxm.attachment
 
org.eclipse.persistence.oxm.documentpreservation - package org.eclipse.persistence.oxm.documentpreservation
 
org.eclipse.persistence.oxm.json - package org.eclipse.persistence.oxm.json
 
org.eclipse.persistence.oxm.mappings - package org.eclipse.persistence.oxm.mappings
 
org.eclipse.persistence.oxm.mappings.converters - package org.eclipse.persistence.oxm.mappings.converters
 
org.eclipse.persistence.oxm.mappings.nullpolicy - package org.eclipse.persistence.oxm.mappings.nullpolicy
 
org.eclipse.persistence.oxm.platform - package org.eclipse.persistence.oxm.platform
 
org.eclipse.persistence.oxm.record - package org.eclipse.persistence.oxm.record
 
org.eclipse.persistence.oxm.schema - package org.eclipse.persistence.oxm.schema
 
org.eclipse.persistence.oxm.sequenced - package org.eclipse.persistence.oxm.sequenced
 
org.eclipse.persistence.oxm.unmapped - package org.eclipse.persistence.oxm.unmapped
 
org.eclipse.persistence.platform.database - package org.eclipse.persistence.platform.database
 
org.eclipse.persistence.platform.database.converters - package org.eclipse.persistence.platform.database.converters
 
org.eclipse.persistence.platform.database.events - package org.eclipse.persistence.platform.database.events
 
org.eclipse.persistence.platform.database.jdbc - package org.eclipse.persistence.platform.database.jdbc
 
org.eclipse.persistence.platform.database.oracle.annotations - package org.eclipse.persistence.platform.database.oracle.annotations
 
org.eclipse.persistence.platform.database.oracle.jdbc - package org.eclipse.persistence.platform.database.oracle.jdbc
 
org.eclipse.persistence.platform.database.oracle.plsql - package org.eclipse.persistence.platform.database.oracle.plsql
 
org.eclipse.persistence.platform.database.partitioning - package org.eclipse.persistence.platform.database.partitioning
 
org.eclipse.persistence.platform.server - package org.eclipse.persistence.platform.server
 
org.eclipse.persistence.platform.server.glassfish - package org.eclipse.persistence.platform.server.glassfish
 
org.eclipse.persistence.platform.server.was - package org.eclipse.persistence.platform.server.was
 
org.eclipse.persistence.platform.server.wls - package org.eclipse.persistence.platform.server.wls
 
org.eclipse.persistence.platform.xml - package org.eclipse.persistence.platform.xml
 
org.eclipse.persistence.queries - package org.eclipse.persistence.queries
 
org.eclipse.persistence.sequencing - package org.eclipse.persistence.sequencing
 
org.eclipse.persistence.services - package org.eclipse.persistence.services
 
org.eclipse.persistence.services.glassfish - package org.eclipse.persistence.services.glassfish
 
org.eclipse.persistence.services.jboss - package org.eclipse.persistence.services.jboss
 
org.eclipse.persistence.services.mbean - package org.eclipse.persistence.services.mbean
 
org.eclipse.persistence.services.weblogic - package org.eclipse.persistence.services.weblogic
 
org.eclipse.persistence.services.websphere - package org.eclipse.persistence.services.websphere
 
org.eclipse.persistence.sessions - package org.eclipse.persistence.sessions
 
org.eclipse.persistence.sessions.broker - package org.eclipse.persistence.sessions.broker
 
org.eclipse.persistence.sessions.changesets - package org.eclipse.persistence.sessions.changesets
 
org.eclipse.persistence.sessions.coordination - package org.eclipse.persistence.sessions.coordination
 
org.eclipse.persistence.sessions.coordination.broadcast - package org.eclipse.persistence.sessions.coordination.broadcast
 
org.eclipse.persistence.sessions.coordination.jms - package org.eclipse.persistence.sessions.coordination.jms
 
org.eclipse.persistence.sessions.coordination.rmi - package org.eclipse.persistence.sessions.coordination.rmi
 
org.eclipse.persistence.sessions.factories - package org.eclipse.persistence.sessions.factories
 
org.eclipse.persistence.sessions.interceptors - package org.eclipse.persistence.sessions.interceptors
 
org.eclipse.persistence.sessions.remote - package org.eclipse.persistence.sessions.remote
 
org.eclipse.persistence.sessions.remote.rmi - package org.eclipse.persistence.sessions.remote.rmi
 
org.eclipse.persistence.sessions.serializers - package org.eclipse.persistence.sessions.serializers
 
org.eclipse.persistence.sessions.server - package org.eclipse.persistence.sessions.server
 
org.eclipse.persistence.tools - package org.eclipse.persistence.tools
 
org.eclipse.persistence.tools.profiler - package org.eclipse.persistence.tools.profiler
 
org.eclipse.persistence.tools.schemaframework - package org.eclipse.persistence.tools.schemaframework
 
org.eclipse.persistence.tools.tuning - package org.eclipse.persistence.tools.tuning
 
org.eclipse.persistence.transaction - package org.eclipse.persistence.transaction
 
org.eclipse.persistence.transaction.glassfish - package org.eclipse.persistence.transaction.glassfish
 
org.eclipse.persistence.transaction.jboss - package org.eclipse.persistence.transaction.jboss
 
org.eclipse.persistence.transaction.sap - package org.eclipse.persistence.transaction.sap
 
org.eclipse.persistence.transaction.was - package org.eclipse.persistence.transaction.was
 
org.eclipse.persistence.transaction.wls - package org.eclipse.persistence.transaction.wls
 
ORIGINAL_INTO_WORKING_COPY - Static variable in class org.eclipse.persistence.internal.sessions.MergeManager
 
ORIGINAL_QUERY_MUST_USE_IN - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
originalCollection - Variable in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
Used for change tracking when user sets entire collection.
originalFields - Variable in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
originalIndex - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
originalIndex - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
Keeps track of the next procedure argument index.
originalObject - Variable in class org.eclipse.persistence.descriptors.DescriptorEvent
The source object represents the object the event is being raised on, some events also require a second object, for example the original object in a postClone.
originalQuery - Variable in class org.eclipse.persistence.internal.indirection.BatchValueHolder
 
originalQueryMustUseBatchIN(DatabaseMapping, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
ORM_SCHEMA_VALIDATION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.orm.validate.schema" property set on the session is used to override orm.xml schema validation from its default of "false".
orphanRemoval() - Method in annotation type org.eclipse.persistence.annotations.VariableOneToOne
(Optional) Whether to apply the remove operation to entities that have been removed from the relationship and to cascade the remove operation to those entities.
OTHER_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
OUT - org.eclipse.persistence.annotations.Direction
Output parameter
OUT - org.eclipse.persistence.internal.databaseaccess.DatasourceCall.ParameterType
 
OUT - Static variable in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
 
OUT_CURSOR - org.eclipse.persistence.annotations.Direction
Output cursor
OUT_CURSOR - org.eclipse.persistence.internal.databaseaccess.DatasourceCall.ParameterType
 
OUTER - org.eclipse.persistence.annotations.JoinFetchType
An inner join is used to fetch the related object.
OUTER_JOIN - Static variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Specify any OUTER join on a join fetch.
OUTER_JOIN_ONLY_VALID_FOR_ONE_TO_ONE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
OuterJoinExpressionHolder - Class in org.eclipse.persistence.internal.expressions
Holder class storing a QueryKeyExpression representing an outer join plus some data calculated by method appendFromClauseForOuterJoin.
OuterJoinExpressionHolder(OuterJoinExpressionHolder) - Constructor for class org.eclipse.persistence.internal.expressions.OuterJoinExpressionHolder
 
OuterJoinExpressionHolder(SQLSelectStatement, ObjectExpression, Expression, Map<DatabaseTable, Expression>, ClassDescriptor) - Constructor for class org.eclipse.persistence.internal.expressions.OuterJoinExpressionHolder
 
outerJoinExpressionHolders - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Used for DB2 style from clause outer joins.
outerJoinIsOnlyValidForOneToOneMappings(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
outIndex - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
output - Variable in class org.eclipse.persistence.internal.codegen.CodeGenerator
 
OUTPUT_UNSUPPORTED_MSG_TYPE - Static variable in exception org.eclipse.persistence.eis.EISException
 
outputArgumentNames - Variable in class org.eclipse.persistence.eis.interactions.EISInteraction
Defines the output argument names as defined in the output record for the interaction.
outputArguments - Variable in class org.eclipse.persistence.eis.interactions.EISInteraction
Defines the field values the output arguments of the interaction map to.
outputClassFile(String, byte[], String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Used by our byte code weaving to enable users who are debugging to output the generated class to a file
outputCreateDDLToFile(String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
outputCreateDDLToWriter(Writer) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
outputCursors - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Keep a list of the output cursors.
outputDDLToDatabase() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
PUBLIC: Output all DDL statements directly to the database.
outputDDLToFile(String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
PUBLIC: Output all DDL statements to a file writer specified by the name in the parameter.
outputDDLToWriter(Writer) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
PUBLIC: Output all DDL statements to a writer specified in the parameter.
outputDropDDLToFile(String) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
outputDropDDLToWriter(Writer) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
outputFileName - Variable in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
outputFileName - Variable in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
 
OutputParameterForCallableStatement - Class in org.eclipse.persistence.internal.databaseaccess
 
OutputParameterForCallableStatement() - Constructor for class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
OutputParameterForCallableStatement(OutputParameterForCallableStatement) - Constructor for class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
OutputParameterForCallableStatement(DatabaseField) - Constructor for class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
OutputParameterForCallableStatement(DatabaseField, AbstractSession) - Constructor for class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
OutputParameterForCallableStatement(DatabaseField, AbstractSession, boolean) - Constructor for class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
outputParametersDetected(DataRecord, DatasourceCall) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Raised for stored proc output parameters.
outputParametersDetected(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
outputParametersDetected(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the session after a stored procedure call has been executed that had output parameters.
OutputParametersDetected - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
outputPath - Variable in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
outputPath - Variable in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
 
outputResultPath - Variable in class org.eclipse.persistence.eis.interactions.EISInteraction
Path to the desired output record if nested.
outputRootElementName - Variable in class org.eclipse.persistence.eis.interactions.XMLInteraction
The root element name to use for the output DOM.
outputStream - Variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
OutputStreamOutput(OutputStream) - Constructor for class org.eclipse.persistence.oxm.record.JSONWriterRecord.OutputStreamOutput
 
OutputStreamRecord - Class in org.eclipse.persistence.oxm.record
Use this type of MarshalRecord when the marshal target is an OutputStream and the XML should not be formatted with carriage returns or indenting.
OutputStreamRecord() - Constructor for class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
OutputStreamRecord.OutputStreamRecordContentHandler - Class in org.eclipse.persistence.oxm.record
This class will typically be used in conjunction with an XMLFragmentReader.
outputStreamWrite(byte) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
outputStreamWrite(byte[]) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
outputStreamWrite(byte[], OutputStream) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
outputStreamWrite(byte, OutputStream) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
outputWriter - Variable in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
outputWriter - Variable in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
 
OVERRIDE_JMX_APPLICATIONNAME_PROPERTY - Static variable in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
This persistence.xml or sessions.xml property is used to override the applicationName
OVERRIDE_JMX_MODULENAME_PROPERTY - Static variable in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
This persistence.xml or sessions.xml property is used to override the moduleName
overrideManyToManyMappings - Variable in class org.eclipse.persistence.mappings.AggregateObjectMapping
List of many to many mapping overrides to apply at initialize time to their cloned aggregate mappings.
overridesRead() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
This can be used by collection such as cursored stream to gain control over execution.
overridesRead() - Method in class org.eclipse.persistence.queries.CursorPolicy
INTERNAL: This can be used by collection such as cursored stream to gain control over execution.
overrideUnidirectionalOneToManyMappings - Variable in class org.eclipse.persistence.mappings.AggregateObjectMapping
List of unidirectional one to many mapping overrides to apply at initialize time to their cloned aggregate mappings.
owner - Variable in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
 
owner - Variable in class org.eclipse.persistence.internal.sessions.ChangeRecord
This is the object change set that holds this record
owner - Variable in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
owner - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
OWNING - org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy.LockOnChange
 
OXM_KEY_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
oxmKeyNotFound() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: Properties passed to createDynamicFromOXM did not contain ECLIPSELINK_OXM_FILE_KEY, or was null.
OXMObjectPersistenceRuntimeXMLProject - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL:
OXMObjectPersistenceRuntimeXMLProject() - Constructor for class org.eclipse.persistence.internal.sessions.factories.OXMObjectPersistenceRuntimeXMLProject
 
OXMObjectPersistenceRuntimeXMLProject(NamespaceResolverWithPrefixes) - Constructor for class org.eclipse.persistence.internal.sessions.factories.OXMObjectPersistenceRuntimeXMLProject
 
OXMSystemProperties - Class in org.eclipse.persistence.internal.oxm
System properties holder.

P

PACKAGE - Static variable in class org.eclipse.persistence.internal.codegen.AccessLevel
 
PackageDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Allow a semi-generic way of creating packages.
PackageDefinition() - Constructor for class org.eclipse.persistence.tools.schemaframework.PackageDefinition
 
packageName - Variable in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
packageName - Variable in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
packageName - Variable in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
 
packageNotSetForBindingException() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception would typically be used by JAXBContextFactory during externalized metadata processing (i.e.
PackageRenamer - Class in org.eclipse.persistence.tools
This class performs package renaming.
PackageRenamer() - Constructor for class org.eclipse.persistence.tools.PackageRenamer
The constructor of a PackageRenamer class.
PackageRenamer(String) - Constructor for class org.eclipse.persistence.tools.PackageRenamer
 
PackageRenamer(String[]) - Constructor for class org.eclipse.persistence.tools.PackageRenamer
 
PackageRenamer.PackageRenamerException - Exception in org.eclipse.persistence.tools
 
PackageRenamerException(String) - Constructor for exception org.eclipse.persistence.tools.PackageRenamer.PackageRenamerException
 
PACKET_TIME_TO_LIVE_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
packetTimeToLive - Variable in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
Number of hops in the life of the datapacket Default is 2, a hub and an interface card to prevent the data packets from leaving the localnetwork.
pageSize - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteCursoredStream
Return the cursored stream page size.
pageSize - Variable in class org.eclipse.persistence.queries.CursorPolicy
 
PAGINATION_PARAMETER_USED_FOR_NOT_PAGEABLE_RESOURCE - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
parallelStream() - Method in class org.eclipse.persistence.indirection.IndirectList
 
parallelStream() - Method in class org.eclipse.persistence.indirection.IndirectSet
 
parameter - Variable in class org.eclipse.persistence.internal.expressions.ExpressionIterator
Some iterations require a more general parameter.
PARAMETER_AND_MAPPING_WITH_INDIRECTION_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
PARAMETER_AND_MAPPING_WITH_TRANSPARENT_INDIRECTION_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
PARAMETER_AND_MAPPING_WITHOUT_INDIRECTION_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
PARAMETER_DELIMITER - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.jdbc.parameter-delimiter"
PARAMETER_DOES_NOT_EXIST_FOR_OPERATION - Static variable in exception org.eclipse.persistence.exceptions.DBWSException
 
PARAMETER_HAS_NO_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.DBWSException
 
PARAMETER_NAME_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
parameterAndMappingWithIndirectionMismatch(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
parameterAndMappingWithoutIndirectionMismatch(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
parameterAndMappingWithTransparentIndirectionMismatch(DatabaseMapping, Class<?>, String) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
parameterBindings - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
parameterDelimiter - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Allow the reserved pound char used to delimit bind parameters to be overridden
ParameterDelimiterType - Class in org.eclipse.persistence.config
Parameter delimiter char hint values.
ParameterDelimiterType() - Constructor for class org.eclipse.persistence.config.ParameterDelimiterType
 
parameterDoesNotExistForOperation(String, String) - Static method in exception org.eclipse.persistence.exceptions.DBWSException
INTERNAL: Exception when processing DBWS metadata and the descriptor cannot be located for the operation
ParameterExpression - Class in org.eclipse.persistence.internal.expressions
Used for parameterized expressions, such as expression defined in mapping queries.
ParameterExpression() - Constructor for class org.eclipse.persistence.internal.expressions.ParameterExpression
 
ParameterExpression(String) - Constructor for class org.eclipse.persistence.internal.expressions.ParameterExpression
 
ParameterExpression(String, Expression, Object) - Constructor for class org.eclipse.persistence.internal.expressions.ParameterExpression
 
ParameterExpression(DatabaseField) - Constructor for class org.eclipse.persistence.internal.expressions.ParameterExpression
 
ParameterExpression(DatabaseField, Expression) - Constructor for class org.eclipse.persistence.internal.expressions.ParameterExpression
 
parameterHasNoMapping(String, String) - Static method in exception org.eclipse.persistence.exceptions.DBWSException
INTERNAL: Exception when processing DBWS metadata and the descriptor cannot be located for the operation
parameterizedMechanism - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
 
ParameterizedSQLBatchWritingMechanism - Class in org.eclipse.persistence.internal.databaseaccess
INTERNAL:
ParameterizedSQLBatchWritingMechanism() - Constructor for class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
 
ParameterizedSQLBatchWritingMechanism(DatabaseAccessor) - Constructor for class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
 
parameterNameMismatch(String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
parameters - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
parameters - Variable in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
This variable contains a list of the parameters list passed into the query
parameters - Variable in class org.eclipse.persistence.logging.SessionLogEntry
 
parameters() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredFunctionQuery
(Optional) Defines the parameters to the stored function.
parameters() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredProcedureQuery
(Optional) Defines the parameters to the stored procedure.
parameters() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredFunctionQuery
(Optional) Defines the parameters to the stored procedure.
parameters() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredProcedureQuery
(Optional) Defines the parameters to the stored procedure.
parameterTypes - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
parent - Variable in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
parent - Variable in class org.eclipse.persistence.internal.codegen.HierarchyNode
 
parent - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
parent - Variable in class org.eclipse.persistence.sessions.broker.SessionBroker
 
parent - Variable in class org.eclipse.persistence.sessions.server.ClientSession
 
PARENT_CLASS_IS_SELF - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
PARENT_DESCRIPTOR_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
PARENT_TO_CHILD - org.eclipse.persistence.queries.ReadAllQuery.Direction
Hierarchy will be traversed from parent to child - PRIOR keyword is generated on the left side of the equation
parentAttributeName - Variable in class org.eclipse.persistence.internal.descriptors.changetracking.AggregateAttributeChangeListener
 
parentAttributeName - Variable in class org.eclipse.persistence.internal.descriptors.changetracking.AggregateObjectChangeListener
 
parentCacheKey - Variable in class org.eclipse.persistence.internal.indirection.BatchValueHolder
 
parentClass - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
parentClass - Variable in class org.eclipse.persistence.dynamic.DynamicClassWriter
 
parentClassIsSelf(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
parentClassName - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
parentClassName - Variable in class org.eclipse.persistence.dynamic.DynamicClassWriter
Name of parent class.
parentDescriptor - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
parentDescriptorNotSpecified(String, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
parentDescriptors - Variable in class org.eclipse.persistence.descriptors.InterfacePolicy
 
parentInterfaceNames - Variable in class org.eclipse.persistence.descriptors.InterfacePolicy
 
parentInterfaces - Variable in class org.eclipse.persistence.descriptors.InterfacePolicy
 
parentLevel - Variable in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
parentListener - Variable in class org.eclipse.persistence.internal.descriptors.changetracking.AggregateAttributeChangeListener
 
parentListener - Variable in class org.eclipse.persistence.internal.descriptors.changetracking.AggregateObjectChangeListener
 
parentRecord - Variable in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
parentResultIndex - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Stores the result index of the parent, used for oneToMany joins.
parentSessionController - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
parentStatement - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Used for subselects.
parentType - Variable in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
parse(File) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
parse(InputStream) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
parse(Reader) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
parse(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
parse(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
parse(URL) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
parse(XMLStreamReader) - Method in class org.eclipse.persistence.internal.oxm.record.XMLStreamReaderReader
 
parse(Source) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
parse(Node) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
parse(Node, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
parse(Node, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
 
parse(InputSource) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
parse(InputSource) - Method in class org.eclipse.persistence.internal.oxm.record.XMLEventReaderReader
 
parse(InputSource) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
parse(InputSource) - Method in class org.eclipse.persistence.internal.oxm.record.XMLStreamReaderReader
 
parse(InputSource) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
parseCharactersEvent(XMLStreamReader) - Method in class org.eclipse.persistence.internal.oxm.record.XMLStreamReaderReader
Subclasses of this class can override this method to provide alternate mechanisms for processing the characters event.
parseFileExtension(File) - Method in class org.eclipse.persistence.tools.PackageRenamer
Returns the extension of the given file.
parseForTypeNames(String) - Static method in class org.eclipse.persistence.internal.codegen.CodeDefinition
Returns a set of java.lang.String type names included in longString.
ParserType - Class in org.eclipse.persistence.config
Parser type property values.
ParserValidationType - Class in org.eclipse.persistence.config
Parser type property values.
ParserValidationType() - Constructor for class org.eclipse.persistence.config.ParserValidationType
 
Partial - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
partialAttributeExpressions - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Stores the partial attributes that have been added to this query
PARTIONING_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
partitionColumn() - Method in annotation type org.eclipse.persistence.annotations.HashPartitioning
The database column or query parameter to partition queries by.
partitionColumn() - Method in annotation type org.eclipse.persistence.annotations.RangePartitioning
The database column or query parameter to partition queries by.
partitionColumn() - Method in annotation type org.eclipse.persistence.annotations.ValuePartitioning
The database column or query parameter to partition queries by.
Partitioned - Annotation Type in org.eclipse.persistence.annotations
Partitioning is used to partition the data for a class across multiple difference databases or across a database cluster such as Oracle RAC.
partitionField - Variable in class org.eclipse.persistence.descriptors.partitioning.FieldPartitioningPolicy
The column to partition by.
Partitioning - Annotation Type in org.eclipse.persistence.annotations
A Partitioning is used to partition the data for a class across multiple difference databases or across a database cluster such as Oracle RAC.
PARTITIONING - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.partitioning" property specifies the default PartitioningPolicy for a persistence unit.
A PartitioningPolicy is used to partition the data for a class across multiple difference databases or across a database cluster such as Oracle RAC.
Partitioning can provide improved scalability by allowing multiple database machines to service requests.
PARTITIONING - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.partitioning"
PARTITIONING_CALLBACK - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.partitioning.callback" is used to integrate with an external DataSource's data affinity support, such as UCP.
partitioningCallback - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used to integrate with data partitioning in an external DataSource such as UCP.
partitioningClasName - Variable in class org.eclipse.persistence.descriptors.partitioning.CustomPartitioningPolicy
 
partitioningClass() - Method in annotation type org.eclipse.persistence.annotations.Partitioning
(Required) Full package.class name of a subclass of PartitioningPolicy.
partitioningNotSupported(AbstractSession, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
partitioningPolicies - Variable in class org.eclipse.persistence.sessions.Project
Map of named partitioning policies, keyed by their name.
partitioningPolicy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
partitioningPolicy - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Allow queries to be targeted at specific connection pools.
partitioningPolicy - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Allow the mapping's queries to be targeted at specific connection pools.
partitioningPolicy - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Allow queries to be targeted at specific connection pools.
PartitioningPolicy - Class in org.eclipse.persistence.descriptors.partitioning
PUBLIC: A PartitioningPolicy is used to partition the data for a class across multiple difference databases or across a database cluster such as Oracle RAC.
PartitioningPolicy() - Constructor for class org.eclipse.persistence.descriptors.partitioning.PartitioningPolicy
Default constructor.
partitioningPolicyName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
partitioningPolicyName - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Allow the mapping's queries to be targeted at specific connection pools.
partitionNames - Variable in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
Store the value partitions by name.
partitionPersist(AbstractSession, Object, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.partitioning.HashPartitioningPolicy
INTERNAL: Allow for the persist call to assign the partition.
partitionPersist(AbstractSession, Object, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.partitioning.PartitioningPolicy
INTERNAL: Allow for the persist call to assign the partition.
partitionPersist(AbstractSession, Object, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartitioningPolicy
INTERNAL: Allow for the persist call to assign the partition.
partitionPersist(AbstractSession, Object, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
INTERNAL: Allow for the persist call to assign the partition.
partitions - Variable in class org.eclipse.persistence.descriptors.partitioning.RangePartitioningPolicy
 
partitions - Variable in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
Store the value partitions.
partitions() - Method in annotation type org.eclipse.persistence.annotations.RangePartitioning
(Required) List of connection pool names to load balance across.
partitions() - Method in annotation type org.eclipse.persistence.annotations.ValuePartitioning
Store the value partitions.
partitionValueType - Variable in class org.eclipse.persistence.descriptors.partitioning.RangePartition
 
partitionValueType - Variable in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
The type of the partition values.
partitionValueType() - Method in annotation type org.eclipse.persistence.annotations.RangePartitioning
The type of the start and end values.
partitionValueType() - Method in annotation type org.eclipse.persistence.annotations.ValuePartitioning
The type of the start and end values.
partitionValueTypeName - Variable in class org.eclipse.persistence.descriptors.partitioning.RangePartition
 
partitionValueTypeName - Variable in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
The type name of the partition value names.
PASSWORD - Static variable in class org.eclipse.persistence.eis.EISConnectionSpec
 
PASSWORD_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
PATCH_SEPARATOR - Static variable in class org.eclipse.persistence.internal.helper.JavaVersion
JavaEE platform patch version element separator character.
PATH_SEPARATOR - Static variable in class org.eclipse.persistence.internal.helper.Helper
Prime the platform-dependent path separator
pathSeparator() - Static method in class org.eclipse.persistence.internal.helper.Helper
Return a string containing the platform-appropriate characters for separating entries in a path (e.g.
PBOOLEAN - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
PBYTE - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
PCHAR - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
PDOUBLE - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
peek() - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Return the next object in the stream, without incrementing the stream's position.
PerformanceMonitor - Class in org.eclipse.persistence.tools.profiler
Purpose: A tool used to provide performance monitoring information in a server environment.
PerformanceMonitor - Static variable in class org.eclipse.persistence.config.ProfilerType
 
PerformanceMonitor() - Constructor for class org.eclipse.persistence.tools.profiler.PerformanceMonitor
PUBLIC: Create a new profiler.
PerformanceProfiler - Class in org.eclipse.persistence.tools.profiler
Purpose: A tool used to provide high level performance profiling information.
PerformanceProfiler - Static variable in class org.eclipse.persistence.config.ProfilerType
 
PerformanceProfiler() - Constructor for class org.eclipse.persistence.tools.profiler.PerformanceProfiler
PUBLIC: Create a new profiler.
PerformanceProfiler(boolean) - Constructor for class org.eclipse.persistence.tools.profiler.PerformanceProfiler
PUBLIC: Create a new profiler.
PerformanceProfiler_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
performDataModificationEvent(Object[], AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Perform the commit event.
performDataModificationEvent(Object[], AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Perform the commit event.
performDataModificationEvent(Object[], AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Perform the commit event.
performDataModificationEvent(Object[], AbstractSession) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Perform the commit event.
performDataModificationEvent(Object[], AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Perform the commit event.
performDataModificationEvent(Object[], AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Perform the commit event.
performFullValidation() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not referred in the unit of work cache.
performFullValidation() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not referred in the unit of work cache.
performOperator(ExpressionOperator, List) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
performPartialValidation() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not referred in the unit of work cache.
performPartialValidation() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not referred in the unit of work cache.
performRemove(Object, Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This method will perform a delete operation on the provided objects pre-determining the objects that will be deleted by a commit of the UnitOfWork including privately owned objects.
performRemovePrivateOwnedObjectFromChangeSet(Object, Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Cascade remove the private owned object from the owned UnitOfWorkChangeSet
performSelector(boolean) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
INTERNAL: Check if the object conforms to the expression in memory.
performUserDefinedInsert() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Insert the object using the user defined query.
performUserDefinedUpdate() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Update the object using the user defined query.
performUserDefinedWrite(WriteObjectQuery) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Write the object using the specified user-defined query.
PERSISTENCE_CONTEXT_CLOSE_ON_COMMIT - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
Specifies that the EntityManager will be closed or not used after commit (not extended).
PERSISTENCE_CONTEXT_CLOSE_ON_COMMIT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.persistence-context.close-on-commit" property specifies that the EntityManager will be closed or not used after commit (not extended).
PERSISTENCE_CONTEXT_COMMIT_ORDER - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
Defines the ordering of updates and deletes of a set of the same entity type during a commit or flush operation.
PERSISTENCE_CONTEXT_COMMIT_ORDER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.persistence-context.commit-order" property defines the ordering of updates and deletes of a set of the same entity type during a commit or flush operation.
PERSISTENCE_CONTEXT_COMMIT_WITHOUT_PERSIST_RULES - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
Specifies that the EntityManager will search all managed objects and persist any related non-managed new objects that are found ignoring any absence of CascadeType.PERSIST settings.
PERSISTENCE_CONTEXT_COMMIT_WITHOUT_PERSIST_RULES - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.persistence-context.commit-without-persist-rules" property specifies that the EntityManager will search all managed objects and persist any related non-managed new objects that are found ignoring any absence of CascadeType.PERSIST settings.
PERSISTENCE_CONTEXT_COULD_NOT_BE_BOOTSTRAPPED - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
PERSISTENCE_CONTEXT_FLUSH_MODE - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
Allows the EntityManager FlushMode to be set as a persistence property.
PERSISTENCE_CONTEXT_FLUSH_MODE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.persistence-context.flush-mode" property configures the EntityManager FlushMode to be set as a persistence property.
PERSISTENCE_CONTEXT_PERSIST_ON_COMMIT - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
Specifies that the EntityManager will search all managed objects and persist any related non-managed new objects that are cascade persist.
PERSISTENCE_CONTEXT_PERSIST_ON_COMMIT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.persistence-context.persist-on-commit" property specifies that the EntityManager will search all managed objects and persist any related non-managed new objects that are cascade persist.
PERSISTENCE_CONTEXT_REFERENCE_MODE - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
Specifies whether there should be hard or soft references used within the Persistence Context.
PERSISTENCE_CONTEXT_REFERENCE_MODE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.persistence-context.reference-mode" property configures whether there should be hard or soft references used within the Persistence Context.
PERSISTENCE_FIELDNAME_POSTFIX - Static variable in class org.eclipse.persistence.internal.helper.Helper
 
PERSISTENCE_FIELDNAME_PREFIX - Static variable in class org.eclipse.persistence.internal.helper.Helper
 
PERSISTENCE_GET - Static variable in class org.eclipse.persistence.internal.helper.Helper
 
PERSISTENCE_SET - Static variable in class org.eclipse.persistence.internal.helper.Helper
 
PERSISTENCE_UNIT_DEFAULT - Static variable in class org.eclipse.persistence.config.HintValues
 
PERSISTENCE_UNIT_NAME_ALREADY_IN_USE - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
PersistenceEntity - Interface in org.eclipse.persistence.internal.descriptors
Define an interface for utility methods weaved into the persistence classes.
PersistenceEntityCopyPolicy - Class in org.eclipse.persistence.descriptors.copying
Purpose: This is the default copy policy when weaving is used.
PersistenceEntityCopyPolicy() - Constructor for class org.eclipse.persistence.descriptors.copying.PersistenceEntityCopyPolicy
 
PersistenceEntityResolver - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL:
PersistenceEntityResolver() - Constructor for class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
INTERNAL:
PersistenceObject - Interface in org.eclipse.persistence.internal.descriptors
Define an interface for utility methods weaved into the persistence classes.
PersistenceObjectAttributeAccessor - Class in org.eclipse.persistence.internal.descriptors
Used with weaving to access attributes without using reflection.
PersistenceObjectAttributeAccessor(String) - Constructor for class org.eclipse.persistence.internal.descriptors.PersistenceObjectAttributeAccessor
 
PersistenceObjectInstantiationPolicy - Class in org.eclipse.persistence.internal.descriptors
Used with weaving to create "empty" instances without using reflection.
PersistenceObjectInstantiationPolicy() - Constructor for class org.eclipse.persistence.internal.descriptors.PersistenceObjectInstantiationPolicy
 
PersistenceObjectInstantiationPolicy(PersistenceObject) - Constructor for class org.eclipse.persistence.internal.descriptors.PersistenceObjectInstantiationPolicy
 
PersistenceUnitLoadingException - Exception in org.eclipse.persistence.exceptions
 
PersistenceUnitLoadingException() - Constructor for exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
PersistenceUnitLoadingException(String) - Constructor for exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
PersistenceUnitLoadingException(String, Throwable) - Constructor for exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
PersistenceUnitLoadingExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
 
PersistenceUnitLoadingExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.PersistenceUnitLoadingExceptionResource
Default constructor.
persistenceUnitNameAlreadyInUse(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
PersistenceUnitProperties - Class in org.eclipse.persistence.config
The class defines EclipseLink persistence unit property names.
PersistenceUnitProperties() - Constructor for class org.eclipse.persistence.config.PersistenceUnitProperties
 
PersistenceWeaved - Interface in org.eclipse.persistence.internal.weaving
INTERNAL: Marker interface used to identify classes modified by the EclipseLink weaver.
PersistenceWeavedChangeTracking - Interface in org.eclipse.persistence.internal.weaving
INTERNAL: Marker interface used to identify classes modified by the TopLink weaver for change tracking.
PersistenceWeavedFetchGroups - Interface in org.eclipse.persistence.internal.weaving
INTERNAL: Marker interface used to identify classes modified by the TopLink weaver for fetch groups.
PersistenceWeavedLazy - Interface in org.eclipse.persistence.internal.weaving
INTERNAL: Marker interface used to identify classes modified by the TopLink weaver for LAZY (ValueHolder indirection) mappings.
PersistenceWeavedLazy_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
PervasivePlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides Pervasive SQL DBMS specific behavior.
PervasivePlatform() - Constructor for class org.eclipse.persistence.platform.database.PervasivePlatform
Default constructor.
PESSIMISTIC_ - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
PESSIMISTIC_FORCE_INCREMENT - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
PESSIMISTIC_LOCK - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.pessimistic-lock"
PESSIMISTIC_LOCK_SCOPE - Static variable in class org.eclipse.persistence.config.QueryHints
"jakarta.persistence.lock.scope"
PESSIMISTIC_LOCK_TIMEOUT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.lock.timeout" property configures the WAIT timeout used in pessimistic locking, if the database query exceeds the timeout the database will terminate the query and return an exception.
PESSIMISTIC_LOCK_TIMEOUT - Static variable in class org.eclipse.persistence.config.QueryHints
"jakarta.persistence.lock.timeout"
PESSIMISTIC_LOCK_TIMEOUT_UNIT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.pessimistic.lock.timeout.unit" property configures the query timeout unit value.
PESSIMISTIC_LOCK_TIMEOUT_UNIT - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.pessimistic.lock.timeout.unit"
PESSIMISTIC_READ - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
PESSIMISTIC_WRITE - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
PessimisticLock - Class in org.eclipse.persistence.config
PessimisticLock hint values.
PessimisticLock() - Constructor for class org.eclipse.persistence.config.PessimisticLock
 
pessimisticLockedObjects - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
use to track pessimistic locked objects
pessimisticLockingPolicy - Variable in class org.eclipse.persistence.descriptors.CMPPolicy
Allow the bean to always be locked as it enters a new transaction.
PessimisticLockingPolicy - Class in org.eclipse.persistence.descriptors
Description: This policy is used to configure bean level pessimistic locking feature.
PessimisticLockingPolicy() - Constructor for class org.eclipse.persistence.descriptors.PessimisticLockingPolicy
 
pessimisticLockTimeoutDefault - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Default pessimistic lock timeout value.
pessimisticLockTimeoutUnitDefault - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
 
PFLOAT - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
pingSQL - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This attribute will store the SQL query that will be used to 'ping' the database connection in order to check the health of a connection.
PinnedPartitioning - Annotation Type in org.eclipse.persistence.annotations
PinnedPartitionPolicy pins requests to a single connection pool.
PinnedPartitioningPolicy - Class in org.eclipse.persistence.descriptors.partitioning
PUBLIC: PinnedPartitionPolicy pins requests to a single connection pool.
PinnedPartitioningPolicy() - Constructor for class org.eclipse.persistence.descriptors.partitioning.PinnedPartitioningPolicy
 
PinnedPartitioningPolicy(String) - Constructor for class org.eclipse.persistence.descriptors.partitioning.PinnedPartitioningPolicy
 
PINT - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
pk - Static variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
 
pkUpdateListOrderFieldQuery - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
 
platform - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
This is also required to ensure all accessors for a session are using the same platform.
platform - Variable in class org.eclipse.persistence.internal.expressions.ExpressionJavaPrinter
 
platform - Variable in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
Stores the current platform to access platform specific functions.
platform - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Allow the datasource platform to be cached.
platform - Variable in class org.eclipse.persistence.internal.sessions.ResultSetRecord
 
platform - Variable in class org.eclipse.persistence.sequencing.Sequence
 
platform - Variable in class org.eclipse.persistence.sessions.DatasourceLogin
Implementation of platform-specific behaviors.
Platform - Interface in org.eclipse.persistence.internal.databaseaccess
Platform is private to TopLink.
PLATFORM_CLASS_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
PLATFORM_DOES_NOT_OVERRIDE_GETCREATETEMPTABLESQLPREFIX - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
PLATFORM_DOES_NOT_SUPPORT_CALL_WITH_RETURNING - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
PLATFORM_DOES_NOT_SUPPORT_SEQUENCE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
PLATFORM_DOES_NOT_SUPPORT_STORED_FUNCTIONS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
PLATFORM_NAME - Static variable in class org.eclipse.persistence.services.RuntimeServices
Short name for the server platform - Must override in subclass
PLATFORM_NOT_SUPPORTED_WITH_JSON_MEDIA_TYPE - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
platformClassNotFound(Throwable, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
platformDoesNotOverrideGetCreateTempTableSqlPrefix(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
platformDoesNotSupportCallWithReturning(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
platformDoesNotSupportSequence(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
platformDoesNotSupportStoredFunctions(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
platformOperator - Variable in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
platformOperator - Variable in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
platformOperatorNames - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
platformOperators - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Operators specific to this platform
platformOperatorSelectors - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
platforms() - Method in interface org.eclipse.persistence.internal.databaseaccess.spi.JsonPlatformProvider
Returns JSON platform suppliers mapping of specific provider.
platformUnmarshaller - Variable in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
PlatformUnmarshaller - Interface in org.eclipse.persistence.internal.oxm.record
 
PlatformWrapper - Interface in org.eclipse.persistence.internal.databaseaccess
Marks DatabasePlatform specific wrapper of instance from ResultSet.
PLONG - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
PLSQLargument - Class in org.eclipse.persistence.platform.database.oracle.plsql
INTERNAL: Helper class - tracks argument's original position as well as re-ordered position Used by PLSQLrecord and PLSQLStoredProcedureCall
PLSQLargument() - Constructor for class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
PLSQLargument(String, int, DatasourceCall.ParameterType, DatabaseType) - Constructor for class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
PLSQLargument(String, int, DatasourceCall.ParameterType, DatabaseType, int) - Constructor for class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
PLSQLargument(String, int, DatasourceCall.ParameterType, DatabaseType, int, int) - Constructor for class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
PLSQLBoolean - org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
PLSQLBoolean_IN_CONV - Static variable in interface org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLType
 
PLSQLBoolean_OUT_CONV - Static variable in interface org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLType
 
PLSQLCollection - Class in org.eclipse.persistence.platform.database.oracle.plsql
PUBLIC: Marker interface for Oracle PL/SQL Collections (Nested Tables and Varrays)
PLSQLCollection() - Constructor for class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCollection
The default constructor sets javaType to ArrayList.class
PLSQLCollectionWrapper - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: a helper class that holds DatabaseType's.
PLSQLCollectionWrapper() - Constructor for class org.eclipse.persistence.internal.sessions.factories.PLSQLCollectionWrapper
 
PLSQLCollectionWrapper(DatabaseType) - Constructor for class org.eclipse.persistence.internal.sessions.factories.PLSQLCollectionWrapper
 
PLSQLCursor - Class in org.eclipse.persistence.platform.database.oracle.plsql
PUBLIC: describe an Oracle PL/SQL Cursor type
PLSQLCursor() - Constructor for class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCursor
 
PLSQLCursor(String) - Constructor for class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCursor
 
PLSQLCursorWrapper - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: a helper class that holds DatabaseTypes.
PLSQLCursorWrapper() - Constructor for class org.eclipse.persistence.internal.sessions.factories.PLSQLCursorWrapper
 
PLSQLCursorWrapper(DatabaseType) - Constructor for class org.eclipse.persistence.internal.sessions.factories.PLSQLCursorWrapper
 
PLSQLInteger - org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
PLSQLParameter - Annotation Type in org.eclipse.persistence.platform.database.oracle.annotations
A PLSQLParameter annotation is used within a NamedPLSQLStoredProcedureQuery or PLSQLRecord annotation.
PLSQLrecord - Class in org.eclipse.persistence.platform.database.oracle.plsql
PUBLIC: describe an Oracle PL/SQL Record type
PLSQLrecord() - Constructor for class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
PLSQLRecord - Annotation Type in org.eclipse.persistence.platform.database.oracle.annotations
A PLSQLRecord annotation is used to define a database PLSQL RECORD type.
PLSQLRecords - Annotation Type in org.eclipse.persistence.platform.database.oracle.annotations
A PLSQLRecords annotation allows the definition of multiple PLSQLRecord.
PLSQLRecordWrapper - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: a helper class that holds DatabaseType's.
PLSQLRecordWrapper() - Constructor for class org.eclipse.persistence.internal.sessions.factories.PLSQLRecordWrapper
 
PLSQLRecordWrapper(DatabaseType) - Constructor for class org.eclipse.persistence.internal.sessions.factories.PLSQLRecordWrapper
 
PLSQLStoredFunctionCall - Class in org.eclipse.persistence.platform.database.oracle.plsql
Purpose: Used to define a platform independent function call.
PLSQLStoredFunctionCall() - Constructor for class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredFunctionCall
 
PLSQLStoredFunctionCall(DatabaseType) - Constructor for class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredFunctionCall
 
PLSQLStoredFunctionCall(DatabaseType, int) - Constructor for class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredFunctionCall
 
PLSQLStoredFunctionCall(DatabaseType, int, int) - Constructor for class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredFunctionCall
 
PLSQLStoredProcedureCall - Class in org.eclipse.persistence.platform.database.oracle.plsql
Purpose: Generates an Anonymous PL/SQL block to invoke the specified Stored Procedure with arguments that may or may not have JDBC equivalents.
PLSQLStoredProcedureCall() - Constructor for class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
PLSQLTable - Annotation Type in org.eclipse.persistence.platform.database.oracle.annotations
A PLSQLTable annotation is used to define a database PLSQL TABLE type.
PLSQLTables - Annotation Type in org.eclipse.persistence.platform.database.oracle.annotations
A PLSQLRecords annotation allows the definition of multiple PLSQLTable.
PointBase - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
PointBasePlatform - Class in org.eclipse.persistence.platform.database
Support the Pointbase database.
PointBasePlatform() - Constructor for class org.eclipse.persistence.platform.database.PointBasePlatform
Default constructor.
policy - Variable in class org.eclipse.persistence.descriptors.partitioning.CustomPartitioningPolicy
 
policy - Variable in class org.eclipse.persistence.queries.Cursor
Query policy that initialize the stream.
policy - Variable in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
POLYMORPHIC_REPORT_ITEM_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
polymorphicReportItemWithMultipletableNotSupported(String, Expression, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
pool - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
 
POOL_NAME_DOES_NOT_EXIST - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
poolName - Variable in class org.eclipse.persistence.sessions.server.ConnectionPolicy
Name of the pool to be used.
poolNameDoesNotExist(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
POOLS_MUST_BE_CONFIGURED_BEFORE_LOGIN - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
PoolsConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.pool
INTERNAL:
PoolsConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.pool.PoolsConfig
 
poolsMustBeConfiguredBeforeLogin() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
pop() - Method in class org.eclipse.persistence.internal.oxm.record.MarshalRecord.CycleDetectionStack
 
pop(String) - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.StackUnmarshalNamespaceResolver
 
pop(String) - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceContext
The underlying NamespaceContext is responsible for maintaining the appropriate prefix/URI associations.
pop(String) - Method in interface org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceResolver
Remove the last declared namespace URI binding for this prefix.
popAttributeGroup() - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
popAttributeGroup() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
populateAndRegisterObject(Object, Object, CacheKey, CacheKey, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This method is called from clone and register.
populateAttributesForClone(Object, CacheKey, Object, Integer, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Clones the attributes of the specified object.
populateLocalResources() - Method in class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
INTERNAL:
populateMapThreadToObjectIdsWithChagenSet(Thread, Collection<ObjectChangeSet>) - Static method in class org.eclipse.persistence.internal.helper.WriteLockManager
Before a thread starts long wait loop to acquire write locks during a commit transaction the thread will record in this map the object ids it holds with chance sets.
populateQuery(CharSequence, DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.internal.jpa.jpql.HermesParser
 
populateQuery(CharSequence, DatabaseQuery, AbstractSession) - Method in interface org.eclipse.persistence.queries.JPAQueryBuilder
Populates the given DatabaseQuery by parsing the given JPQL query.
populateQuery(AbstractSession) - Method in class org.eclipse.persistence.queries.JPQLCall
Populate the query using the information retrieved from parsing the EJBQL.
populateRow(DatabaseField[], Object[], ResultSet, ResultSetMetaData, AbstractSession, int, int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
 
PopulationManager - Class in org.eclipse.persistence.tools.schemaframework
Purpose: This class is used to populate example data into the database, it allows for circular references to be resolved.
PopulationManager() - Constructor for class org.eclipse.persistence.tools.schemaframework.PopulationManager
 
PORT_TOKEN - Static variable in class org.eclipse.persistence.sessions.coordination.ServiceId
This $HOST token indicate that the host ip of the URL should be replaced at runtime by user input
position - Variable in class org.eclipse.persistence.oxm.record.JsonRecord
 
position - Variable in class org.eclipse.persistence.queries.Cursor
Current position in the objectCollection of the stream.
POSITION_AFTER_GET_PREFIX - Static variable in class org.eclipse.persistence.internal.helper.Helper
 
POSITION_AFTER_IS_PREFIX - Static variable in class org.eclipse.persistence.internal.helper.Helper
 
POSITIONAL - org.eclipse.persistence.queries.DatabaseQuery.ParameterType
 
Positive - org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
POSITIVE_INFINITY - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
POSITIVE_INTEGER - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
POSITIVE_INTEGER_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
PositiveN - org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
possibleFailure - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
This attribute is used to track failures on an accessor that may be communication based.
POST - Static variable in class org.eclipse.persistence.internal.sessions.CommitManager
The commit is in progress, and the row has been written.
POST_INITIALIZED - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
postAcquireClientSession() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Post acquire client session.
postAcquireClientSession(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postAcquireClientSession(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the client session after creation/acquiring.
PostAcquireClientSession - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postAcquireConnection(Accessor) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: This method rises appropriate for the session event(s) right after connection is acquired.
postAcquireConnection(Accessor) - Method in class org.eclipse.persistence.internal.sessions.ExclusiveIsolatedClientSession
INTERNAL: This method rises appropriate for the session event(s) right after connection is acquired.
postAcquireConnection(Accessor) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Raised after acquire a connection from a connection pool.
postAcquireConnection(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postAcquireConnection(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on when using the server/client sessions.
PostAcquireConnection - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postAcquireExclusiveConnection(ClientSession, Accessor) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Raised after acquire a connection from a connection pool.
postAcquireExclusiveConnection(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postAcquireExclusiveConnection(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised when a ClientSession, with Isolated data, acquires an exclusive connection.
PostAcquireExclusiveConnection - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postAcquireUnitOfWork() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Post acquire unit of work.
postAcquireUnitOfWork(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postAcquireUnitOfWork(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the unit of work after creation/acquiring.
PostAcquireUnitOfWork - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postBeginTransaction() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Post begin transaction.
postBeginTransaction(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postBeginTransaction(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised after a database transaction is started.
PostBeginTransaction - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postBuild(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
postBuild(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised after an object is built from its row on a read operation.
postBuild(DescriptorEvent) - Method in class org.eclipse.persistence.mappings.TypedAssociation
INTERNAL: Handler for the descriptor post build event.
postBuildAttributesIntoObjectEvent(Object, AbstractRecord, ObjectBuildingQuery, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
postBuildAttributesIntoWorkingCopyCloneEvent(Object, AbstractRecord, ObjectBuildingQuery, UnitOfWorkImpl, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
PostBuildEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
postCalculateChanges(Object, Object, ClassDescriptor, DatabaseMapping, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Add the provided object to the deleted objects list on the commit manager.
postCalculateChanges(Object, Object, ClassDescriptor, DatabaseMapping, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Add the provided object to the deleted objects list on the commit manager.
postCalculateChanges(ObjectChangeSet, ClassDescriptor, DatabaseMapping, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Add the provided object to the deleted objects list on the commit manager.
postCalculateChanges(ObjectChangeSet, ClassDescriptor, DatabaseMapping, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Add the provided object to the deleted objects list on the commit manager.
postCalculateChanges(ChangeRecord, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Overridden by mappings that require additional processing of the change record after the record has been calculated.
postCalculateChanges(ChangeRecord, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Overridden by mappings that require additional processing of the change record after the record has been calculated.
postCalculateChanges(ChangeRecord, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Overridden by mappings that require additional processing of the change record after the record has been calculated.
postCalculateChanges(ChangeRecord, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Overridden by mappings that require additional processing of the change record after the record has been calculated.
postCalculateChanges(ChangeRecord, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Overridden by mappings that require additional processing of the change record after the record has been calculated.
postCalculateChanges(ChangeRecord, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL: Overridden by mappings that require additional processing of the change record after the record has been calculated.
postCalculateChangesOnDeleted(Object, UnitOfWorkChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Overridden by mappings that require objects to be deleted contribute to change set creation.
postCalculateChangesOnDeleted(Object, UnitOfWorkChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL: Overridden by mappings that require objects to be deleted contribute to change set creation.
postCalculateUnitOfWorkChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Post calculate UnitOfWork Change Set.
postCalculateUnitOfWorkChangeSet(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postCalculateUnitOfWorkChangeSet(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised after the commit has begun on the UnitOfWork and after the changes are calculated.
PostCalculateUnitOfWorkChangeSet - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postClone(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
postClone(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised after an object is cloned into a unit of work.
PostCloneEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
postCommitTransaction() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Post commit transaction.
postCommitTransaction(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postCommitTransaction(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised after a database transaction is commited.
PostCommitTransaction - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postCommitUnitOfWork() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Post commit unit of work.
postCommitUnitOfWork(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postCommitUnitOfWork(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the unit of work after commit.
PostCommitUnitOfWork - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postConnect(Accessor) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Raised after connecting.
postConnect(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postConnect(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised after the session connects to the database.
PostConnect - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postConnectDatasource() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: This method includes all of the code that is issued after the datasource is connected to.
postConstruct() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
Post construct.
postConstruct(DynamicEntity) - Method in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
 
postCopyIn(Map) - Method in class org.eclipse.persistence.expressions.Expression
 
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.ArgumentListFunctionExpression
 
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.BaseExpression
INTERNAL: Used for cloning.
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.CollectionExpression
INTERNAL: Used for cloning.
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: Used for cloning.
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: Used for cloning.
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL: Used for cloning.
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
INTERNAL: Also copy over the sub-select if present.
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Used for cloning.
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
INTERNAL: Used for cloning.
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL: Used for cloning.
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Used for cloning.
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Used for cloning.
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
The query must be cloned, and the sub-expression must be cloned using the same outer expression identity.
postCopyIn(Map) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
postCopyIn(Map, List<Expression>, List<Expression>) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL: The method was added to circumvent derivedFields and derivedTables being protected.
postCreateObject(AbstractSession, Writer, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
Execute any statements required after the creation of the object
postCreateObject(AbstractSession, Writer, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
Execute any statements required after the creation of the object
postDelete(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
postDelete(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised after an object is deleted from the database.
postDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Execute the post delete operation for the query
postDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Delete the reference objects.
postDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: The message is passed to its reference class descriptor.
postDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
postDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
postDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Delete privately owned parts
postDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Delete privately owned parts
postDelete(ModifyQuery) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
postDeleteAttributeValue(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: The message is passed to its reference class descriptor.
postDeleteAttributeValue(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
The message is passed to its reference class descriptor.
PostDeleteEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
postDistributedMergeUnitOfWorkChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre execute query.
postDistributedMergeUnitOfWorkChangeSet(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postDistributedMergeUnitOfWorkChangeSet(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This even will be raised after a UnitOfWorkChangeSet has been merged When that changeSet has been received from a distributed session
PostDistributedMergeUnitOfWorkChangeSet - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postExecuteCall(Call, Object) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Post execute call.
postExecuteCall(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postExecuteCall(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised after the execution of every call against the session.
PostExecuteCall - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postExecuteQuery(DatabaseQuery, Object) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Post execute query.
postExecuteQuery(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postExecuteQuery(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised after the execution of every query against the session.
PostExecuteQuery - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postfixSQL(String) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Inserts the SQL as is directly into the expression.
PostgreSQL - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
PostgreSQL10Platform - Class in org.eclipse.persistence.platform.database
Postgres 10 database platform extension.
PostgreSQL10Platform() - Constructor for class org.eclipse.persistence.platform.database.PostgreSQL10Platform
Creates an instance of Postgres 10 platform.
PostgreSQL10Platform.PostgreSQL10JsonExtension - Interface in org.eclipse.persistence.platform.database
Add extended JSON functionality dependent on PostgreSQL JDBC driver.
PostgreSQLPlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides Postgres specific behavior.
PostgreSQLPlatform() - Constructor for class org.eclipse.persistence.platform.database.PostgreSQLPlatform
 
postInitialize(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Initialize the cache isolation setting.
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Post initializations after mappings are initialized.
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Post initializations after mappings are initialized.
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: postInitialize called for inheritance children first.
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Initialized the inheritance properties that cannot be initialized until after the mappings have been.
postInitialize(AbstractSession) - Method in interface org.eclipse.persistence.descriptors.MultitenantPolicy
 
postInitialize(AbstractSession) - Method in interface org.eclipse.persistence.descriptors.SerializedObjectPolicy
postinitialize the policy: determine which mappings are included, which fields should be selected
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL: Subclasses that need to add field to an expresison should override this method.
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL:
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeObjectMapping
INTERNAL: Initialize the mapping.
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Post initializations after mappings are initialized.
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.SerializedObjectPolicyWrapper
 
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Some subclasses need to post initialize mappings associated with them
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Some subclasses need to post initialize mappings associated with them.
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: For aggregate collection mapping the reference descriptor is cloned.
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: For an aggregate mapping the reference descriptor is cloned.
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Ensure the container policy is post initialized
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Allow for initialization of properties and validation that have dependecies no the descriptor being initialized.
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Ensure the container policy is post initialized
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: Post Initialize the mapping.
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
Initialize the type of the target foreign key, as it will be null as it is not mapped in the target.
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
postInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Post initializations after mappings are initialized.
postInitializeMapKey(MappedKeyMapContainerPolicy) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Making any mapping changes necessary to use a the mapping as a map key after initializing the mapping.
postInitializeMapKey(MappedKeyMapContainerPolicy) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Making any mapping changes necessary to use a the mapping as a map key after initializing the mapping.
postInitializeMapKey(MappedKeyMapContainerPolicy) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Making any mapping changes necessary to use a the mapping as a map key after initializing the mapping
postInitializeMapKey(MappedKeyMapContainerPolicy) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Need to set the field type for the foreign key fields for a map key, as the fields are not contained in any descriptor.
postInitializeSourceAndTargetExpressions() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Mapping callback for post-initialization of source and target expression fields created when a mapping's selectionCriteria is created early with uninitialized fields.
postInitializeSourceAndTargetExpressions() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Post-initialize source and target expression fields created when a mapping's selectionCriteria is created early with only partly initialized fields.
postInitializeSourceAndTargetExpressions() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Post-initialize source and target expression fields created when a mapping's selectionCriteria is created early with only partly initialized fields.
postInitTableSchema(ClassDescriptor) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Build additional table/field definitions for the descriptor, like relation table and direct-collection, direct-map table, as well as reset LOB type for serialized object mapping and type conversion mapping for LOB usage
postInsert(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
postInsert(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised after an object is inserted to the database.
postInsert(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
postInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Execute the post insert operation for the query
postInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Insert the reference objects.
postInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Insert privately owned parts
postInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: The message is passed to its reference class descriptor.
postInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
postInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
postInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Insert the private owned object.
postInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Insert the private owned object.
postInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Insert into relation table.
postInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Insert privately owned parts
postInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Insert the reference objects.
postInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Insert into relation table.
postInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Insert privately owned parts
PostInsert - Static variable in class org.eclipse.persistence.mappings.ManyToManyMapping
Used for data modification events.
PostInsert - Static variable in class org.eclipse.persistence.mappings.OneToManyMapping
Used for data modification events.
postInsertAttributeValue(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: The message is passed to its reference class descriptor.
postInsertAttributeValue(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
The message is passed to its reference class descriptor.
PostInsertEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
postInstantiate() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
INTERNAL: Run any extra code required after the valueholder instantiates
postInstantiate() - Method in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
INTERNAL: Run any extra code required after the valueholder instantiates For query based VH, we notify the cache that the valueholder has been triggered
postLogin() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Rise postLogin event.
postLogin() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Rise postLogin events for member sessions and the SessionBroker.
postLogin(Session) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: post login to the session.
postLogin(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postLogin(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This Event is raised after the session logs in.
PostLogin - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postLogout(Session) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: post logout to the session.
postLogout(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postLogout(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This Event is raised after the session logs out.
PostLogout - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postMerge(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
postMerge(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised after an object is merged from a unit of work into its parent.
postMergeChanges(Set) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Remove objects from parent's identity map.
PostMergeEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
postMergeUnitOfWorkChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre execute query.
postMergeUnitOfWorkChangeSet(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postMergeUnitOfWorkChangeSet(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This even will be raised after a UnitOfWorkChangeSet has been merged
PostMergeUnitOfWorkChangeSet - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postPrepareNestedBatchQuery(ReadQuery, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Allow the mapping the do any further batch preparation.
postPrepareNestedBatchQuery(ReadQuery, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Add additional fields
postPrepareNestedBatchQuery(ReadQuery, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Allow the mapping the do any further batch preparation.
postPrepareNestedBatchQuery(ReadQuery, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Add additional fields and check for history.
postPrepareNestedBatchQuery(ReadQuery, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Allow the mapping the do any further batch preparation.
postPrepareNestedBatchQuery(ReadQuery, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Add the addition join fields to the batch query.
postPrepareNestedBatchQuery(ReadQuery, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL: Add additional fields
postRefresh(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
postRefresh(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised after an object is refreshed from its row on a refresh operation.
PostRefreshEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
postRegisterIndividualResult(Object, Object, Object, UnitOfWorkImpl, JoinedAttributeManager, ClassDescriptor) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
Post process the object once it is registered in the unit of work.
postReleaseClientSession() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Post release client session.
postReleaseClientSession(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postReleaseClientSession(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the client session after releasing.
PostReleaseClientSession - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postReleaseUnitOfWork() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Post release unit of work.
postReleaseUnitOfWork(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postReleaseUnitOfWork(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the unit of work after release.
PostReleaseUnitOfWork - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postResumeUnitOfWork() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Post resume unit of work.
postResumeUnitOfWork(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postResumeUnitOfWork(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the unit of work after resuming.
PostResumeUnitOfWork - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postRollbackTransaction() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Post rollback transaction.
postRollbackTransaction(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
postRollbackTransaction(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised after a database transaction is rolledback.
PostRollbackTransaction - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
postSerialize(Object, UnitOfWorkChangeSet, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Reset the change set's transient variables after serialization.
postUpdate(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
postUpdate(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised after an object updated in the database.
postUpdate(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
postUpdate(ObjectLevelModifyQuery, boolean) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
postUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Execute the post update operation for the query
postUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Update the reference objects.
postUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Update the privately owned parts
postUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: The message is passed to its reference class descriptor.
postUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
postUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Update private owned part.
postUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Update the relation table with the entries related to this mapping.
postUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Update privately owned parts
postUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Update the reference objects.
postUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Update the relation table with the entries related to this mapping.
postUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Update privately owned parts
postUpdateAttributeValue(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: The message is passed to its reference class descriptor.
postUpdateAttributeValue(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
The message is passed to its reference class descriptor.
PostUpdateEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
postUpdateWithChangeSet(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Update private owned part.
postUpdateWithChangeSet(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Update private owned part.
postUpdateWithChangeSetListOrder(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Update private owned part.
postWrite(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
postWrite(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised after an object is inserted or updated in the database.
PostWriteEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
power() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
power(Expression, int) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
power(Expression, Object) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Power - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
PRE - Static variable in class org.eclipse.persistence.internal.sessions.CommitManager
The commit is in progress, but the row has not been written.
preBeginTransaction() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre begin transaction.
preBeginTransaction(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preBeginTransaction(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised before a database transaction is started.
PreBeginTransaction - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
preCalculateUnitOfWorkChangeSet() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre calculate UnitOfWork Change Set.
preCalculateUnitOfWorkChangeSet(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preCalculateUnitOfWorkChangeSet(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised after the commit has begun on the UnitOfWork but before the changes are calculated.
PreCalculateUnitOfWorkChangeSet - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
precision - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
 
precision - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
precision() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLParameter
(Optional) If a numeric, the max precision value.
preCommitTransaction() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre commit transaction.
preCommitTransaction(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preCommitTransaction(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised before a database transaction is commited.
PreCommitTransaction - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
preCommitUnitOfWork() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre commit unit of work.
preCommitUnitOfWork(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preCommitUnitOfWork(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the unit of work before commit.
PreCommitUnitOfWork - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
preConnectDatasource() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: This method includes all of the code that is issued before the datasource is connected to.
predecessor - Variable in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
preDelete(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
preDelete(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised before an object is deleted from the database.
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Execute the pre delete operation for the query
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Delete the reference objects.
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Delete privately owned parts
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: The message is passed to its reference class descriptor.
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Delete private owned part.
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Propagate the preDelete event through the container policy if necessary
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Delete entries related to this mapping from the relation table.
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Delete privately owned parts
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Delete the reference objects.
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Delete privately owned parts
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: Delete privately owned parts
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Delete privately owned parts
preDelete(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL: Delete the reference objects.
preDeleteAttributeValue(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: The message is passed to its reference class descriptor.
preDeleteAttributeValue(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
The message is passed to its reference class descriptor.
preDeleteComplete - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
This attribute records when the preDelete stage of Commit has completed
PreDeleteEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
preDeleteMappings - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
stores a list of mappings that require preDelete as a group prior to the delete individually
PREDEPLOY_FAILED - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
predeployFailed(String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
predicateAttribute(XPathFragment, NAMESPACE_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
predicateAttribute(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Marshal the attribute for the predicate if one was specified.
preDistributedMergeUnitOfWorkChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre merge Distributed UnitOfWorkChangeSet
preDistributedMergeUnitOfWorkChangeSet(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preDistributedMergeUnitOfWorkChangeSet(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This even will be raised before a UnitOfWorkChangeSet has been merged When that changeSet has been received from a distributed session
PreDistributedMergeUnitOfWorkChangeSet - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
preDropObject(AbstractSession, Writer, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
Execute any statements required before the deletion of the object
preDropObject(AbstractSession, Writer, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
Execute any statements required before the deletion of the object
preDropObject(AbstractSession, Writer, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
Execute any statements required before the deletion of the object
preExecuteCall(Call) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre execute call.
preExecuteCall(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preExecuteCall(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised before the execution of every call against the session.
PreExecuteCall - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
preExecuteQuery(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre execute query.
preExecuteQuery(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preExecuteQuery(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised before the execution of every query against the session.
PreExecuteQuery - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
prefetchCacheKeys - Variable in class org.eclipse.persistence.descriptors.CachePolicy
In certain cases and cache types it is more efficient to preFetch the cache keys from the cache when building the results of the query.
prefetchedCacheKeys - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
 
prefix - Variable in class org.eclipse.persistence.internal.oxm.Namespace
 
prefix - Variable in class org.eclipse.persistence.internal.oxm.Root
 
PREFIX - org.eclipse.persistence.annotations.TenantTableDiscriminatorType
Apply the tenant table discriminator as a prefix to all multitenant tables.
PREFIX_USED_BUT_NOT_DEFINED - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
PrefixMapperNamespaceResolver - Class in org.eclipse.persistence.internal.oxm.record.namespaces
INTERNAL:
PrefixMapperNamespaceResolver(NamespacePrefixMapper, NamespaceResolver) - Constructor for class org.eclipse.persistence.internal.oxm.record.namespaces.PrefixMapperNamespaceResolver
 
prefixSQL(String) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Insert the SQL as is directly into the expression.
prefixUsedButNotDefined(String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: thrown from SDOTypesGenerator
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Allow the descriptor to initialize any dependencies on this session.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Initialize the query manager.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Allow the inheritance properties of the descriptor to be initialized.
preInitialize(AbstractSession) - Method in interface org.eclipse.persistence.descriptors.MultitenantPolicy
 
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL: Allow the descriptor to initialize any dependencies on this session.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL:
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.VPDMultitenantPolicy
INTERNAL: Allow the descriptor to initialize any dependencies on this session.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: Configure the object builder for the correct dataFormat.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeCollectionMapping
Fix field names for XML data descriptors.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeObjectMapping
Fix field names for XML data descriptors.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
Fix field names for XML data descriptors.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.QNameInheritancePolicy
INTERNAL: Allow the inheritance properties of the descriptor to be initialized.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Allow for initialization of properties and validation.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Initialize the state of mapping.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Initialize the attribute classification.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Allow for initialization of properties and validation.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Initialize the state of mapping.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Set the type field classification through searching the indicators hashtable.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.mappings.xdb.DirectToXMLTypeMapping
INTERNAL: Default to mutable if mapped as a DOM.
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAbstractAnyMapping
 
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
 
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
 
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
 
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLTransformationMapping
 
preInitialize(AbstractSession) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Allow the descriptor to initialize any dependencies on this session.
PREINITIALIZED - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
preInitializeInheritancePolicy(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Hook together the inheritance policy tree.
preInitializeInheritancePolicy(AbstractSession) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
preinitializeMapKey(DatabaseTable) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Making any mapping changes necessary to use a the mapping as a map key prior to initializing the mapping
preinitializeMapKey(DatabaseTable) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Making any mapping changes necessary to use a the mapping as a map key prior to initializing the mapping.
preinitializeMapKey(DatabaseTable) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Making any mapping changes necessary to use a the mapping as a map key prior to initializing the mapping
preinitializeMapKey(DatabaseTable) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Making any mapping changes necessary to use a the mapping as a map key prior to initializing the mapping
preInsert(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
preInsert(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised before an object is inserted to the database.
preInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Execute the pre insert operation for the query.
preInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Insert privately owned parts
preInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: The message is passed to its reference class descriptor.
preInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: The message is passed to its reference class descriptor.
preInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Propagate preInsert event to container policy if necessary
preInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
preInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Insert privately owned parts
preInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: Insert privately owned parts
preInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Insert privately owned parts
preInsertAttributeValue(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: The message is passed to its reference class descriptor.
preInsertAttributeValue(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
The message is passed to its reference class descriptor.
PreInsertEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
preInterfaceInitialization(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Allow the descriptor to initialize any dependencies on this session.
preLogin(Session) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre login to the session.
preLogin(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preLogin(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This Event is raised before the session logs in.
preLogin(PROJECT, ClassLoader) - Method in class org.eclipse.persistence.internal.oxm.Context.ContextState
 
PreLogin - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
preLogout(Session) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre logout to the session.
preLogout(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preLogout(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This Event is raised before the session logs out.
PreLogout - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
preMergeChanges() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Remove objects deleted during commit from clone and new object cache so that these are not merged
preMergeUnitOfWorkChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre merge UnitOfWorkChangeSet
preMergeUnitOfWorkChangeSet(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preMergeUnitOfWorkChangeSet(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This even will be raised before a UnitOfWorkChangeSet has been merged
PreMergeUnitOfWorkChangeSet - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
prepare() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
This is different from 'prepareForExecution()' in that this is called on the original query, and the other is called on the clone of the query.
prepare() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
INTERNAL: This is different from 'prepareForExecution' in that this is called on the original query, and the other is called on the copy of the query.
prepare() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Override super to do nothing.
prepare() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
INTERNAL: This is different from 'prepareForExecution' in that this is called on the original query, and the other is called on the copy of the query.
prepare() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: This is different from 'prepareForExecution' in that this is called on the original query, and the other is called on the copy of the query.
prepare() - Method in class org.eclipse.persistence.queries.DataModifyQuery
INTERNAL: Prepare the receiver for execution in a session.
prepare() - Method in class org.eclipse.persistence.queries.DataReadQuery
INTERNAL: Prepare the receiver for execution in a session.
prepare() - Method in class org.eclipse.persistence.queries.DeleteAllQuery
INTERNAL: Prepare the receiver for execution in a session.
prepare() - Method in class org.eclipse.persistence.queries.DeleteObjectQuery
INTERNAL: Prepare the receiver for execution in a session.
prepare() - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Prepare the receiver for execution in a session.
prepare() - Method in class org.eclipse.persistence.queries.InsertObjectQuery
INTERNAL: Prepare the receiver for execution in a session.
prepare() - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
INTERNAL: Prepare the receiver for execution in a session.
prepare() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Prepare the receiver for execution in a session.
prepare() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Prepare the receiver for execution in a session.
prepare() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Prepare the receiver for execution in a session.
prepare() - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: This is different from 'prepareForExecution' in that this is called on the original query, and the other is called on the copy of the query.
prepare() - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Prepare the receiver for execution in a session.
prepare() - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
INTERNAL: Prepare the receiver for execution in a session.
prepare() - Method in class org.eclipse.persistence.queries.UpdateAllQuery
INTERNAL:
prepare() - Method in class org.eclipse.persistence.queries.UpdateObjectQuery
INTERNAL: Prepare the receiver for execution in a session.
prepare(AbstractSession) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
Set the default record name from the descriptor.
prepare(AbstractSession) - Method in class org.eclipse.persistence.eis.interactions.QueryStringInteraction
Translate the custom query markers.
prepare(AbstractSession) - Method in class org.eclipse.persistence.eis.interactions.XMLInteraction
Set the default record name from the descriptor.
prepare(AbstractSession) - Method in class org.eclipse.persistence.eis.interactions.XQueryInteraction
INTERNAL: Translate the custom query markers.
prepare(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Allow pre-printing of the SQL string for fully bound calls, to save from reprinting.
prepare(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Allow pre-printing of the query/SQL string for fully bound calls, to save from reprinting.
prepare(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
prepare(AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
Allow pre-printing of the query/SQL string for fully bound calls, to save from reprinting.
prepare(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.remote.Transporter
Serialize the object.
prepare(DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
Prepare and validate.
prepare(DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
Prepare and validate.
prepare(DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.queries.CursoredStreamPolicy
INTERNAL: Prepare and validate.
prepare(DatabaseQuery, AbstractSession) - Method in class org.eclipse.persistence.queries.CursorPolicy
INTERNAL: Prepare and validate.
PREPARE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.prepare"
PREPARE_FAILED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
prepareAndVerify(FetchGroup) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
PUBLIC: Add primary key and version attributes to the passed fetch group and all the fetch group it contains.
prepareAndVerifyInternal(FetchGroup, String) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Add primary key and version attributes to the passed fetch group and all the fetch group it contains.
prepareBatchStatement(Statement, int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Internal: Allows setting the batch size on the statement Is used with parameterized SQL, and should only be passed in prepared statements
prepareBatchStatement(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DynamicSQLBatchWritingMechanism
INTERNAL: This method is used to build the batch statement by concatenating the strings together.
prepareBatchStatements(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
INTERNAL: This method is used to build the parameterized batch statement for the JDBC2.0 specification
prepareCall() - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
INTERNAL: This is different from 'prepareForExecution' in that this is called on the original query, and the other is called on the copy of the query.
prepareCall() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
INTERNAL: This is different from 'prepareForExecution' in that this is called on the original query, and the other is called on the copy of the query.
prepareCall(Session, DataRecord) - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: Pre-generate the call/SQL for the query.
prepareCascadeLockingPolicy() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass that supports cascade version optimistic locking should implement this method to properly prepare the locking policy for their mapping type.
prepareCascadeLockingPolicy() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
Prepare a cascade locking policy.
prepareCascadeLockingPolicy() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Prepare a cascade locking policy.
prepareCascadeLockingPolicy() - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
Prepare a cascade locking policy.
prepareCascadeLockingPolicy(DatabaseMapping) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL:
prepareCursorSelectAllRows() - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Pre-build configure the SQL call.
prepareCursorSelectAllRows() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Pre-pare for a cursored execute.
prepareCursorSelectAllRows() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Pre-build configure the call.
prepareCursorSelectAllRows() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expression.
prepareCursorSelectAllRows() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Pre-build the SQL call from the statement.
prepareCustomQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the properties needed to be cascaded into the custom query.
prepareCustomQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.DeleteObjectQuery
INTERNAL: Set the properties needed to be cascaded into the custom query.
prepareCustomQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.InsertObjectQuery
INTERNAL: Set the properties needed to be cascaded into the custom query.
prepareCustomQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Set the properties needed to be cascaded into the custom query including the translation row.
prepareCustomQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Set the properties needed to be cascaded into the custom query.
prepareCustomQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Set the properties needed to be cascaded into the custom query including the translation row.
prepareCustomQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.UpdateObjectQuery
INTERNAL: Set the properties needed to be cascaded into the custom query.
prepareDatabaseQuery(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: A call back to do session specific preparation of a query.
prepareDeleteAll() - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Pre-build configure the SQL call.
prepareDeleteAll() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Prepare for a delete all.
prepareDeleteAll() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Pre-build configure the call.
prepareDeleteAll() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expression.
prepareDeleteAll() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Pre-build the SQL call from the statement.
prepareDeleteAll(List<DatabaseTable>, boolean) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expression.
prepareDeleteAllUsingTempStorage() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
prepareDeleteAllUsingTempTables() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
prepareDeleteObject() - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Pre-build configure the SQL call.
prepareDeleteObject() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Prepare for a delete.
prepareDeleteObject() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Pre-build configure the call.
prepareDeleteObject() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expression.
prepareDeleteObject() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Pre-build the SQL call from the statement.
prepareDoesExist(DatabaseField) - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Pre-build configure the SQL call.
prepareDoesExist(DatabaseField) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Pre-pare for a select execute.
prepareDoesExist(DatabaseField) - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Pre-build configure the call.
prepareDoesExist(DatabaseField) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expression.
prepareDoesExist(DatabaseField) - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Pre-build the SQL call from the statement.
prepareExecute() - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Pre-build configure the SQL call for an execute call.
prepareExecute() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Prepare for a raw execute call.
prepareExecute() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Pre-build configure the call.
prepareExecuteNoSelect() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Prepare for a raw (non-object), non-selecting call.
prepareExecuteNoSelect() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Pre-build configure the call.
prepareExecuteNoSelect() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Pre-build the SQL call from the statement.
prepareExecuteSelect() - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Pre-build configure the SQL call.
prepareExecuteSelect() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Prepare for a raw (non-object) select call.
prepareExecuteSelect() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Pre-build configure the call.
prepareExecuteSelect() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Pre-build the SQL call from the statement.
prepareFailed(Exception, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
prepareFetchGroup() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Add mandatory attributes to fetch group, create entityFetchGroup.
prepareFetchGroup() - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: ReportQuery doesn't support fetch groups.
prepareForExecution() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
Prepare and validate.
prepareForExecution() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Prepare the receiver for execution in a session.
prepareForExecution() - Method in class org.eclipse.persistence.queries.DataModifyQuery
INTERNAL: Prepare the receiver for execution in a session.
prepareForExecution() - Method in class org.eclipse.persistence.queries.DataReadQuery
INTERNAL: Prepare the receiver for execution in a session.
prepareForExecution() - Method in class org.eclipse.persistence.queries.DeleteObjectQuery
INTERNAL: Prepare the receiver for execution in a session.
prepareForExecution() - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Prepare the receiver for execution in a session.
prepareForExecution() - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
INTERNAL: Prepare the receiver for execution in a session.
prepareForExecution() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Prepare the receiver for execution in a session.
prepareForExecution() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Prepare the receiver for execution in a session.
prepareForExecution() - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: Prepare the receiver for execution in a session.
prepareForExecution() - Method in class org.eclipse.persistence.queries.WriteObjectQuery
INTERNAL: Prepare the receiver for execution in a session.
prepareForMergeIntoRemoteUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
The returned remote unit of work from the server is prepared to merge with local remote unit of work.
prepareForRemoteExecution() - Method in class org.eclipse.persistence.queries.DatabaseQuery
 
prepareForRemoteExecution() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Prepare the receiver for execution in a session.
prepareForSynchronization(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.ChangeRecord
INTERNAL: Ensure this change record is ready to by sent remotely for cache synchronization In general, this means setting the CacheSynchronizationType on any ObjectChangeSets associated with this ChangeRecord
prepareFromCachedQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Check if the query is cached and prepare from it.
prepareFromQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Prepare the query from the prepared query.
prepareFromQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Prepare the query from the prepared query.
prepareFromQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Prepare the query from the prepared query.
prepareFromQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Prepare the query from the prepared query.
prepareFromQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Prepare the query from the prepared query.
prepareHistoricalQuery(ReadQuery, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Allow for the mapping to perform any historical query additions.
prepareHistoricalQuery(ReadQuery, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Append the temporal selection to the query selection criteria.
prepareInsertObject() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Prepare for an insert.
prepareInsertObject() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Pre-build configure the call.
prepareInsertObject() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expression.
prepareInsertObject() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Pre-build the SQL call from the statement.
prepareInternal(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Called by prepare method only.
prepareInternal(AbstractSession) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredFunctionCall
INTERNAL:
prepareInternal(AbstractSession) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
Generate the Anonymous PL/SQL block
prepareInternal(AbstractSession) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Call the prepare on the query.
prepareInternal(AbstractSession) - Method in class org.eclipse.persistence.queries.SQLCall
INTERNAL: Called by prepare method only.
prepareInternal(AbstractSession) - Method in class org.eclipse.persistence.queries.StoredFunctionCall
INTERNAL:
prepareInternal(AbstractSession) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
INTERNAL: Called by prepare method only.
prepareInternalParameters(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Called by prepareInternal method only.
prepareJDK12BatchStatement(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DynamicSQLBatchWritingMechanism
INTERNAL: This method is used to build the batch statement for the JDBC2.0 specification
prepareJoinExpression(Expression, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Validate and prepare the join expression.
prepareJoinExpressions(AbstractSession) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Validate and prepare join expressions.
prepareJoining(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Prepare the joining indexes if joining.
prepareModifyQueryForDelete(ObjectLevelModifyQuery, ObjectLevelModifyQuery, Object, Map) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: setup the modifyQuery for pre delete
prepareModifyQueryForUpdate(ObjectLevelModifyQuery, ObjectLevelModifyQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: setup the modifyQuery for update,
prepareNestedBatchQuery(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Clone and prepare the selection query as a nested batch read query.
prepareNestedBatchQuery(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Clone and prepare the selection query as a nested batch read query.
prepareNestedJoinQueryClone(AbstractRecord, List, JoinedAttributeManager, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Prepare the clone of the nested query for joining.
prepareNestedJoins(JoinedAttributeManager, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Clone and prepare the JoinedAttributeManager nested JoinedAttributeManager.
prepareNestedJoins(JoinedAttributeManager, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Clone and prepare the joined direct query.
prepareNestedJoins(JoinedAttributeManager, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Clone and prepare the JoinedAttributeManager nested JoinedAttributeManager.
prepareNestedQuery(ObjectBuildingQuery) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Clone and prepare the selection query as a nested batch read query.
prepareObjectAttributeCount(Map) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Prepare a report query with a count defined on an object attribute.
prepareObjectAttributeCount(ExpressionNormalizer, ReportItem, ReportQuery, Map) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: JPQL allows count([distinct] e), where e can be an object, not just a single field, however the database only allows a single field, so object needs to be translated to a single field.
prepareOutsideUnitOfWork(AbstractSession) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: There is a very special case where a query may be a bean-level pessimistic locking query.
prepareProjectLogin(Project, Login) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Return the correct session type from the sessionConfig
prepareQuery() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Prepare the receiver for execution in a session.
prepareQuery(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Select all objects for a concrete descriptor.
prepareReportQueryItems() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Prepare the report items.
prepareReportQuerySelectAllRows() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Pre-pare for a select execute.
prepareReportQuerySelectAllRows() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Pre-build configure the call.
prepareReportQuerySelectAllRows() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expression.
prepareReportQuerySubSelect() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Pre-pare a report query for a sub-select.
prepareReportQuerySubSelect() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Prepare for a sub select using a call.
prepareReportQuerySubSelect() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expression.
prepareResultSetAccessOptimization() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Sets usesResultSetAccessOptimization based on isResultSetAccessOptimizedQuery, session default and query settings that could not be altered without re-preparing the query.
prepareSelectAllRows() - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Pre-build configure the SQL call.
prepareSelectAllRows() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Prepare for a select returning (possibly) multiple rows.
prepareSelectAllRows() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Pre-build configure the call.
prepareSelectAllRows() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expression.
prepareSelectAllRows() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Pre-build the SQL call from the statement.
prepareSelectAllRows() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Prepare the mechanism.
prepareSelectAllRows() - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Prepare the mechanism.
prepareSelectOneRow() - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Pre-build configure the SQL call.
prepareSelectOneRow() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Prepare for a select returning a single row.
prepareSelectOneRow() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Pre-build configure the call.
prepareSelectOneRow() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expression.
prepareSelectOneRow() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Pre-build the SQL call from the statement.
prepareServerSpecificServicesMBean() - Method in class org.eclipse.persistence.platform.server.glassfish.GlassfishPlatform
INTERNAL: prepareServerSpecificServicesMBean(): Server specific implementation of the creation and deployment of the JMX MBean to provide runtime services for the databaseSession.
prepareServerSpecificServicesMBean() - Method in interface org.eclipse.persistence.platform.server.JMXEnabledPlatform
INTERNAL: prepareServerSpecificServicesMBean(): Server specific implementation of the creation and deployment of the JMX MBean to provide runtime services for the databaseSession.
prepareServerSpecificServicesMBean() - Method in class org.eclipse.persistence.platform.server.was.WebSphere_7_Platform
INTERNAL: prepareServerSpecificServicesMBean(): Server specific implementation of the creation and deployment of the JMX MBean to provide runtime services for the databaseSession.
prepareServerSpecificServicesMBean() - Method in class org.eclipse.persistence.platform.server.wls.WebLogic_10_Platform
INTERNAL: prepareServerSpecificServicesMBean(): Server specific implementation of the creation and deployment of the JMX MBean to provide runtime services for the databaseSession.
prepareStatement(String, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Prepare the SQL statement for the call.
prepareStatement(DatabaseAccessor, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Prepare the JDBC statement, this may be parameterize or a call statement.
prepareStatement(DatabaseAccessor, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
INTERNAL: Prepare the JDBC statement, this may be parameterize or a call statement.
prepareStatement(DatabaseAccessor, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: Prepare the JDBC statement, this may be parameterize or a call statement.
prepareStatement(DatabaseAccessor, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
INTERNAL: Prepare the JDBC statement, this may be parameterize or a call statement.
prepareStatement(DatabaseCall, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Prepare the SQL statement for the call.
prepareStatement(DatabaseCall, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Prepare the SQL statement for the call.
prepareSubSelect(AbstractSession, AbstractRecord, Map) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Prepare the receiver for being printed inside a subselect.
prepareTranslationRow(AbstractRecord, Object, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: copies the non primary key information into the row currently used only in ManyToMany
prepareTranslationRow(AbstractRecord, Object, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: The translation row may require additional fields than the primary key if the mapping in not on the primary key.
prepareTranslationRow(AbstractRecord, Object, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: The translation row may require additional fields than the primary key if the mapping in not on the primary key.
prepareTranslationRow(AbstractRecord, Object, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL: The translation row may require additional fields than the primary key if the mapping in not on the primary key.
prepareUnitOfWork() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Prepare unit of work.
prepareUnitOfWork(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
prepareUnitOfWork(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the unit of work after the SQL has been flushed, but the commit transaction has not been executed.
PrepareUnitOfWork - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
prepareUpdateAll() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Prepare for an update all.
prepareUpdateAll() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Pre-build configure the call.
prepareUpdateAll() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expressions.
prepareUpdateAll() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Pre-build the SQL call from the statement.
prepareUpdateAllUsingOracleAnonymousBlock(HashMap, HashMap) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expressions.
prepareUpdateAllUsingTempStorage(HashMap, HashMap<DatabaseTable, List<DatabaseField>>) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
prepareUpdateAllUsingTempTables(HashMap, HashMap<DatabaseTable, List<DatabaseField>>) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expressions.
prepareUpdateObject() - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Pre-build configure the SQL call.
prepareUpdateObject() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Prepare for an update.
prepareUpdateObject() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Pre-build configure the call.
prepareUpdateObject() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Pre-build the SQL statement from the expression.
prepareUpdateObject() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Pre-build the SQL call from the statement.
prePersist(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
prePersist(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is only raised by the EntityManager.
PrePersistEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
prePrepare() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Prepare the receiver for execution in a session.
prePrepare() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: Prepare the receiver for execution in a session.
preReleaseClientSession() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre release client session.
preReleaseClientSession(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preReleaseClientSession(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the client session before releasing.
PreReleaseClientSession - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
preReleaseConnection(Accessor) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: This method rises appropriate for the session event(s) right before the connection is released.
preReleaseConnection(Accessor) - Method in class org.eclipse.persistence.internal.sessions.ExclusiveIsolatedClientSession
INTERNAL: This method rises appropriate for the session event(s) right before the connection is released.
preReleaseConnection(Accessor) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Raised before release a connection to a connection pool.
preReleaseConnection(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preReleaseConnection(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on when using the server/client sessions.
PreReleaseConnection - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
preReleaseExclusiveConnection(ClientSession, Accessor) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: This event is fired just before a Client Session, with isolated data, releases its Exclusive Connection
preReleaseExclusiveConnection(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preReleaseExclusiveConnection(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is fired just before a Client Session, with isolated data, releases its Exclusive Connection
PreReleaseExclusiveConnection - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
preReleaseUnitOfWork() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre release unit of work.
preReleaseUnitOfWork(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preReleaseUnitOfWork(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised on the unit of work before release.
PreReleaseUnitOfWork - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
preRemove(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
preRemove(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised when the remove operation is initiated on an object.
PreRemoveEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
preRollbackTransaction() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Pre rollback transaction.
preRollbackTransaction(SessionEvent) - Method in class org.eclipse.persistence.sessions.SessionEventAdapter
 
preRollbackTransaction(SessionEvent) - Method in interface org.eclipse.persistence.sessions.SessionEventListener
PUBLIC: This event is raised before a database transaction is rolledback.
PreRollbackTransaction - Static variable in class org.eclipse.persistence.sessions.SessionEvent
 
preUpdate(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
preUpdate(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised for all existing objects written or committed in a unit of work.
preUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Execute the pre update operation for the query
preUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Update the privately owned parts.
preUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: The message is passed to its reference class descriptor.
preUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Propagate preUpdate event to container policy if necessary
preUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
preUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Update privately owned parts
preUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: Update the privately owned parts
preUpdate(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Update privately owned parts
preUpdateAttributeValue(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: The message is passed to its reference class descriptor.
preUpdateAttributeValue(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
The message is passed to its reference class descriptor.
PreUpdateEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
preUpdateWithChanges(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
preUpdateWithChanges(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised before an object is updated regardless if the object has any database changes.
PreUpdateWithChangesEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
prevailingQueue - Variable in class org.eclipse.persistence.internal.helper.WriteLockManager
 
previous - Variable in class org.eclipse.persistence.internal.identitymaps.LinkedCacheKey
Handle on previous element in cache
previous() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Return the previous object from the collection.
previousCall - Variable in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
This member variable is used to keep track of the last SQL string that was executed by this mechanism.
previousExpiry - Variable in class org.eclipse.persistence.descriptors.invalidation.DailyCacheInvalidationPolicy
 
previousIndex() - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Retrieves the previous row index (against the current row)
previousObject - Variable in class org.eclipse.persistence.queries.ScrollableCursor
 
previousRow - Variable in class org.eclipse.persistence.queries.ScrollableCursor
Store the previous row, for 1-m joining.
preWrite(DescriptorEvent) - Method in class org.eclipse.persistence.descriptors.DescriptorEventAdapter
 
preWrite(DescriptorEvent) - Method in interface org.eclipse.persistence.descriptors.DescriptorEventListener
This event is raised for all new or existing objects written or committed in a unit of work.
PreWriteEvent - Static variable in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
PRIMARY_KEY_COLUMN_NAME_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
PRIMARY_KEY_FIELDS_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
PRIMARY_KEY_UPDATE_DISALLOWED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
PRIMARY_TABLE_NOT_DEFINED_FOR_RELATIONSHIP - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
primaryKey - Variable in class org.eclipse.persistence.internal.identitymaps.CacheId
The primary key values.
primaryKey - Variable in class org.eclipse.persistence.internal.oxm.Reference
 
primaryKey - Variable in class org.eclipse.persistence.queries.DoesExistQuery
Query that is performing the does exist check.
primaryKey - Variable in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
 
primaryKey - Variable in class org.eclipse.persistence.queries.ReportQueryResult
Id value if the retrievPKs flag was set on the ReportQuery.
primaryKey() - Method in annotation type org.eclipse.persistence.annotations.TenantDiscriminatorColumn
Specifies that the tenant discriminator column is part of the primary key of the tables.
PrimaryKey - Annotation Type in org.eclipse.persistence.annotations
The PrimaryKey annotation allows advanced configuration of the Id.
primaryKeyClassifications - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
The types for the primary key fields, in same order as descriptor's primary key fields.
primaryKeyColumnNameNotSpecified(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
primaryKeyExpression - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Expression for querying an object by primary key.
primaryKeyFields - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
primaryKeyFields - Variable in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
primaryKeyFields - Variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
primaryKeyFieldsNotSepcified(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
primaryKeyIdValidations - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
Allow zero primary key validation to be configured per field.
primaryKeyJoinColumns() - Method in annotation type org.eclipse.persistence.annotations.CollectionTable
Deprecated.
(Optional) Used to specify a primary key column that is used as a foreign key to join to another table.
primaryKeyMap - Variable in class org.eclipse.persistence.internal.oxm.Reference
 
primaryKeyMappings - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Mapping for the primary key fields.
primaryKeyUpdateDisallowed(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
primaryPrefix - Variable in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolverWithPrefixes
 
primaryTableNotDefined(Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: Instance document is incomplete - primary tables must be defined for both sides of a relationhip.
printAllIdentityMapTypes() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will log the types of Identity Maps in the session.
printAllIdentityMapTypes() - Method in class org.eclipse.persistence.services.RuntimeServices
This method will log the types of Identity Maps in the session.
printArgument(FieldDefinition, Writer, AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
Print the argument and its type.
printAvailableConnectionPools() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will print the available Connection pools to the SessionLog.
printAvailableConnectionPools() - Method in class org.eclipse.persistence.services.RuntimeServices
This method will print the available Connection pools to the SessionLog.
printByte(Byte) - Method in class org.eclipse.persistence.internal.expressions.ExpressionJavaPrinter
 
printCalendar(Calendar) - Static method in class org.eclipse.persistence.internal.helper.Helper
Print the Calendar.
printCalendar(Calendar, boolean) - Static method in class org.eclipse.persistence.internal.helper.Helper
Print the Calendar.
printCalendarWithoutNanos(Calendar) - Static method in class org.eclipse.persistence.internal.helper.Helper
Print the Calendar without the nanos portion.
printCharacter(Character) - Method in class org.eclipse.persistence.internal.expressions.ExpressionJavaPrinter
 
printClassesInSession() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to output those Class Names that have identity Maps in the Session.
printClassesInSession() - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to output those Class Names that have identity Maps in the Session.
printCollection(List<Expression>, ExpressionSQLPrinter) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Print the collection onto the SQL stream.
printCollection(List<Expression>, ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
 
printCustomSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
Print the sub query to the printer.
printDate(Date) - Static method in class org.eclipse.persistence.internal.helper.Helper
Print the sql.Date.
printDate(Calendar) - Static method in class org.eclipse.persistence.internal.helper.Helper
Print the date part of the calendar.
printDate(Calendar, boolean) - Static method in class org.eclipse.persistence.internal.helper.Helper
Print the date part of the calendar.
printDayJava(Expression, Expression, ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for DAY (<date-time-part> argument.
printDaySQL(Expression, Expression, ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for DAY (<date-time-part> argument.
printDuo(Expression, Expression, ExpressionSQLPrinter) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: For performance, special case printing two children, since it's by far the most common
printDuo(Expression, Expression, ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
 
printExpression(Expression) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
printField(DatabaseField) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
printField(DatabaseField, DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
printFieldIdentityClause(Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Append the receiver's field 'identity' constraint clause to a writer.
printFieldIdentityClause(Writer) - Method in class org.eclipse.persistence.platform.database.AccessPlatform
Append the receiver's field 'identity' constraint clause to a writer.
printFieldIdentityClause(Writer) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Append the receiver's field 'identity' constraint clause to a writer.
printFieldIdentityClause(Writer) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL: Append the receiver's field 'identity' constraint clause to a writer.
printFieldIdentityClause(Writer) - Method in class org.eclipse.persistence.platform.database.H2Platform
 
printFieldIdentityClause(Writer) - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
 
printFieldIdentityClause(Writer) - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Append the receiver's field serial constraint clause to a writer.
printFieldIdentityClause(Writer) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Append the receiver's field 'identity' constraint clause to a writer.
printFieldIdentityClause(Writer) - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Append the receiver's field 'identity' constraint clause to a writer.
printFieldIdentityClause(Writer) - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Append the receiver's field 'identity' constraint clause to a writer.
printFieldIdentityClause(Writer) - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
printFieldIdentityClause(Writer) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Append the receiver's field 'identity' constraint clause to a writer.
printFieldIdentityClause(Writer) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Append the receiver's field 'identity' constraint clause to a writer.
printFieldNotNullClause(Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Append the receiver's field 'NOT NULL' constraint clause to a writer.
printFieldNotNullClause(Writer) - Method in class org.eclipse.persistence.platform.database.DBasePlatform
Append the receiver's field 'NOT NULL' constraint clause to a writer.
printFieldNullClause(Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Append the receiver's field 'NULL' constraint clause to a writer.
printFieldNullClause(Writer) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Append the receiver's field 'NULL' constraint clause to a writer.
printFieldNullClause(Writer) - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
printFieldNullClause(Writer) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Append the receiver's field 'NULL' constraint clause to a writer.
printFieldNullClause(Writer) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Append the receiver's field 'NULL' constraint clause to a writer.
printFieldTypeSize(Writer, FieldDefinition, FieldTypeDefinition) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
printFieldTypeSize(Writer, FieldDefinition, FieldTypeDefinition) - Method in class org.eclipse.persistence.platform.database.DB2Platform
 
printFieldTypeSize(Writer, FieldDefinition, FieldTypeDefinition) - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
printFieldTypeSize(Writer, FieldDefinition, FieldTypeDefinition) - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
printFieldTypeSize(Writer, FieldDefinition, FieldTypeDefinition, boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
printFieldTypeSize(Writer, FieldDefinition, FieldTypeDefinition, boolean) - Method in class org.eclipse.persistence.platform.database.AccessPlatform
 
printFieldTypeSize(Writer, FieldDefinition, FieldTypeDefinition, boolean) - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Append the field type to a writer unless the field uses an Identity strategy to generate its value.
printFieldTypeSize(Writer, FieldDefinition, FieldTypeDefinition, boolean) - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Taken from org.eclipse.persistence\foundation\org.eclipse.persistence.core\src\org\eclipse\persistence\platform\database\AccessPlatform.java
printFieldTypeSize(Writer, FieldDefinition, FieldTypeDefinition, boolean) - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
 
printFieldUnique(Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
printFieldUnique(Writer, boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
printFieldUnique(Writer, boolean) - Method in class org.eclipse.persistence.platform.database.AccessPlatform
 
printFieldUnique(Writer, boolean) - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
 
printForUpdateClauseOnJoin(DatabaseTable, ExpressionSQLPrinter, boolean, Collection, DatabasePlatform) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Print the FOR UPDATE clause after each join if required.
printFullStackTrace() - Method in exception org.eclipse.persistence.exceptions.JPQLException
PUBLIC Print the stack trace for each error generated by the parser.
printHourJava(Expression, Expression, ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for HOUR (<date-time-part> argument.
printHourSQL(Expression, Expression, ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for HOUR (<date-time-part> argument.
printIdentityMap(Class<?>) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Used to print all the objects in the identity map of the passed in class.
printIdentityMap(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
PUBLIC: Used to print all the objects in the identity map of the passed in class.
printIdentityMap(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
PUBLIC: Used to print all the objects in the identity map of the passed in class.
printIdentityMap(Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
PUBLIC: Used to print all the Objects in the identity map of the given Class type.
printIdentityMapLocks() - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
PUBLIC: Used to print all the locks in every identity map in this session.
printIdentityMapLocks() - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
PUBLIC: Used to print all the locks in every identity map in this session.
printIdentityMapLocks() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will log the instance level locks in all Identity Maps in the session.
printIdentityMapLocks() - Method in class org.eclipse.persistence.services.RuntimeServices
This method will log the instance level locks in all Identity Maps in the session.
printIdentityMapLocks() - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
PUBLIC: Used to print all the locks in every identity map in this session.
printIdentityMapLocks(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will log the instance level locks in the Identity Map for the given class in the session.
printIdentityMapLocks(String) - Method in class org.eclipse.persistence.services.RuntimeServices
This method will log the instance level locks in the Identity Map for the given class in the session.
printIdentityMaps() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Used to print all the objects in every identity map in this session.
printIdentityMaps() - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
PUBLIC: Used to print all the objects in every identity map in this session.
printIdentityMaps() - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
PUBLIC: Used to print all the objects in every identity map in this session.
printIdentityMaps() - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
PUBLIC: Used to print all the Objects in every identity map in this session.
printInnerJoinInWhereClause - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allow configuration option to use Where clause joining or From clause joining.
printInnerJoinInWhereClause - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
Indicates whether the query printer/normalizer changes the way that inner joins are printed in generated SQL for the database.
printInnerJoinInWhereClause() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Indicates whether the query will change the way that inner joins are printed in generated SQL for the database.
printInOutputArgument(FieldDefinition, Writer, AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
Print the argument and its type.
printJava(Object) - Method in class org.eclipse.persistence.internal.expressions.ExpressionJavaPrinter
 
printJava(ExpressionJavaPrinter) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Print java for project class generation
printJava(ExpressionJavaPrinter) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Print java
printJava(ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: Print java for project class generation
printJava(ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: Print java for project class generation
printJava(ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: Print java for project class generation
printJava(ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Print java for project class generation
printJava(ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Print java for project class generation
printJava(ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Print java for project class generation
printJava(ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
INTERNAL: Print java for project class generation
printJava(ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
INTERNAL: Print java for project class generation
printJavaCollection(List<Expression>, ExpressionJavaPrinter) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Print the collection onto the SQL stream.
printJavaCollection(List<Expression>, ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
 
printJavaDuo(Expression, Expression, ExpressionJavaPrinter) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: For performance, special case printing two children, since it's by far the most common
printJavaDuo(Expression, Expression, ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
 
printList(Collection<Object>, Boolean) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
printLocks() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Used to print all the Locks in every identity map in this session.
printLocks(Class<?>) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Used to print all the Locks in the specified identity map in this session.
printMinuteJava(Expression, Expression, ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for MINUTE (<date-time-part> argument.
printMinuteSQL(Expression, Expression, ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for MINUTE (<date-time-part> argument.
printMonthJava(Expression, Expression, ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for MONTH (<date-time-part> argument.
printMonthSQL(Expression, Expression, ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for MONTH (<date-time-part> argument.
printNull(ConstantExpression) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
printObjectsInIdentityMap(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will log the objects in the Identity Map.
printObjectsInIdentityMap(String) - Method in class org.eclipse.persistence.services.RuntimeServices
This method will log the objects in the Identity Map.
printObjectsInIdentityMaps() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method will log all objects in all Identity Maps in the session.
printObjectsInIdentityMaps() - Method in class org.eclipse.persistence.services.RuntimeServices
This method will log all objects in all Identity Maps in the session.
printOnClause(Expression, ExpressionSQLPrinter, DatabasePlatform) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Print the outer join ON clause.
printOuterJoinInWhereClause - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allow configuration option to use Where clause outer joining or From clause joining.
printOutputArgument(FieldDefinition, Writer, AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
Print the argument and its type.
printParameter(ParameterExpression) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
printParameter(DatabaseField) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
printPrefixString(int, String) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
Print the prefix string representing EclipseLink logging
printPrimitive(Object, Boolean) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
printProfileSummary() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method assumes EclipseLink Profiling (as opposed to Java profiling).
printProfileSummary() - Method in class org.eclipse.persistence.services.RuntimeServices
This method assumes EclipseLink Profiling (as opposed to Java profiling).
printProfileSummaryByClass() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method assumes EclipseLink Profiling (as opposed to Java profiling).
printProfileSummaryByClass() - Method in class org.eclipse.persistence.services.RuntimeServices
This method assumes EclipseLink Profiling (as opposed to Java profiling).
printProfileSummaryByQuery() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method assumes EclipseLink Profiling (as opposed to Java profiling).
printProfileSummaryByQuery() - Method in class org.eclipse.persistence.services.RuntimeServices
This method assumes EclipseLink Profiling (as opposed to Java profiling).
printQuarterJava(Expression, Expression, ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for QUARTER (<date-time-part> argument.
printQuarterSQL(Expression, Expression, ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for QUARTER (<date-time-part> argument.
printRegisteredObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Print the objects in the unit of work.
printRegisteredObjects() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Print the objects in the unit of work.
printReturn(Writer, AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.StoredFunctionDefinition
Prints return for stored function
printReturn(Writer, AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
Prints return for stored function, nothing to do for stored procedure
printsAs(String) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Set the single string for this operator.
printsAs(List<String>) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Set the strings for this operator.
printSecondJava(Expression, Expression, ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for SECOND (<date-time-part> argument.
printSecondSQL(Expression, Expression, ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for SECOND (<date-time-part> argument.
printsJavaAs(String) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Set the single string for this operator.
printsJavaAs(List<String>) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Set the strings for this operator.
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Print SQL
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.history.AsOfClause
INTERNAL: Prints the as of clause for an expression inside of the FROM clause.
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.history.AsOfSCNClause
INTERNAL: Prints the as of clause for an expression inside of the FROM clause.
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.ArgumentListFunctionExpression
INTERNAL: Print SQL
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.CollectionExpression
 
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: Print SQL
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: Print SQL onto the stream, using the ExpressionPrinter for context
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL: Print SQL onto the stream, using the ExpressionPrinter for context
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.DateConstantExpression
INTERNAL: Print SQL onto the stream, using the ExpressionPrinter for context
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: Print SQL onto the stream, using the ExpressionPrinter for context
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Print SQL using the operator.
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
INTERNAL: Print SQL onto the stream, using the ExpressionPrinter for context
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Print SQL onto the stream, using the ExpressionPrinter for context
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Print SQL onto the stream, using the ExpressionPrinter for context
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
INTERNAL: Print SQL
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Print the SQL representation of the statement on a stream.
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SubSelectDatabaseTable
Print the table's SQL from clause.
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
Print the sub query to the printer.
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
printSQL(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Print the table's SQL from clause.
printSQL(ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.ForUpdateClause
INTERNAL: Prints the as of clause for an expression inside of the FROM clause.
printSQL(ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.ForUpdateOfClause
INTERNAL: Prints the as of clause for an expression inside of the FROM clause.
printSQLForUpdateClause(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
printSQLGroupByClause(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
printSQLHavingClause(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
printSQLHierarchicalQueryClause(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
printSQLNoParens(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
INTERNAL: Print SQL without adding parentheses (for DB2 outer joins).
printSQLOrderByClause(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
printSQLSelect(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
printSQLSelectStatement(DatabaseCall, ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Print the SQL representation of the statement on a stream, storing the fields in the DatabaseCall.
printSQLSelectStatement(DatabaseCall, ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Print the SQL representation of the statement on a stream, storing the fields in the DatabaseCall.
printSQLSelectStatement(DatabaseCall, ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL: Print the SQL representation of the statement on a stream, storing the fields in the DatabaseCall.
printSQLSelectStatement(DatabaseCall, ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
Print the pagination SQL using FB syntax " ROWS <max> TO <first>".
printSQLSelectStatement(DatabaseCall, ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.platform.database.H2Platform
Print the pagination SQL using H2 syntax " LIMIT <max> OFFSET <first>".
printSQLSelectStatement(DatabaseCall, ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
printSQLSelectStatement(DatabaseCall, ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
Print the pagination SQL using HSQL syntax "SELECT LIMIT <first> <max>".
printSQLSelectStatement(DatabaseCall, ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
 
printSQLSelectStatement(DatabaseCall, ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Print the SQL representation of the statement on a stream, storing the fields in the DatabaseCall.
printSQLSelectStatement(DatabaseCall, ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
Print the pagination SQL using Postgres syntax " LIMIT <max> OFFSET <first>".
printSQLSelectStatement(DatabaseCall, ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
 
printSQLSelectStatement(DatabaseCall, ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Print the pagination SQL using Symfoware syntax " WITH OPTION LIMIT ( <max>)".
printSQLUnionClause(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
printSQLWhereClause(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
printSQLWhereKeyWord(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
printStackTrace() - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
PUBLIC: Print both the normal and internal stack traces.
printStackTrace() - Method in exception org.eclipse.persistence.exceptions.IntegrityException
PUBLIC: Print both the normal and internal stack traces.
printStackTrace(PrintStream) - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
PUBLIC: Print both the normal and internal stack traces.
printStackTrace(PrintStream) - Method in exception org.eclipse.persistence.exceptions.IntegrityException
PUBLIC: Print both the normal and internal stack traces.
printStackTrace(PrintWriter) - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
PUBLIC: Print both the normal and internal stack traces.
printStackTrace(PrintWriter) - Method in exception org.eclipse.persistence.exceptions.IntegrityException
PUBLIC: Print both the normal and internal stack traces.
printStackTrace(PrintWriter) - Method in exception org.eclipse.persistence.exceptions.SessionLoaderException
PUBLIC: Iterate through the exception list printing out the stack traces.
printStackTraceToString(Throwable) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return a String containing the printed stacktrace of an exception.
printStoredFunctionReturnKeyWord(Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Prints return keyword for StoredFunctionDefinition: CREATE FUNCTION StoredFunction_In (P_IN BIGINT) RETURN BIGINT The method was introduced because MySQL requires "RETURNS" instead: CREATE FUNCTION StoredFunction_In (P_IN BIGINT) RETURNS BIGINT
printStoredFunctionReturnKeyWord(Writer) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Prints return keyword for StoredFunctionDefinition: CREATE FUNCTION StoredFunction_In (P_IN BIGINT) RETURN BIGINT The method was introduced because MySQL requires "RETURNS" instead: CREATE FUNCTION StoredFunction_In (P_IN BIGINT) RETURNS BIGINT
printString(Object) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
Return the printed version of the primitive value object.
printString(Object) - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
Return the printed version of the primitive value object.
printString(String) - Method in class org.eclipse.persistence.internal.expressions.ExpressionJavaPrinter
 
printString(String) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
printTime(Time) - Static method in class org.eclipse.persistence.internal.helper.Helper
Print the sql.Time.
printTime(Calendar) - Static method in class org.eclipse.persistence.internal.helper.Helper
Print the time part of the calendar.
printTime(Calendar, boolean) - Static method in class org.eclipse.persistence.internal.helper.Helper
Print the time part of the calendar.
printTimeFromMilliseconds(long) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
printTimestamp(Timestamp) - Static method in class org.eclipse.persistence.internal.helper.Helper
Print the sql.Timestamp.
printTimestampWithoutNanos(Timestamp) - Static method in class org.eclipse.persistence.internal.helper.Helper
Print the sql.Timestamp without the nanos portion.
printValuelist(int[], DatabaseCall, Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Print the int array on the writer.
printValuelist(Collection<?>, DatabaseCall, Writer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
printValuelist(Collection<Object>, Boolean) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
printVector(Vector<?>) - Static method in class org.eclipse.persistence.internal.helper.Helper
Given a Vector, print it, even if there is a null in it
printVersion() - Static method in class org.eclipse.persistence.Version
 
printWeekJava(Expression, Expression, ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for WEEK (<date-time-part> argument.
printWeekSQL(Expression, Expression, ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for WEEK (<date-time-part> argument.
printYearJava(Expression, Expression, ExpressionJavaPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for YEAR (<date-time-part> argument.
printYearSQL(Expression, Expression, ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.ExtractOperator
Printer for YEAR (<date-time-part> argument.
PRIVATE - Static variable in class org.eclipse.persistence.internal.codegen.AccessLevel
 
PrivateOwned - Annotation Type in org.eclipse.persistence.annotations
A PrivateOwned annotation is used to specify a relationship is privately owned.
privateOwnedCriteria - Variable in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
 
privateOwnedCriteria - Variable in class org.eclipse.persistence.mappings.OneToOneMapping
 
privateOwnedObjects - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Cache references of private owned objects for the removal of private owned orphans
privateOwnedRelationship() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Sets the reference object to be a private owned.
priviledgedExecuteNonSelectingCall(Call) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Execute the call on the database.
priviledgedExecuteSelectingCall(Call) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Execute the call on the database and return the result.
PrivilegedAccessHelper - Class in org.eclipse.persistence.internal.security
INTERNAL: Privileged Access Helper provides a utility so all calls that require privileged access can use the same code.
PrivilegedAccessHelper() - Constructor for class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
 
PrivilegedAccessHelper.CallableExceptionSupplier<E extends Exception> - Interface in org.eclipse.persistence.internal.security
INTERNAL Specific Exception supplier for PrivilegedAccessHelper.PrivilegedExceptionCallable.
PrivilegedAccessHelper.CallableThrowableSupplier<T extends Throwable> - Interface in org.eclipse.persistence.internal.security
INTERNAL Specific Throwable supplier for PrivilegedAccessHelper.PrivilegedExceptionCallable.
PrivilegedAccessHelper.PrivilegedCallable<T> - Interface in org.eclipse.persistence.internal.security
INTERNAL A task that returns a result and shall not throw an exception.
PrivilegedAccessHelper.PrivilegedExceptionCallable<T> - Interface in org.eclipse.persistence.internal.security
INTERNAL A task that returns a result and may throw an exception.
PrivilegedAccessHelper.PrivilegedExceptionConsumer - Interface in org.eclipse.persistence.internal.security
INTERNAL A task that does not return any result and may throw an exception.
privilegedAddDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: You cannot add descriptors to a remote session.
PrivilegedClassForName<T> - Class in org.eclipse.persistence.internal.security
 
PrivilegedClassForName(String) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedClassForName
 
PrivilegedClassForName(String, boolean, ClassLoader) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedClassForName
 
PrivilegedGetClassLoaderForClass - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetClassLoaderForClass(Class<?>) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetClassLoaderForClass
 
PrivilegedGetClassLoaderFromCurrentThread - Class in org.eclipse.persistence.internal.security
INTERNAL: Retrieve current Thread context ClassLoader with privileges enabled.
PrivilegedGetClassLoaderFromCurrentThread() - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetClassLoaderFromCurrentThread
INTERNAL: Creates an instance of current Thread context ClassLoader getter.
PrivilegedGetConstructorFor<T> - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetConstructorFor(Class<T>, Class<?>[], boolean) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetConstructorFor
 
PrivilegedGetContextClassLoader - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetContextClassLoader(Thread) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetContextClassLoader
 
PrivilegedGetDeclaredConstructorFor - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetDeclaredConstructorFor(Class<?>, Class<?>[], boolean) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetDeclaredConstructorFor
 
PrivilegedGetDeclaredField - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetDeclaredField(Class<?>, String, boolean) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetDeclaredField
 
PrivilegedGetDeclaredFields - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetDeclaredFields(Class<?>) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetDeclaredFields
 
PrivilegedGetDeclaredMethod - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetDeclaredMethod(Class<?>, String, Class<?>[]) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetDeclaredMethod
 
PrivilegedGetDeclaredMethods - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetDeclaredMethods(Class<?>) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetDeclaredMethods
 
PrivilegedGetField - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetField(Class<?>, String, boolean) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetField
 
PrivilegedGetFields - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetFields(Class<?>) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetFields
 
PrivilegedGetFieldType - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetFieldType(Field) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetFieldType
 
PrivilegedGetMethod - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetMethod(Class<?>, String, Class<?>[], boolean) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetMethod
 
PrivilegedGetMethod(Class<?>, String, Class<?>[], boolean, boolean) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetMethod
 
PrivilegedGetMethodParameterTypes - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetMethodParameterTypes(Method) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetMethodParameterTypes
 
PrivilegedGetMethodReturnType - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetMethodReturnType(Method) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetMethodReturnType
 
PrivilegedGetMethods - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetMethods(Class<?>) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetMethods
 
PrivilegedGetSystemProperty - Class in org.eclipse.persistence.internal.security
INTERNAL: Retrieve System property with privileges enabled.
PrivilegedGetSystemProperty(String) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetSystemProperty
INTERNAL: Creates an instance of System property getter with privileges enabled.
PrivilegedGetSystemProperty(String, String) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetSystemProperty
INTERNAL: Creates an instance of System property getter with privileges enabled.
PrivilegedGetThreadInfo - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetThreadInfo(int) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetThreadInfo
 
PrivilegedGetThreadInfo(long[], int) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetThreadInfo
 
PrivilegedGetValueFromField - Class in org.eclipse.persistence.internal.security
 
PrivilegedGetValueFromField(Field, Object) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedGetValueFromField
 
PrivilegedInvokeConstructor<T> - Class in org.eclipse.persistence.internal.security
 
PrivilegedInvokeConstructor(Constructor<T>, Object[]) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedInvokeConstructor
 
PrivilegedMethodInvoker<T> - Class in org.eclipse.persistence.internal.security
 
PrivilegedMethodInvoker(Method, Object) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedMethodInvoker
 
PrivilegedMethodInvoker(Method, Object, Object[]) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedMethodInvoker
 
PrivilegedNewInstanceFromClass<T> - Class in org.eclipse.persistence.internal.security
 
PrivilegedNewInstanceFromClass(Class<T>) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedNewInstanceFromClass
 
privilegedSetValue(T) - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Set the object.
PrivilegedSetValueInField - Class in org.eclipse.persistence.internal.security
 
PrivilegedSetValueInField(Field, Object, Object) - Constructor for class org.eclipse.persistence.internal.security.PrivilegedSetValueInField
 
procedureArgumentNames - Variable in class org.eclipse.persistence.queries.StoredProcedureCall
 
procedureName - Variable in class org.eclipse.persistence.queries.StoredProcedureCall
 
procedureName() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredProcedureQuery
(Required) The name of the stored procedure.
procedureName() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredProcedureQuery
(Required) The name of the stored procedure.
procedures - Variable in class org.eclipse.persistence.tools.schemaframework.PackageDefinition
 
process(boolean) - Method in class org.eclipse.persistence.internal.expressions.OuterJoinExpressionHolder
 
process(boolean, boolean) - Method in class org.eclipse.persistence.internal.expressions.OuterJoinExpressionHolder
 
processAdditionalLocalExpressions(Expression, boolean) - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
INTERNAL This will return the localExpression if isLogicalExpression is false, otherwise it will check the addAdditionalExpressionsWithinCurrrentExpressionContext flag and clear additionalLocalExpression once adding it to the localExpression.
processAdditionalTablePkFields(ClassDescriptor) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
 
processAdditionalWritableMapKeyFields(AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: This method is used to check the key mapping to ensure that it does not write to a field that is written by another mapping.
processAdditionalWritableMapKeyFields(AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: This method is used to check the key mapping to ensure that it does not write to a field that is written by another mapping.
processAnyMapping(Sequence, boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Adds an Any to a given sequence.
processChild(XPathFragment, UnmarshalRecord, Attributes, Descriptor, Mapping) - Method in class org.eclipse.persistence.internal.oxm.XMLRelationshipMappingNodeValue
 
processChoiceMapping(Map<Field, Class<?>>, List<XMLChoiceFieldToClassAssociation>, Sequence, ComplexType, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties, List<Descriptor>, boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Process a given XMLChoiceMapping.
processCommand(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: RemoteCommandManager method.
processCommand(Object) - Method in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
PUBLIC: Invoked by the CommandManager after it has received a Command object and has converted it to the application command format.
processCommand(RemoteCommand) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
ADVANCED: This method will send the command to the remote session for processing
processCommand(RemoteCommand) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
ADVANCED: This method will send the command to the remote session for processing
processCommand(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
INTERNAL: This method is intended to be used by by sessions that wish to execute a command on a remote session
processCommand(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
INTERNAL: This method is intended to be used by by sessions that wish to execute a command on a remote session
processCommand(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
INTERNAL: This method is intended to be used by by sessions that wish to execute a command on a remote session
processCommandFromRemoteConnection(byte[]) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
INTERNAL: Deserialize the command and execute it.
processCommandFromRemoteConnection(Command) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
INTERNAL: Delegate to command processor
processCommandsConfig(CommandsConfig, RemoteCommandManager) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
processConnectionPolicyConfig(ConnectionPolicyConfig, ServerSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Process the common elements from a ConnectionPoolConfig
processConnectionPoolConfig(ConnectionPoolConfig, ConnectionPool, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Process the common elements from a ConnectionPoolConfig
processDatabaseSessionConfig(DatabaseSessionConfig, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL Process a DatabaseSessionConfig object.
processDataResults(AbstractRecord, Cursor, boolean) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Process the data-results for joined data for a 1-m join.
processDataResults(AbstractSession) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Process the data-results for joined data for a 1-m join.
processDeleteObjectQuery(DeleteObjectQuery) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This method is used to process delete queries that pass through the unitOfWork It is extracted out of the internalExecuteQuery method to reduce duplication
processDescriptor(Descriptor, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties, List<Descriptor>) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Process a given descriptor.
processDescriptorEventHolders(AbstractSession, ClassLoader) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: This method was added to allow JPA project caching so that DescriptorEventListeners could be serialized and re-added to the EventManager using a SerializableDescriptorEventHolder.
processDiscoveryConfig(DiscoveryConfig, DiscoveryManager) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
processEnumeration(String, XPathFragment, DirectMapping, Sequence, ComplexType, Schema, CoreConverter) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Process information contained within an EnumTypeConverter.
processEvents() - Method in class org.eclipse.persistence.internal.descriptors.changetracking.ObjectChangeListener
INTERNAL: This method will set this listener to ignore events not issues by EclipseLink
processExceptionForCommError(AbstractSession, SQLException, Call) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
This method is used to process an SQL exception and determine if the exception should be passed on for further processing.
processingInstruction(String, String) - Method in class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmappedContentHandlerWrapper
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.internal.oxm.unmapped.DefaultUnmappedContentHandler
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryAttachmentHandler
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
processingInstruction(String, String) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
processItem(ReportQuery, AbstractRecord, Vector, ReportItem) - Method in class org.eclipse.persistence.queries.ReportQueryResult
INTERNAL: Return a value from an item and database row (converted from raw field values using the mapping).
processJMSMessage(Message, AbstractSession) - Static method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingHelper
PUBLIC: Processes the received RCM messaged from a JMS provider for cache coordination.
processJMSTransportManagerConfig(JMSPublishingTransportManagerConfig, JMSPublishingTransportManager) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Common JMS configuration
processJNDINamingServiceConfig(JNDINamingServiceConfig, TransportManager) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
processJoinedMappings(AbstractSession) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
This method collects the Joined Mappings from the descriptor and initializes them.
processJPAQueries() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Process the JPA named queries into EclipseLink Session queries.
processJPAQuery(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Process the JPA named query into an EclipseLink Session query.
processLogConfig(LogConfig, SessionLog) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
processLoginConfig(LoginConfig, DatasourceLogin) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Process the common elements of a Login.
processMapping(CoreMapping, Sequence, ComplexType, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties, List<Descriptor>) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Process a given mapping.
processNamespaceResolverForXSIPrefix(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
INTERNAL: Private function to process or create an entry in the NamespaceResolver for the xsi prefix.
processNamespaceResolverForXSIPrefix(NamespaceResolver, MarshalRecord) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
INTERNAL: Private function to process or create an entry in the NamespaceResolver for the xsi prefix.
Processor - Interface in org.eclipse.persistence.internal.cache
Processor for computable tasks.
PROCESSOR - org.eclipse.persistence.logging.LogCategory
 
PROCESSOR - Static variable in interface org.eclipse.persistence.logging.SessionLog
ModelGen logging name space.
processParentNamespaces(Element) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
Process namespace declarations on parent elements if not the root.
processParentNamespaces(Element) - Method in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
Process namespace declarations on parent elements if not the root.
processPoolsConfig(PoolsConfig, ServerSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Process the PoolsConfig object.
processReceivedObject(Object, String) - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: Process the object extracted from the received message.
processReferenceDescriptor(Element, Descriptor, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties, List<Descriptor>, Field, boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
 
processResultSet(ResultSet, DatabaseCall, Statement, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Fetch all the rows from the result set.
processRMIRegistryNamingServiceConfig(RMIRegistryNamingServiceConfig, TransportManager) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
processSequenceConnectionPoolConfig(ConnectionPoolConfig, ServerSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Process a SequenceConnectionPoolConfig object.
processSequenceDefinition(SequenceDefinition, boolean, boolean, boolean, Set<String>, Set<String>) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Method creates database tables/objects.
processSequenceDefinitions(boolean, boolean, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Common implementor for createSequence and replaceSequence, distinguishes between sequence tables and sequence objects
processServerPlatformConfig(ServerPlatformConfig, ServerPlatform) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Process a ServerPlatformConfig object.
processSessionConfig(SessionConfig, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Process the common elements from a SessionConfig.
processSessionCustomizer(SessionConfig, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL: Process the user inputed session customizer class.
processSessionEventManagerConfig(SessionEventManagerConfig, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
processStructConverterConfig(StructConverterConfig, DatabaseLogin) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
processTransportManagerConfig(TransportManagerConfig, TransportManager) - Method in class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
processValueFromRecordForMapping(ClassDescriptor, String[], int) - Method in class org.eclipse.persistence.queries.EntityResult
INTERNAL: This method is for processing a single FieldResult, returning the DatabaseField it refers to.
processXMLBinaryDataCollectionMapping(BinaryDataCollectionMapping, Sequence, ComplexType, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Process a given XMLBinaryDataCollectionMapping.
processXMLBinaryDataMapping(BinaryDataMapping, Sequence, ComplexType, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Process a given XMLBinaryDataMapping.
processXMLChoiceCollectionMapping(ChoiceCollectionMapping, Sequence, ComplexType, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties, List<Descriptor>) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Process a given XMLChoiceCollectionMapping.
processXMLChoiceObjectMapping(ChoiceObjectMapping, Sequence, ComplexType, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties, List<Descriptor>) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
 
processXMLCompositeDirectCollectionMapping(DirectCollectionMapping, Sequence, ComplexType, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Process a given XMLCompositeDirectCollectionMapping.
processXMLCompositeMapping(CompositeObjectMapping, Sequence, ComplexType, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties, List<Descriptor>, boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Process a given XML composite mapping - either an XMLCompositeObjectMapping, or an XMLCompositeCollectionMapping.
processXMLDirectMapping(DirectMapping, Sequence, ComplexType, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Process a given XMLDirectMapping.
processXMLObjectReferenceMapping(ObjectReferenceMapping, Sequence, ComplexType, HashMap<String, Schema>, Schema, SchemaModelGeneratorProperties, List<Descriptor>, boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
Process a given XMLObjectReferenceMapping.
Profile - Class in org.eclipse.persistence.tools.profiler
Purpose: Any information stored for a profile operation.
Profile() - Constructor for class org.eclipse.persistence.tools.profiler.Profile
 
profileExecutionOfQuery(DatabaseQuery, DataRecord, AbstractSession) - Method in interface org.eclipse.persistence.sessions.SessionProfiler
INTERNAL: Finish a profile operation if profiling.
profileExecutionOfQuery(DatabaseQuery, DataRecord, AbstractSession) - Method in class org.eclipse.persistence.sessions.SessionProfilerAdapter
INTERNAL: Finish a profile operation if profiling.
profileExecutionOfQuery(DatabaseQuery, DataRecord, AbstractSession) - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
INTERNAL: Monitoring is done on the endOperation only.
profileExecutionOfQuery(DatabaseQuery, DataRecord, AbstractSession) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
INTERNAL: Finish a profile operation if profiling.
profiler - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Tool that log performance information.
PROFILER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.profiler" property configures the type of profiler used to capture runtime statistics.
ProfilerType - Class in org.eclipse.persistence.config
Profiler type persistence property values.
ProfilerType() - Constructor for class org.eclipse.persistence.config.ProfilerType
 
profiles - Variable in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
profileTime - Variable in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
profileTime - Variable in class org.eclipse.persistence.tools.profiler.Profile
 
profileWeight - Variable in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
PROHIBITED - Static variable in class org.eclipse.persistence.internal.oxm.schema.model.Attribute
 
project - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
The project stores configuration information, such as the descriptors and login.
project - Variable in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
project - Static variable in class org.eclipse.persistence.sessions.factories.XMLProjectReader
Cache the creation and initialization of the EclipseLink XML mapping project.
project - Static variable in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
Cache the creation and initialization of the Session XML mapping project.
Project - Class in org.eclipse.persistence.sessions
Purpose: Maintain all of the EclipseLink configuration information for a system.
Project() - Constructor for class org.eclipse.persistence.sessions.Project
PUBLIC: Create a new project.
Project(DatabaseLogin) - Constructor for class org.eclipse.persistence.sessions.Project
PUBLIC: Create a new project that will connect through JDBC using the login information.
Project(Login) - Constructor for class org.eclipse.persistence.sessions.Project
PUBLIC: Create a new project that will connect through the login information.
PROJECT_AMENDMENT_EXCEPTION_OCCURED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
PROJECT_CACHE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.project-cache" property configures the type of org.eclipse.persistence.jpa.metadata.ProjectCache implementation to use to retrieve and store projects representing the metadata for the project.
PROJECT_CACHE_FILE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The property "eclipselink.project-cache.java-serialization.file" specifies the name of the file to read/write a serialized project representing the application's metadata
PROJECT_LOGIN_IS_NULL - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
PROJECT_XML_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ProjectClassConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.project
INTERNAL:
ProjectClassConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.project.ProjectClassConfig
 
ProjectClassGenerator - Class in org.eclipse.persistence.sessions.factories
Purpose: Allow for a class storing a TopLink project's descriptors (meta-data) to be generated.
ProjectClassGenerator() - Constructor for class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Create a new generator.
ProjectClassGenerator(Project) - Constructor for class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Create a new generator to output the project.
ProjectClassGenerator(Project, String, Writer) - Constructor for class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Create a new generator to output to the writer.
ProjectClassGenerator(Project, String, String) - Constructor for class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Create a new generator to output to the file.
ProjectConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.project
INTERNAL:
ProjectConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.project.ProjectConfig
 
projectLoginIsNull(AbstractSession) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
ProjectXMLConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.project
INTERNAL:
ProjectXMLConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.project.ProjectXMLConfig
 
projectXMLNotFound(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
promptForDestinationDirectory() - Method in class org.eclipse.persistence.tools.PackageRenamer
INTERNAL Prompt from System.in for an empty or non-existent directory to use as the destination directory.
PROP_NOT_SET - Static variable in exception org.eclipse.persistence.eis.EISException
 
propagateCommand(Object) - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
ADVANCED: Propagate a remote command to all remote RCM services participating in the EclipseLink cluster.
propagateCommand(Object) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
ADVANCED: Propagate a remote command to all remote RCM services participating in the EclipseLink cluster.
propagateCommand(RemoteConnection) - Method in class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
INTERNAL: Propagate the command to the specified connection.
propagatesEventsToCollection() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Returns false.
propagatesEventsToCollection() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Returns true if the key mapping is an AggregateObjectMapping.
PROPAGATION - org.eclipse.persistence.logging.LogCategory
 
PROPAGATION - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
properties - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
Additional properties may be added.
properties - Variable in class org.eclipse.persistence.eis.interactions.EISInteraction
Adapter specific properties may be added.
properties - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Allow for user defined properties.
properties - Variable in class org.eclipse.persistence.internal.sessions.coordination.MetadataRefreshCommand
 
properties - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
Allow user defined properties.
properties - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Internally used by the mappings as a temporary store.
properties - Variable in class org.eclipse.persistence.sessions.DatasourceLogin
Connection properties (e.g.
properties - Variable in class org.eclipse.persistence.sessions.server.ConnectionPolicy
This attribute will provide a mechanism by which customers will be able to pass connection information to events to enable further customization.
properties - Variable in class org.eclipse.persistence.sessions.SessionEvent
Additional properties may be added.
Properties - Annotation Type in org.eclipse.persistence.annotations
Annotation for user defined properties.
PROPERTIES - org.eclipse.persistence.logging.LogCategory
 
PROPERTIES - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
PROPERTIES_MANAGER_FIELD - Static variable in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
All DynamicEntity classes have a public static field 'DPM' of type DynamicPropertiesManager
PropertiesHandler - Class in org.eclipse.persistence.internal.sessions
The class processes some of EclipseLink properties.
PropertiesHandler() - Constructor for class org.eclipse.persistence.internal.sessions.PropertiesHandler
 
PropertiesHandler.BatchWritingProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.BooleanProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.CacheSizeProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.CacheTypeProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.CommitOrderProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.ConnectionPoolProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.DescriptorCustomizerProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.ExclusiveConnectionModeProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.FlushClearCacheProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.FlushModeProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.IdValidationProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.JTACntrlrProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.LoggerTypeProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.LoggingLevelProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.PessimisticLockTimeoutUnitProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.Prop - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.QueryTimeoutUnitProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.ReferenceModeProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.TargetDatabaseProp - Class in org.eclipse.persistence.internal.sessions
 
PropertiesHandler.TargetServerProp - Class in org.eclipse.persistence.internal.sessions
 
propertiesMap - Variable in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
propertiesNotSet(String, String) - Static method in exception org.eclipse.persistence.eis.EISException
 
PropertiesUtils - Class in org.eclipse.persistence.config
A static utility class that handles parsing a String "key=value,key1=value1...." and calls an appropriate set[key]([value]) method on the provided instance.
PropertiesUtils() - Constructor for class org.eclipse.persistence.config.PropertiesUtils
 
Property - Annotation Type in org.eclipse.persistence.annotations
Annotation for a user defined property.
PROPERTY_LOG_OVERRIDES - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
INTERNAL: The following properties will not be displayed through logging but instead have an alternate value shown in the log.
PROPERTY_NOT_FOUND_AT_INDEX - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
PropertyAssociation - Class in org.eclipse.persistence.mappings
Purpose: Generic association object.
PropertyAssociation() - Constructor for class org.eclipse.persistence.mappings.PropertyAssociation
Default constructor.
PropertyAssociation(Object, Object) - Constructor for class org.eclipse.persistence.mappings.PropertyAssociation
 
propertyChange(PropertyChangeEvent) - Method in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
PUBLIC: This method creates the object change set if necessary.
propertyChange(PropertyChangeEvent) - Method in class org.eclipse.persistence.internal.descriptors.changetracking.ObjectChangeListener
PUBLIC: This method turns marks the object as changed.
PropertyChangeEvent_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
PropertyConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.property
INTERNAL:
PropertyConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.property.PropertyConfig
 
propertyNotFoundAtIndex(Exception, int) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when trying to find a property at an invalid index
propertyNotSet(String) - Static method in exception org.eclipse.persistence.eis.EISException
 
propertyOrFieldCannotBeXmlValue(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
propertyOrFieldShouldBeAnAttribute(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
propertyTypeAnnotationTargetCannotBeDataTypeTrue(String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when trying to resolve an sdo xml [propertyType] annotation on a target Type of dataType==true.
See Sect 9.2 (1) of the SDO Specification.
PropertyWrapper() - Constructor for class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl.PropertyWrapper
Instantiates a new property wrapper.
PropertyWrapper(Object) - Constructor for class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl.PropertyWrapper
Instantiates a new property wrapper.
propMap - Variable in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGeneratorProperties
 
propogatePostDelete(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Propagate the postDeleteEvent to any additional objects the query is aware of This method will be overridden by subclasses that deal MapKeys
propogatePostDelete(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Propagate the postDeleteEvent to any additional objects the query is aware of
propogatePostInsert(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Propagate the postDeleteEvent to any additional objects the query is aware of This method will be overridden by subclasses that deal MapKeys
propogatePostInsert(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Propagate the postDeleteEvent to any additional objects the query is aware of
propogatePostUpdate(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Propagate the postDeleteEvent to any additional objects the query is aware of This method will be overridden by subclasses that deal MapKeys
propogatePostUpdate(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Propagate the postDeleteEvent to any additional objects the query is aware of
propogatePreDelete(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Propagate the postDeleteEvent to any additional objects the query is aware of This method will be overridden by subclasses that deal MapKeys
propogatePreDelete(DeleteObjectQuery, Object) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Propagate the postDeleteEvent to any additional objects the query is aware of
propogatePreInsert(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Propagate the postDeleteEvent to any additional objects the query is aware of This method will be overridden by subclasses that deal MapKeys
propogatePreInsert(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Propagate the postDeleteEvent to any additional objects the query is aware of
propogatePreUpdate(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Propagate the postDeleteEvent to any additional objects the query is aware of This method will be overridden by subclasses that deal MapKeys
propogatePreUpdate(WriteObjectQuery, Object) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Propagate the postDeleteEvent to any additional objects the query is aware of
PROPS_NOT_SET - Static variable in exception org.eclipse.persistence.eis.EISException
 
PROTECTED - org.eclipse.persistence.config.CacheIsolationType
Entity state information will be cached in the shared cache but Entity instances will not be shared.
PROTECTED - Static variable in class org.eclipse.persistence.internal.codegen.AccessLevel
 
protectedForeignKeys - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
Stores retrieved FK values for relationships that are not stored in the Entity
protectedForeignKeys - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
ProtectedValueHolder<T> - Class in org.eclipse.persistence.internal.indirection
Purpose: provides a value holder type that can be used in Protected instances of Entities.
ProtectedValueHolder(ValueHolderInterface<T>, DatabaseMapping, AbstractSession) - Constructor for class org.eclipse.persistence.internal.indirection.ProtectedValueHolder
 
PROVIDER_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.BeanValidationException
 
providerNotFound(String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.BeanValidationException
 
PROXY_INDIRECTION_NOT_AVAILABLE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
ProxyIndirectionHandler<T> - Class in org.eclipse.persistence.internal.indirection
ProxyIndirectionHandler
ProxyIndirectionHandler() - Constructor for class org.eclipse.persistence.internal.indirection.ProxyIndirectionHandler
INTERNAL: Just in here to allow for Serialization.
proxyIndirectionNotAvailable(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
ProxyIndirectionPolicy - Class in org.eclipse.persistence.internal.indirection
ProxyIndirectionPolicy
ProxyIndirectionPolicy() - Constructor for class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
 
ProxyIndirectionPolicy(Class<?>[]) - Constructor for class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
 
PSHORT - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
PU_NOT_EXIST - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
PUBLIC - Static variable in class org.eclipse.persistence.internal.codegen.AccessLevel
 
PublicInterfaceDatabaseSession_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
PublicInterfaceSession_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
puNotExist(String) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
push(E) - Method in class org.eclipse.persistence.internal.oxm.record.MarshalRecord.CycleDetectionStack
 
push(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.StackUnmarshalNamespaceResolver
 
push(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceContext
The underlying NamespaceContext is responsible for maintaining the appropriate prefix/URI associations.
push(String, String) - Method in interface org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceResolver
Associate a prefix and a namespace URI.
pushAttributeGroup(CoreAttributeGroup) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
pushAttributeGroup(CoreAttributeGroup) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
put(FIELD, Object) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
put(FIELD, Object) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
put(Object, Object) - Method in class org.eclipse.persistence.internal.helper.ConcurrentFixedCache
Add the value to the cache.
put(Object, Object) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
put(Object, Object) - Method in interface org.eclipse.persistence.internal.oxm.record.TransformationRecord
 
put(Object, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Add the field-value pair to the row.
put(Object, Object) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
put(Object, Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult
ADVANCED: Set the value for given item name.
put(Object, Object, Object, long) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Store the object in the cache at its primary key.
put(Object, Object, Object, long) - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Store the object in the cache at its primary key.
put(Object, Object, Object, long) - Method in class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap
Store the object in the cache at its primary key, and add to sub-cache list.
put(Object, Object, Object, long) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Store the object in the cache at its primary key.
put(Object, Object, Object, long) - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Do Nothing.
put(Object, Object, Object, long) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Store the object in the cache at its primary key.
put(String, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Add the field-value pair to the row.
put(String, Object) - Method in class org.eclipse.persistence.internal.sessions.EmptyRecord
 
put(String, Object) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
PUBLIC: Add the field-value pair to the row.
put(String, String) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
Adds a namespace to the collection of namespaces on the NamespaceResolver
put(String, String) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
 
put(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.PrefixMapperNamespaceResolver
 
put(List<XMLField>, List<XMLEntry>) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
put(K, V) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
put(K, V) - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Associate the given object with the given key in this IdentityWeakHashMap, replacing any existing mapping.
put(CoreField, Object) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
INTERNAL: Add the field-value pair to the document.
put(CoreField, Object) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
put(DatabaseField, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: Add the field-value pair to the row.
put(DatabaseField, Object) - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
INTERNAL: Add the field-value pair to the row.
put(DatabaseField, Object) - Method in class org.eclipse.persistence.internal.sessions.EmptyRecord
 
put(DatabaseField, Object) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Set the field value into the DOM.
put(DatabaseTable, DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.TableAliasLookup
put method comment.
putAll(Map) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Add all of the elements.
putAll(Map) - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Add all of the elements.
putAll(Map<?, ?>) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
putAll(Map<? extends String, ? extends String>) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
 
putAll(Map<? extends K, ? extends V>) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Copies all of the mappings from the given map to this IdentityWeakHashMap, replacing any existing mappings.
putCachedExpressionQuery(DatabaseQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Set the cached SQL call for the expression query.
putCachedUpdateCalls(Vector, Vector) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Cache a clone of the update SQL calls based on the updated fields.
putCacheKeyByIndex(CacheIndex, CacheId, CacheKey, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Index the cache key by the index values.
putCacheKeyByIndex(CacheIndex, CacheId, CacheKey, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
Index the cache key by the index values.
putCacheKeyByIndex(CacheIndex, CacheId, CacheKey, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
Index the cache key by the index values.
putCacheKeyIfAbsent(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Return the CacheKey (with object) matching the searchKey.
putCacheKeyIfAbsent(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.CacheIdentityMap
Also insert the link if the cacheKey is put.
putCacheKeyIfAbsent(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Return the CacheKey (with object) matching the searchKey.
putCacheKeyIfAbsent(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Return null as no objects are cached.
putCacheKeyIfAbsent(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
Use hashmap put, as no concurrency in unit of work.
putCacheKeyIfAbsent(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.WeakIdentityMap
Need to check for cleanup on put.
putCacheKeyIfAbsent(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.WeakUnitOfWorkIdentityMap
Need to check for cleanup on put.
putDeferredLock(Thread, DeferredLockManager) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
putIfAbsent(String, String) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
 
putIfAbsent(K, V) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
putInIdentityMap(Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Register the object with the cache.
putInIdentityMap(Object) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Registers the given Object with the identity map.
putInIdentityMap(Object, Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Register the object with the cache.
putInIdentityMap(Object, Object) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Registers the Object and given key with the identity map.
putInIdentityMap(Object, Object, Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Register the object with the cache.
putInIdentityMap(Object, Object, Object) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Registers the Object and given key with the identity map.
putInIdentityMap(Object, Object, Object, long) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Register the object with the cache.
putInIdentityMap(Object, Object, Object, long) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Registers the given Object with the identity map.
putInIdentityMap(Object, Object, Object, long, ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Register the object with the identity map.
putInIdentityMap(Object, Object, Object, long, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Register the object with the cache.
putNewObjectInChangesList(ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Used to rehash the new objects back into the objectChanges list for serialization Assumes the transaction in in post commit stage.
putObjectIntoRow(AbstractRecord, Object, AbstractSession) - Method in interface org.eclipse.persistence.descriptors.SerializedObjectPolicy
Serialize the object and put the result into the row as a value corresponding to the policy field
putObjectIntoRow(AbstractRecord, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.SerializedObjectPolicyWrapper
 
putPrimary(String, String) - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolverWithPrefixes
 
putQueryResult(ReadQuery, List, Object) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Set the results for a query.
putQueryResult(ReadQuery, List, Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Set the results for a query.
putQueryResult(ReadQuery, List, Object) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Set the results for a query.
putQueryResult(ReadQuery, List, Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
INTERNAL: Set the results for a query.
putSecondary(String, String) - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolverWithPrefixes
 
putThreadAsWaitingToAcquireLockForReading(Thread, String) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
The thread is trying to acquire a read lock but it is not being able to make process on getting the read lock.
putThreadAsWaitingToAcquireLockForWriting(Thread, String) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Normally this mehtod should only be called from withing the concurrency manager.
putTypeNameInMap(String, Map<String, Set<String>>) - Static method in class org.eclipse.persistence.internal.codegen.CodeDefinition
Used for calculating imports.
putTypeNamesInMap(Map<String, Set<String>>) - Method in class org.eclipse.persistence.internal.codegen.AttributeDefinition
Used for calculating imports.
putTypeNamesInMap(Map<String, Set<String>>) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
Used for calculating imports.
putValue(Class<?>, Object, Object) - Method in class org.eclipse.persistence.internal.oxm.ReferenceResolver
Store an instance by key based on a mapped class.

Q

QNAME - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
QNAME_CLASS - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
QNAME_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
QNameInheritancePolicy - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
QNameInheritancePolicy() - Constructor for class org.eclipse.persistence.internal.oxm.QNameInheritancePolicy
 
QNameInheritancePolicy(ClassDescriptor) - Constructor for class org.eclipse.persistence.internal.oxm.QNameInheritancePolicy
 
QUALIFIED - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
qualifiedName - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
PERF: Cache fully qualified table.field-name.
qualifiedName - Variable in class org.eclipse.persistence.internal.helper.DatabaseTable
 
qualifier - Variable in class org.eclipse.persistence.sequencing.Sequence
 
qualifier - Variable in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
 
queries - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
queries - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Stores predefine reusable queries.
queries - Variable in class org.eclipse.persistence.sessions.Project
List of queries - once Project is initialized, these are copied to the Session.
query - Variable in class org.eclipse.persistence.descriptors.DescriptorEvent
The query causing the event.
query - Variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
query - Variable in exception org.eclipse.persistence.exceptions.OptimisticLockException
Store the query that raised the optimistic violation.
query - Variable in exception org.eclipse.persistence.exceptions.QueryException
 
query - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
query - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Query this statement is associated to (used for SQL query options).
query - Variable in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
Stores the query to be executed.
query - Variable in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
The database query that uses this mechanism.
query - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
 
query - Variable in class org.eclipse.persistence.internal.sessions.remote.Transporter
 
query - Variable in class org.eclipse.persistence.queries.Cursor
Read query that initialize the stream.
query - Variable in class org.eclipse.persistence.queries.CursorPolicy
 
query - Variable in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
Used to set the policy state in the query.
query - Variable in class org.eclipse.persistence.queries.JPQLCall
 
query - Variable in class org.eclipse.persistence.sessions.SessionEvent
Some events may have a query associated with them (pre/postExecuteQuery).
QUERY - org.eclipse.persistence.logging.LogCategory
 
QUERY - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
QUERY_ARGUMENT_TYPE_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
QUERY_BATCH_PARAMETER - Static variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Query parameter name used for IN batch ids.
QUERY_CACHE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
Property prefix "eclipselink.cache.query-results" used to configure the default option for query results caching.
QUERY_FETCHGROUP_NOT_DEFINED_IN_DESCRIPTOR - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
QUERY_HINT_CONTAINED_INVALID_INTEGER_VALUE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
QUERY_HINT_DID_NOT_CONTAIN_ENOUGH_TOKENS - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
QUERY_HINT_NAVIGATED_ILLEGAL_RELATIONSHIP - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
QUERY_HINT_NAVIGATED_NON_EXISTANT_RELATIONSHIP - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
QUERY_IS_TOO_COMPLEX_FOR_ORACLE_NOSQL_DB - Static variable in exception org.eclipse.persistence.eis.EISException
 
QUERY_NOT_DEFINED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
QUERY_REDIRECTOR - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.query.redirector"
QUERY_RESULTS_CACHE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.query-results-cache"
QUERY_RESULTS_CACHE_EXPIRY - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.query-results-cache.expiry"
QUERY_RESULTS_CACHE_EXPIRY_TIME_OF_DAY - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.query-results-cache.expiry-time-of-day"
QUERY_RESULTS_CACHE_IGNORE_NULL - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.query-results-cache.ignore-null"
QUERY_RESULTS_CACHE_INVALIDATE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.query-results-cache.invalidate-on-change"
QUERY_RESULTS_CACHE_RANDOMIZE_EXPIRY - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.query-results-cache.randomize-expiry"
QUERY_RESULTS_CACHE_SIZE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.query-results-cache.size"
QUERY_RESULTS_CACHE_TYPE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.query-results-cache.type"
QUERY_SENT_TO_INACTIVE_UNIT_OF_WORK - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
QUERY_SEQUENCE_DOES_NOT_HAVE_SELECT_QUERY - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
QUERY_TIMEOUT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.query.timeout" property configures the default query timeout value.
QUERY_TIMEOUT - Static variable in class org.eclipse.persistence.config.QueryHints
"jakarta.persistence.query.timeout"
QUERY_TIMEOUT_UNIT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.query.timeout.unit" property configures the query timeout unit value.
QUERY_TIMEOUT_UNIT - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.jdbc.timeout.unit"
QUERY_TYPE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.query-type"
QueryArgument - Class in org.eclipse.persistence.internal.descriptors
Purpose: Used to define the query argument mapping.
QueryArgument() - Constructor for class org.eclipse.persistence.internal.descriptors.QueryArgument
Default constructor.
QueryArgument(String, Object, Class<?>) - Constructor for class org.eclipse.persistence.internal.descriptors.QueryArgument
 
queryArguments - Variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
queryArguments - Variable in exception org.eclipse.persistence.exceptions.QueryException
 
queryArgumentTypeNotFound(DatabaseQuery, String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
QueryBasedValueHolder<T> - Class in org.eclipse.persistence.internal.indirection
QueryBasedValueHolder wraps a database-stored object and implements behavior to access it.
QueryBasedValueHolder() - Constructor for class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
 
QueryBasedValueHolder(ReadQuery, Object, AbstractRecord, AbstractSession) - Constructor for class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
Initialize the query-based value holder.
QueryBasedValueHolder(ReadQuery, AbstractRecord, AbstractSession) - Constructor for class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
Initialize the query-based value holder.
queryBuilder - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Store the query builder used to parse JPQL.
QueryByExampleMechanism - Class in org.eclipse.persistence.internal.queries
Purpose: Mechanism used for all queries by example.
QueryByExampleMechanism(DatabaseQuery) - Constructor for class org.eclipse.persistence.internal.queries.QueryByExampleMechanism
Initialize the state of the query
QueryByExampleMechanism(DatabaseQuery, Expression) - Constructor for class org.eclipse.persistence.internal.queries.QueryByExampleMechanism
Initialize the state of the query
queryByExamplePolicy - Variable in class org.eclipse.persistence.internal.queries.QueryByExampleMechanism
 
QueryByExamplePolicy - Class in org.eclipse.persistence.queries
Purpose: This policy defines the configuration options for a Query By Example query.
QueryByExamplePolicy() - Constructor for class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: Constructs a default policy equal to that used when no policy is specified.
queryCacheForceDeferredLocks - Variable in class org.eclipse.persistence.sessions.Project
Force all queries and relationships to use deferred lock strategy during object building and L2 cache population.
queryClass - Variable in class org.eclipse.persistence.expressions.ExpressionBuilder
 
queryClass - Variable in class org.eclipse.persistence.tools.profiler.Profile
 
QueryCounter - Class in org.eclipse.persistence.internal.helper
INTERNAL: This counter is used by the sessions to assign individual id's to all queries.
QueryCounter() - Constructor for class org.eclipse.persistence.internal.helper.QueryCounter
 
QueryException - Exception in org.eclipse.persistence.exceptions
Purpose: This exception is used for any problem that is detected with a query.
QueryException(String) - Constructor for exception org.eclipse.persistence.exceptions.QueryException
INTERNAL: Constructor.
QueryException(String, DatabaseQuery) - Constructor for exception org.eclipse.persistence.exceptions.QueryException
INTERNAL: Constructor.
QueryException(String, DatabaseQuery, Exception) - Constructor for exception org.eclipse.persistence.exceptions.QueryException
INTERNAL: Constructor.
QueryExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for QueryException messages.
QueryExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.QueryExceptionResource
Default constructor.
queryHintContainedInvalidIntegerValue(String, Object, Exception) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
queryHintDidNotContainEnoughTokens(DatabaseQuery, String, Object) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
queryHintNavigatedIllegalRelationship(DatabaseQuery, String, Object, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
queryHintNavigatedNonExistantRelationship(DatabaseQuery, String, Object, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
QueryHints - Class in org.eclipse.persistence.config
The class defines EclipseLink query hints.
queryId - Variable in class org.eclipse.persistence.queries.ReadQuery
 
queryIsTooComplexForOracleNoSQLDB(String) - Static method in exception org.eclipse.persistence.eis.EISException
 
queryKey - Variable in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
Cache the query key for performance.
QueryKey - Class in org.eclipse.persistence.mappings.querykeys
Purpose: Define a Java appropriate alias to a database field or function.
QueryKey() - Constructor for class org.eclipse.persistence.mappings.querykeys.QueryKey
Default constructor.
QueryKey_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
QueryKeyExpression - Class in org.eclipse.persistence.internal.expressions
Represents expression on query keys or mappings.
QueryKeyExpression() - Constructor for class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
QueryKeyExpression(String, Expression) - Constructor for class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
QueryKeyReference - Class in org.eclipse.persistence.internal.descriptors
Purpose: Used to define variable 1-1 mapping query key field references.
QueryKeyReference() - Constructor for class org.eclipse.persistence.internal.descriptors.QueryKeyReference
Default constructor.
QueryKeyReference(DatabaseField, String) - Constructor for class org.eclipse.persistence.internal.descriptors.QueryKeyReference
Create an association.
queryKeys - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
queryManager - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
queryMechanism - Variable in class org.eclipse.persistence.queries.DatabaseQuery
The query mechanism determines the mechanism on how the database will be accessed.
QueryMonitor - Class in org.eclipse.persistence.tools.profiler
Purpose: Provide a very simple low overhead means for measuring query executions, and cache hits.
QueryMonitor - Static variable in class org.eclipse.persistence.config.ProfilerType
 
QueryMonitor() - Constructor for class org.eclipse.persistence.tools.profiler.QueryMonitor
 
queryNotDefined() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
queryNotDefined(String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
queryNotDefined(String, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
queryParameter() - Method in annotation type org.eclipse.persistence.annotations.StoredProcedureParameter
(Required) The query parameter name.
queryParameter() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLParameter
(Optional) The query parameter name.
QueryPreparation - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
QueryRedirector - Interface in org.eclipse.persistence.queries
Purpose: Query redirection allows for a named or parameterized query (or finder) to dynamically determine how the query is to be executed based on the arguments.
QueryRedirectorHelper - Class in org.eclipse.persistence.queries
Purpose: The purpose of this class is to provide the query redirector with some helper methods for general EclipseLink operations (such as checking a query against the cache) which may not occur because the query is being redirected.
QueryRedirectors - Annotation Type in org.eclipse.persistence.annotations
Redirectors allow EclipseLink queries to be intercepted and pre/post processed or redirected.
queryResultCachingPolicy - Variable in class org.eclipse.persistence.queries.ReadQuery
Used to specify how query results are cached
queryResults - Variable in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
A table of identity maps with the key being the query
QueryResultsCachePolicy - Class in org.eclipse.persistence.queries
PUBLIC: A QueryResultsCache policy dictates how a query's results will be cached.
QueryResultsCachePolicy() - Constructor for class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Build a QueryResultsCachePolicy with the default settings By default there is no invalidation of query results and the maximum number of results sets is 100.
QueryResultsCachePolicy(int) - Constructor for class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Build a QueryResultsCachePolicy and supply a maximum for the number of results sets.
QueryResultsCachePolicy(CacheInvalidationPolicy) - Constructor for class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Build a QueryResultsCachePolicy and supply a CacheInvalidationPolicy.
QueryResultsCachePolicy(CacheInvalidationPolicy, int) - Constructor for class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Build a QueryResultsCachePolicy and supply a CacheInvalidationPolicy and a maximum number of results sets.
queryResultsInvalidationsByClass - Variable in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
A map of class to list of queries that need to be invalidated when that class changes.
queryRetryAttemptCount - Variable in class org.eclipse.persistence.sessions.DatabaseLogin
Stores the value for the number of time EclipseLink will attempt to reconnect the connection on a comm failure in the case EclipseLink is attempting to retry a query.
querySentToInactiveUnitOfWork(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
QuerySequence - Class in org.eclipse.persistence.sequencing
Purpose: An generic query sequence mechanism.
QuerySequence() - Constructor for class org.eclipse.persistence.sequencing.QuerySequence
 
QuerySequence(boolean, boolean) - Constructor for class org.eclipse.persistence.sequencing.QuerySequence
 
QuerySequence(String) - Constructor for class org.eclipse.persistence.sequencing.QuerySequence
Create a new sequence with the name.
QuerySequence(String, boolean, boolean) - Constructor for class org.eclipse.persistence.sequencing.QuerySequence
 
QuerySequence(String, int) - Constructor for class org.eclipse.persistence.sequencing.QuerySequence
Create a new sequence with the name and sequence pre-allocation size.
QuerySequence(String, int, boolean, boolean) - Constructor for class org.eclipse.persistence.sequencing.QuerySequence
 
QuerySequence(String, int, int) - Constructor for class org.eclipse.persistence.sequencing.QuerySequence
 
QuerySequence(String, int, int, boolean, boolean) - Constructor for class org.eclipse.persistence.sequencing.QuerySequence
 
querySequenceDoesNotHaveSelectQuery(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
queryString - Variable in class org.eclipse.persistence.eis.interactions.QueryStringInteraction
 
QueryStringCall - Interface in org.eclipse.persistence.internal.databaseaccess
INTERNAL: Purpose: Used to define query string calls.
QueryStringInteraction - Class in org.eclipse.persistence.eis.interactions
Defines the specification for a call to a JCA interaction that uses a query string.
QueryStringInteraction() - Constructor for class org.eclipse.persistence.eis.interactions.QueryStringInteraction
Default constructor.
QueryStringInteraction(String) - Constructor for class org.eclipse.persistence.eis.interactions.QueryStringInteraction
Construct interaction with the query string.
queryTimeout - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
queryTimeout - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
queryTimeout - Variable in class org.eclipse.persistence.queries.DatabaseQuery
queryTimeout has three possible settings: DefaultTimeout, NoTimeout, and 1..N This applies to both DatabaseQuery.queryTimeout and DescriptorQueryManager.queryTimeout DatabaseQuery.queryTimeout: - DefaultTimeout: get queryTimeout from DescriptorQueryManager - NoTimeout, 1..N: overrides queryTimeout in DescriptorQueryManager DescriptorQueryManager.queryTimeout: - DefaultTimeout: get queryTimeout from parent DescriptorQueryManager.
queryTimeoutCache - Variable in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
INTERNAL: This variable is used to temporarily cache the largest queryTimeout among a batch of queries for a particular mechanism.
queryTimeoutDefault - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
 
queryTimeoutUnit - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
queryTimeoutUnit - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
queryTimeoutUnit - Variable in class org.eclipse.persistence.queries.DatabaseQuery
 
queryTimeoutUnitDefault - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
 
QueryType - Class in org.eclipse.persistence.config
Query type hint values.
QueryType() - Constructor for class org.eclipse.persistence.config.QueryType
 
QUESTION_MARK - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
Vertical bar.
QueueableWeakCacheKey - Class in org.eclipse.persistence.internal.identitymaps
 
QueueableWeakCacheKey(Object, Object, Object, long, ReferenceQueue, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
 
queueNode - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
Stores the node that holds this mergemanager within the WriteLocksManager queue
QUOT - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 

R

raiseAddChangeEvent(E, Integer) - Method in class org.eclipse.persistence.indirection.IndirectList
Raise the add change event and relationship maintenance.
raiseAddChangeEvent(E, Integer, boolean) - Method in class org.eclipse.persistence.indirection.IndirectList
 
raiseAddChangeEvent(Object) - Method in class org.eclipse.persistence.indirection.IndirectSet
Raise the add change event and relationship maintainence.
raiseAddChangeEvent(Object, Object) - Method in class org.eclipse.persistence.indirection.IndirectMap
Raise the add change event and relationship maintainence.
raiseInternalPropertyChangeEvent(Object, String, Object, Object) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: This may cause a property change event to be raised to a listener in the case that a listener exists.
raiseInternalPropertyChangeEvent(Object, String, Object, Object) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: This may cause a property change event to be raised to a listener in the case that a listener exists.
raiseInternalPropertyChangeEvent(Object, String, Object, Object) - Method in class org.eclipse.persistence.descriptors.changetracking.ObjectChangeTrackingPolicy
INTERNAL: This may cause a property change event to be raised to a listner in the case that a listener exists.
raiseRemoveChangeEvent(Object) - Method in class org.eclipse.persistence.indirection.IndirectSet
Raise the remove change event.
raiseRemoveChangeEvent(Object, Integer) - Method in class org.eclipse.persistence.indirection.IndirectList
Raise the remove change event.
raiseRemoveChangeEvent(Object, Integer, boolean) - Method in class org.eclipse.persistence.indirection.IndirectList
 
raiseRemoveChangeEvent(Object, Object) - Method in class org.eclipse.persistence.indirection.IndirectMap
Raise the remove change event.
random - Variable in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
Random used for randomized invalidation.
RangePartition - Class in org.eclipse.persistence.descriptors.partitioning
PUBLIC: Represent a specific range partition.
RangePartition - Annotation Type in org.eclipse.persistence.annotations
Represent a specific range partition.
RangePartition() - Constructor for class org.eclipse.persistence.descriptors.partitioning.RangePartition
 
RangePartition(String, Comparable, Comparable) - Constructor for class org.eclipse.persistence.descriptors.partitioning.RangePartition
PUBLIC: Create the partition for the connectionPool and start/end values.
RangePartition(String, String, String, String) - Constructor for class org.eclipse.persistence.descriptors.partitioning.RangePartition
INTERNAL: COnstructor used from metadata processing to avoid classloader dependencies.
RangePartitioning - Annotation Type in org.eclipse.persistence.annotations
RangePartitioningPolicy partitions access to a database cluster by a field value from the object, such as the object's id, location, or tenant.
RangePartitioningPolicy - Class in org.eclipse.persistence.descriptors.partitioning
PUBLIC: RangePartitioningPolicy partitions access to a database cluster by a field value from the object, such as the object's id, location, or tenant.
RangePartitioningPolicy() - Constructor for class org.eclipse.persistence.descriptors.partitioning.RangePartitioningPolicy
 
RangePartitioningPolicy(String) - Constructor for class org.eclipse.persistence.descriptors.partitioning.RangePartitioningPolicy
 
RangePartitioningPolicy(String, boolean) - Constructor for class org.eclipse.persistence.descriptors.partitioning.RangePartitioningPolicy
 
RangePartitioningPolicy(String, RangePartition...) - Constructor for class org.eclipse.persistence.descriptors.partitioning.RangePartitioningPolicy
 
rcm - Variable in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
 
rcm - Variable in class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
Reference to manager to get connections, etc.
rcm - Variable in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
The remote command manager responsible for this service
rcm - Variable in class org.eclipse.persistence.sessions.coordination.TransportManager
The RCM that manages this transport
RCM_UNINITIALIZED_OR_CLOSED - Static variable in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
RCMCommand - Class in org.eclipse.persistence.internal.sessions.coordination
Purpose: An abstract class that can be subclassed when internal commands need to be added.
RCMCommand() - Constructor for class org.eclipse.persistence.internal.sessions.coordination.RCMCommand
 
RcmReceived - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
RcmSent - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
RcmStatus - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
read() - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: This method differs slightly from conventional read() operation on a Java stream.
read(int) - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: This method differs slightly from conventional read() operation on a Java stream.
read(Reader) - Static method in class org.eclipse.persistence.sessions.factories.XMLProjectReader
PUBLIC: Read the EclipseLink project deployment XML from the reader on the file.
read(Reader, ClassLoader) - Static method in class org.eclipse.persistence.sessions.factories.XMLProjectReader
PUBLIC: Read the EclipseLink project deployment XML from the reader on the file.
read(String) - Static method in class org.eclipse.persistence.sessions.factories.XMLProjectReader
PUBLIC: Read the EclipseLink project deployment XML from the file or resource name.
read(String, ClassLoader) - Static method in class org.eclipse.persistence.sessions.factories.XMLProjectReader
PUBLIC: Read the EclipseLink project deployment XML from the file or resource name.
READ - org.eclipse.persistence.annotations.OrderCorrectionType
Order of the list read into application is corrected, but no knowledge is kept about the invalid list order left in the data base.
READ - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Names of the possible lock mode types, JPA 1.0 and 2.0
READ_BEYOND_QUERY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
READ_CONNECTION_POOL_MAX_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
READ_CONNECTION_POOL_MIN_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
READ_ONLY - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.read-only"
READ_STATEMENTS_COUNT_PROPERTY - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
 
READ_TRANSFORMER_CLASS_DOESNT_IMPLEMENT_ATTRIBUTE_TRANSFORMER - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
READ_TRANSFORMER_HAS_BOTH_CLASS_AND_METHOD - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
READ_TRANSFORMER_HAS_BOTH_CLASS_AND_METHOD - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
READ_TRANSFORMER_HAS_NEITHER_CLASS_NOR_METHOD - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
READ_TRANSFORMER_HAS_NEITHER_CLASS_NOR_METHOD - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
READ_WRITE - org.eclipse.persistence.annotations.OrderCorrectionType
Order of the list read into application is corrected, and remembered that the invalid list order left in the data base.
read1013Format(Document, ClassLoader) - Static method in class org.eclipse.persistence.sessions.factories.XMLProjectReader
INTERNAL: Read the TopLink 10.1.3 deployment XML format.
read1111Format(Document, ClassLoader) - Static method in class org.eclipse.persistence.sessions.factories.XMLProjectReader
INTERNAL: Read the TopLink 11.1.1 deployment XML format.
readAll() - Method in annotation type org.eclipse.persistence.annotations.QueryRedirectors
A Default ReadAll Query Redirector will be applied to any executing ReadAllQuery that does not have a redirector set directly on the query.
ReadAll - Static variable in class org.eclipse.persistence.config.QueryType
 
readAllObjects(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Read all of the instances of the class from the database.
readAllObjects(Class<?>) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Read all of the instances of the class from the database.
readAllObjects(Class<?>, String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Read all of the instances of the class from the database return through execution the SQL string.
readAllObjects(Class<?>, Expression) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Read all of the instances of the class from the database matching the given expression.
readAllObjects(Class<?>, Expression) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Read all of the instances of the class from the database matching the given expression.
readAllObjects(Class<?>, Call) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Read all the instances of the class from the database returned through execution the Call string.
readAllObjects(Class<?>, Call) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Read all the instances of the class from the database returned through execution the Call string.
readAllQuery - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
ReadAllQuery - Class in org.eclipse.persistence.queries
Purpose: Concrete class for all read queries involving a collection of objects.
ReadAllQuery() - Constructor for class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Return a new read all query.
ReadAllQuery(Class<?>) - Constructor for class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Return a new read all query.
ReadAllQuery(Class<?>, Expression) - Constructor for class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Return a new read all query for the class and the selection criteria.
ReadAllQuery(Class<?>, ExpressionBuilder) - Constructor for class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Return a new read all query for the class.
ReadAllQuery(Class<?>, Call) - Constructor for class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Return a new read all query.
ReadAllQuery(Object, QueryByExamplePolicy) - Constructor for class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Return a query by example query to find all objects matching the attributes of the example object.
ReadAllQuery(ExpressionBuilder) - Constructor for class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: The expression builder should be provide on creation to ensure only one is used.
ReadAllQuery(Call) - Constructor for class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Create a read all query with the database call.
ReadAllQuery.Direction - Enum in org.eclipse.persistence.queries
Specifies the direction in which the hierarchy is traversed in a hierarchical query.
readAllSubclassesView - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
readBeyondStream(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
readChangesFile(String) - Method in class org.eclipse.persistence.tools.PackageRenamer
This readChangesFile() method reads the given properties file to be a reference for renaming TopLink package name.
readCompleteChangeSet(ObjectInputStream) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Helper method used by readObject to read a completely serialized change set from the stream.
readConnectionPool - Variable in class org.eclipse.persistence.sessions.server.ServerSession
 
ReadConnectionPool - Class in org.eclipse.persistence.sessions.server
Purpose: The read connection pool is used for read access through the server session.
ReadConnectionPool() - Constructor for class org.eclipse.persistence.sessions.server.ReadConnectionPool
PUBLIC: Build a new read connection pool.
ReadConnectionPool(String, Login, int, int, int, ServerSession) - Constructor for class org.eclipse.persistence.sessions.server.ReadConnectionPool
PUBLIC: Build a new read connection pool.
ReadConnectionPool(String, Login, int, int, ServerSession) - Constructor for class org.eclipse.persistence.sessions.server.ReadConnectionPool
PUBLIC: Build a new read connection pool.
ReadConnectionPool(String, Login, ServerSession) - Constructor for class org.eclipse.persistence.sessions.server.ReadConnectionPool
PUBLIC: Build a new read connection pool.
ReadConnectionPoolConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.pool
INTERNAL:
ReadConnectionPoolConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.pool.ReadConnectionPoolConfig
 
readExternal(ObjectInput) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Override the default serialization for a remote valueholder so as not to serialize the value Note: Changed for bug 3145211.
readFromBytes(byte[]) - Method in class org.eclipse.persistence.internal.sessions.coordination.ServiceAnnouncement
INTERNAL: Initialize the instance fields from the serialized bytes.
readFromResultSetIntoObject(ResultSet, Object, ObjectBuildingQuery, AbstractSession, DatabaseAccessor, ResultSetMetaData, int, DatabasePlatform) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Extract values directly from the result-set.
readFromReturnRowIntoObject(AbstractRecord, Object, ReadObjectQuery, Collection, ObjectChangeSet) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Build an aggregate object from the specified return row and put it in the specified target object.
readFromReturnRowIntoObject(AbstractRecord, Object, ReadObjectQuery, Collection, ObjectChangeSet) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Extracts value from return row and set the attribute to the value in the object.
readFromRowIntoObject(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Build an aggregate object from the specified row and put it in the specified target object.
readFromRowIntoObject(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Extract value from the row and set the attribute to this value in the object.
readFromRowIntoObject(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Extract value from the row and set the attribute to this value in the object.
readFromRowIntoObject(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Extract value from the row and set the attribute to the value in the object.
readFromRowIntoObject(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, AbstractSession, boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
readFromRowIntoObject(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, AbstractSession, boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
INTERNAL: Extract the primary key values from the row, then create an org.eclipse.persistence.internal.oxm.Reference instance and stored it on the session's org.eclipse.persistence.internal.oxm.ReferenceResolver.
readFromRowIntoObject(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, AbstractSession, boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
readFromRowIntoObject(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, AbstractSession, boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
INTERNAL: Extract the primary key values from the row, then create an org.eclipse.persistence.internal.oxm.Reference instance and store it on the session's org.eclipse.persistence.internal.oxm.ReferenceResolver.
readFromRowIntoObject(AbstractRecord, JoinedAttributeManager, Object, CacheKey, ObjectBuildingQuery, AbstractSession, boolean, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
INTERNAL: Extract the primary key values from the row, then create an org.eclipse.persistence.internal.oxm.Reference instance and stored it on the session's org.eclipse.persistence.internal.oxm.ReferenceResolver.
readFromRowIntoObject(XMLRecord, Object, AbstractSession, boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLTransformationMapping
INTERNAL: Extract value from the row and set the attribute to the value in the object.
readFromRowIntoObject(XML_RECORD, Object, ABSTRACT_SESSION, boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.TransformationMapping
INTERNAL: Extract value from the row and set the attribute to the value in the object.
readIdentityInformation(ObjectInputStream) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Helper method used by readObject to read just the information about object identity from a serialized stream.
ReadLockAcquisitionMetadata - Class in org.eclipse.persistence.internal.helper.type
Metadata about ReadLock acquisition
ReadLockAcquisitionMetadata(ConcurrencyManager, int, String, long) - Constructor for class org.eclipse.persistence.internal.helper.type.ReadLockAcquisitionMetadata
Create a new ReadLockAcquisitionMetadata.
ReadLockManager - Class in org.eclipse.persistence.internal.helper
 
ReadLockManager() - Constructor for class org.eclipse.persistence.internal.helper.ReadLockManager
 
readLockManagerProblem01CreateLogErrorMessageToIndicateThatCurrentThreadHasNullReadLockManagerWhileDecrementingNumberOfReaders(int, int, ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
If when we are decrement the counter of number of readers on a cache key we find ourselves lacking the read lock manager at the time of the decrement we want to log a big fat error on the server log protecting that the current thread is misbehaving.
readLockManagerProblem02ReadLockManageHasNoEntriesForThread(ConcurrencyManager, long) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
readLockManagerProblem03ReadLockManageHasNoEntriesForThread(ConcurrencyManager, long) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
ReadLockOnly - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Used for read lock to determine update the version field with the same value or increment value
ReadLockUpdateVersion - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
readObject() - Method in annotation type org.eclipse.persistence.annotations.QueryRedirectors
A Default ReadObject Query Redirector will be applied to any executing ReadObjectQuery that does not have a redirector set directly on the query.
readObject(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Read the first instance of the class from the database.
readObject(Class<?>) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Read the first instance of the class from the database.
readObject(Class<?>, String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Read the first instance of the class from the database return through execution the SQL string.
readObject(Class<?>, Expression) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Read the first instance of the class from the database matching the given expression.
readObject(Class<?>, Expression) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Read the first instance of the class from the database matching the given expression.
readObject(Class<?>, Call) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Read the first instance of the class from the database returned through execution the Call string.
readObject(Class<?>, Call) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Read the first instance of the class from the database returned through execution the Call string.
readObject(Class<?>, Session) - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: If the PKs were retrieved with the attributes then this method can be used to read the real object from the database.
readObject(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Use the example object to consruct a read object query by the objects primary key.
readObject(Object) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Use the example object to construct a read object query by the objects primary key.
ReadObject - Static variable in class org.eclipse.persistence.config.QueryType
 
readObjectPersistenceRuntimeFormat(Document, ClassLoader, Project) - Static method in class org.eclipse.persistence.sessions.factories.XMLProjectReader
Read a project in the format of an ObjectPersistenceRuntimeXMLProject.
readObjectQuery - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
ReadObjectQuery - Class in org.eclipse.persistence.queries
Purpose: Concrete class for all read queries involving a single object.
ReadObjectQuery() - Constructor for class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return a new read object query.
ReadObjectQuery(Class<?>) - Constructor for class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return a new read object query.
ReadObjectQuery(Class<?>, Expression) - Constructor for class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return a new read object query for the class and the selection criteria.
ReadObjectQuery(Class<?>, ExpressionBuilder) - Constructor for class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return a new read object query for the class.
ReadObjectQuery(Class<?>, Call) - Constructor for class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return a new read object query.
ReadObjectQuery(Object) - Constructor for class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return a query to read the object with the same primary key as the provided object.
ReadObjectQuery(Object, QueryByExamplePolicy) - Constructor for class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return a query by example query to find an object matching the attributes of the example object.
ReadObjectQuery(ExpressionBuilder) - Constructor for class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: The expression builder should be provide on creation to ensure only one is used.
ReadObjectQuery(Call) - Constructor for class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return a new read object query.
readOnly() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: To make mapping read only.
ReadOnly - Annotation Type in org.eclipse.persistence.annotations
The ReadOnly annotation is used to specify that a class is read only.
ReadOnly - Static variable in class org.eclipse.persistence.config.ResultSetConcurrency
The concurrency mode for a ResultSet object that may NOT be updated.
readOnlyClasses - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Read-only class can be used for reference data to avoid cloning when not required.
readOnlyMappingsByField - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
List of read-only mappings using a database field.
readPrivateOwnedForObject(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: Reads the private owned object.
readPrivateOwnedForObject(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: All the privately owned parts are read
readPrivateOwnedForObject(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Reads the private owned object.
readPrivateOwnedForObject(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Reads the private owned object.
ReadQuery - Class in org.eclipse.persistence.queries
Purpose: Abstract class for all read queries.
ReadQuery() - Constructor for class org.eclipse.persistence.queries.ReadQuery
PUBLIC: Initialize the state of the query
readStatementsCount - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Keep track of the number of the read statement that being executed.
readSubclassesOnQueries() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Set the descriptor to read instance of itself and its subclasses when queried.
readTime - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
The read time stores the millisecond value of the last time the object help by this cache key was confirmed as up to date.
readTime - Variable in class org.eclipse.persistence.internal.sessions.remote.ObjectDescriptor
The read time for the object
ReadTransformer - Annotation Type in org.eclipse.persistence.annotations
Annotation for org.eclipse.persistence.mappings.TransformationMapping.
readTransformerClassDoesntImplementAttributeTransformer(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Cause: ReadTransformer for the specified attribute of the specified class doesn't implement the required interface AttributeTransforer.
readTransformerHasBothClassAndMethod(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: ReadTransformer for the specified attribute of the specified class specifies both class and method.
readTransformerHasBothClassAndMethod(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Cause: ReadTransformer for the specified attribute of the specified class specifies both class and method.
readTransformerHasNeitherClassNorMethod(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: ReadTransformer for the specified attribute of the specified class specifies neither class nor method.
readTransformerHasNeitherClassNorMethod(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Cause: ReadTransformer for the specified attribute of the specified class specifies neither class nor method.
readWrite() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: The mapping can be dynamically made either readOnly or readWriteOnly.
REAL_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
rebuildAndAddExpressions(List, List, ExpressionBuilder, Map) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Rebuild the expressions with the correct expression builder if using a different one.
rebuildAndAddExpressions(Map, Vector, ExpressionBuilder, Map) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Rebuild the expressions with the correct expression builder if using a different one.
rebuildExpression(Expression, Expression, Map<Expression, Expression>) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Rebuild the expression if required.
rebuildOn(Expression) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
 
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.ManualQueryKeyExpression
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
Should not rebuild as has its on expression builder.
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.TableExpression
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
INTERNAL: This expression is built on a different base than the one we want.
rebuildOn(Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
INTERNAL: A special version of rebuildOn where the newBase need not be a new ExpressionBuilder but any expression.
rebuildOn(Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: A special version of rebuildOn where the newBase need not be a new ExpressionBuilder but any expression.
rebuildWriteLockValueFromUserFormat(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Rebuild writeLockValue to the expected type from user format i.e XML change set has all values as String.
receivedAnnouncement(ServiceId) - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
INTERNAL: Process the announcement that indicates that a new service is online
recognitionException - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
recognitionException(String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
INTERNAL Create an exception to wrap the recognition exception thrown
reconnect(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Attempt to save some of the cost associated with getting a fresh connection.
reconnect(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Attempt to save some of the cost associated with getting a fresh connection.
record - Variable in class org.eclipse.persistence.eis.EISDOMRecord
The original adapter record.
record - Variable in class org.eclipse.persistence.eis.EISMappedRecord
 
Record_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
RECORD_STACK_ON_LOCK - Static variable in class org.eclipse.persistence.config.SystemProperties
This property is used in conjunction with org.eclipse.persistence.sessions.IdentityMapAccessor.printIdentityMapLocks().
recordAddToCollectionInChangeRecord(ObjectChangeSet, CollectionChangeRecord) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
This method is used to bridge the behavior between Attribute Change Tracking and deferred change tracking with respect to adding the same instance multiple times.
recordAddToCollectionInChangeRecord(ObjectChangeSet, CollectionChangeRecord) - Method in class org.eclipse.persistence.internal.queries.ListContainerPolicy
This method is used to bridge the behavior between Attribute Change Tracking and deferred change tracking with respect to adding the same instance multiple times.
recordAddToCollectionInChangeRecord(ObjectChangeSet, CollectionChangeRecord) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
This method is used to bridge the behavior between Attribute Change Tracking and deferred change tracking with respect to adding the same instance multiple times.
recordCloneForPessimisticLocking(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Helper method that records clone with uow if query is pessimistic locking.
recordCloneForPessimisticLocking(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Helper method that records clone with uow if query is pessimistic locking.
recordConverter - Variable in class org.eclipse.persistence.eis.EISPlatform
Can be used to convert from an adapter specific record.
RecordConverter - Interface in org.eclipse.persistence.eis
The RecordConverter interface allows conversion of an adapter specific record.
RecordEntry(Object, Object) - Constructor for class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordEntry
 
RecordEntry(Object, Object) - Constructor for class org.eclipse.persistence.queries.ReportQueryResult.RecordEntry
 
recordFactory - Variable in class org.eclipse.persistence.eis.EISAccessor
 
recordFetchedAttribute(Class<?>, String) - Static method in class org.eclipse.persistence.tools.profiler.FetchGroupMonitor
 
RecordKeyIterator() - Constructor for class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordKeyIterator
Default constructor.
recordMappingDependencies() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
Add all owned classes for each descriptor through checking the mappings.
recordMerge(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
recordName - Variable in class org.eclipse.persistence.eis.EISDOMRecord
The record name.
recordPrivateOwnedRemovals(Object, ClassDescriptor, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Add the provided object to the deleted objects list on the commit manager.
recordPrivateOwnedRemovals(Object, ClassDescriptor, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Add the key and value from provided association to the deleted objects list on the commit manager.
recordPrivateOwnedRemovals(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Overridden by mappings that require additional processing of the change record after the record has been calculated.
recordPrivateOwnedRemovals(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Overridden by mappings that require objects to be deleted contribute to change set creation.
recordPrivateOwnedRemovals(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Overridden by mappings that require additional processing of the change record after the record has been calculated.
recordPrivateOwnedRemovals(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Overridden by mappings that require additional processing of the change record after the record has been calculated.
recordPrivateOwnedRemovals(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Overridden by mappings that require additional processing of the change record after the record has been calculated.
recordPrivateOwnedRemovals(Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL: Overridden by mappings that require additional processing of the change record after the record has been calculated.
recordPrivateOwnedRemovals(Object, UnitOfWorkImpl, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
recordRemoveFromCollectionInChangeRecord(ObjectChangeSet, CollectionChangeRecord) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
This method is used to bridge the behavior between Attribute Change Tracking and deferred change tracking with respect to adding the same instance multiple times.
recordRemoveFromCollectionInChangeRecord(ObjectChangeSet, CollectionChangeRecord) - Method in class org.eclipse.persistence.internal.queries.ListContainerPolicy
This method is used to bridge the behavior between Attribute Change Tracking and deferred change tracking with respect to adding the same instance multiple times.
recordRemoveFromCollectionInChangeRecord(ObjectChangeSet, CollectionChangeRecord) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
 
recordShortDescription - Variable in class org.eclipse.persistence.eis.EISDOMRecord
The record name.
recordSpecifiedDependencies() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
Add all owned classes for each descriptor through checking the mappings.
recordUpdateToCollectionInChangeRecord(CollectionChangeEvent, ObjectChangeSet, CollectionChangeRecord) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
This method is used to bridge the behavior between Attribute Change Tracking and deferred change tracking with respect to adding the same instance multiple times.
recordUpdateToCollectionInChangeRecord(CollectionChangeEvent, ObjectChangeSet, CollectionChangeRecord) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
This method is used to bridge the behavior between Attribute Change Tracking and deferred change tracking with respect to adding the same instance multiple times.
recordUpdateToCollectionInChangeRecord(CollectionChangeEvent, ObjectChangeSet, CollectionChangeRecord) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
 
RecordValuesIterator() - Constructor for class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordValuesIterator
Default constructor.
recreateOriginalCollection(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
Recreates the original state of the collection.
recursiveExpansionCurrentThreadBeingBlockedByActiveThreadOnCacheKey(ConcurrencyManagerState, int, int, Thread, List<Thread>, Set<Thread>, ConcurrencyManager, boolean) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
Try to expand the current thread from the perspective that it wants a cache key that may be own for writing by a competitor thread.
recursiveExpansionCurrentThreadBeingBlockedByActiveWriters(ConcurrencyManagerState, int, int, Thread, List<Thread>, Set<Thread>, ConcurrencyManager, boolean) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
Try to expand the current thread from the perspective that it wants a cache key that may be own for writing by a competitor thread.
recursiveExplainPossibleDeadLockStep01(ConcurrencyManagerState, int, int, Thread, List<Thread>, Set<Thread>) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
The algorithm expands the current thread in depth.
recursiveExplainPossibleDeadLockStep02(ConcurrencyManagerState, int, int, Thread, List<Thread>, Set<Thread>) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
Precondition the logic of ExplainDeadLockUtil.recursiveExplainPossibleDeadLockStep01(ConcurrencyManagerState, int, int, Thread, List, Set) has been invoked and determined that we need to go deeper and expand the current thread.
recursiveExplainPossibleDeadLockStep03ExpandBasedOnCacheKeyWantedForWriting(ConcurrencyManagerState, int, int, Thread, List<Thread>, Set<Thread>, ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
We are looking at thread that we know has registered itself as wanting to acquire a write lock and not managing to make progress getting the write lock.
recursiveExplainPossibleDeadLockStep03Scenario01CurrentWriterVsOtherWritersWriter(ConcurrencyManagerState, int, int, Thread, List<Thread>, Set<Thread>, ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
Expand the possibility of the current thread wanting to acquire for writing what some other already has acquired for writing.
recursiveExplainPossibleDeadLockStep03Scenario02CurrentWriterVsOtherReader(ConcurrencyManagerState, int, int, Thread, List<Thread>, Set<Thread>, ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
Expand the recursion exploring the possibility that the reason the current thread cannot acquire the cache key is because there are readers on the cache key.
recursiveExplainPossibleDeadLockStep03Scenario03CurrentWriterVsCacheKeyActiveThread(ConcurrencyManagerState, int, int, Thread, List<Thread>, Set<Thread>, ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
In scenario 3 is when we start considering the possbility our data for detecting the dead lock is not ok or the cache is corrupted.
recursiveExplainPossibleDeadLockStep04ExpandBasedOnThreadStuckOnReleaseDeferredLocks(ConcurrencyManagerState, int, int, Thread, List<Thread>, Set<Thread>) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
When a thead cannot move forward due to having deferred cache keys, it means that the thread could not go as deep as it wanted during object building and hda to defer making some parts of the object.
recursiveExplainPossibleDeadLockStep05ExpandBasedOnCacheKeyWantedForReading(ConcurrencyManagerState, int, int, Thread, List<Thread>, Set<Thread>, ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
In this case have a thread that wants to acquire for reading a cache key but it does not manage to acquire it because the cache key is being owned by somebody else.
recursiveExplainPossibleDeadLockStep05Scenario01CurrentReaderVsOtherWriters(ConcurrencyManagerState, int, int, Thread, List<Thread>, Set<Thread>, ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
Expand the possibility of the current thread wanting to acquire for writing what some other already has acquired for writing.
recursiveExplainPossibleDeadLockStep05Scenario02CurrentReaderVsCacheKeyActiveThread(ConcurrencyManagerState, int, int, Thread, List<Thread>, Set<Thread>, ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
Same as ExplainDeadLockUtil.recursiveExplainPossibleDeadLockStep03Scenario03CurrentWriterVsCacheKeyActiveThread(ConcurrencyManagerState, int, int, Thread, List, Set, ConcurrencyManager) but in this case our candidate thread is trying to get the cache key with the purpose of READING and not for writing.
REDIRECTION_CLASS_OR_METHOD_NOT_SET - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
REDIRECTION_METHOD_ERROR - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
REDIRECTION_METHOD_NOT_DEFINED_CORRECTLY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
redirectionClassOrMethodNotSet(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
redirectionMethodError(Exception, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
redirectionMethodNotDefinedCorrectly(Class<?>, String, Exception, DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
redirector - Variable in class org.eclipse.persistence.queries.DatabaseQuery
A redirector allows for a queries execution to be the execution of a piece of code.
redirectQuery(QueryRedirector, DatabaseQuery, AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Use a EclipseLink redirector to redirect this query to a method.
reestablishConnection(AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Reconnect to the database.
reestablishConnection(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
PUBLIC: Reconnect to the database.
reestablishCustomizer() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
This method is called by reestablishConnection.
ref() - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: For Object-relational support.
ref() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
Ref - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
REF_PREFIX - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
REF_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
REF_URL - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
reference - Variable in class org.eclipse.persistence.internal.identitymaps.WeakCacheKey
Reference is maintained weak to allow garbage collection
reference - Variable in class org.eclipse.persistence.internal.oxm.WeakObjectWrapper
 
reference(Reference) - Method in class org.eclipse.persistence.internal.oxm.ChoiceUnmarshalContext
 
reference(Reference) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectUnmarshalContext
 
reference(Reference) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedUnmarshalContext
 
reference(Reference) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalContext
 
reference(Reference) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
reference(Reference) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
reference(Reference) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
Reference - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
Reference(Mapping, Object, Class<?>, Object) - Constructor for class org.eclipse.persistence.internal.oxm.Reference
Constructor typically used in the single case.
Reference(Mapping, Object, Class<?>, HashMap, Object) - Constructor for class org.eclipse.persistence.internal.oxm.Reference
Constructor typically used in the collection case.
REFERENCE_CLASS_MISSING - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
REFERENCE_CLASS_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
REFERENCE_DESCRIPTOR_CANNOT_BE_AGGREGATE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
REFERENCE_DESCRIPTOR_IS_NOT_AGGREGATE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
REFERENCE_DESCRIPTOR_IS_NOT_AGGREGATECOLLECTION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
REFERENCE_KEY_FIELD_NOT_PROPERLY_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
REFERENCE_TABLE_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
referenceCache - Variable in class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap
A subset of cache entries have hard references maintained in this list to reduce garbage collection frequency
ReferenceCacheKey(Object, Object, Object, long, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap.ReferenceCacheKey
 
referenceClass - Variable in class org.eclipse.persistence.mappings.AggregateMapping
Stores a reference class
referenceClass - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
This is used only in descriptor proxy in remote session
referenceClass - Variable in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
 
referenceClass - Variable in class org.eclipse.persistence.queries.ModifyAllQuery
 
referenceClass - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
The class of the target objects to be read from the database.
referenceClassMissing(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
referenceClassName - Variable in class org.eclipse.persistence.mappings.AggregateMapping
 
referenceClassName - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
 
referenceClassName - Variable in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
 
referenceClassName - Variable in class org.eclipse.persistence.queries.ModifyAllQuery
 
referenceClassName - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
 
referenceClassNotSpecified(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
REFERENCED_PROPERTY_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
referenceDescriptor - Variable in class org.eclipse.persistence.mappings.AggregateMapping
The descriptor of the reference class
referenceDescriptor - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
The descriptor of the reference class.
referenceDescriptorCannotBeAggregate(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
referenceDescriptorIsNotAggregate(String, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
referenceDescriptorIsNotAggregateCollection(String, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
referencedPropertyNotFound(String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when trying to find a referenced property during xsdhelper.define
referencedXmlPath() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlJoinNode
 
referenceKeyFieldNotProperlySpecified(DatabaseField, ForeignReferenceMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
referenceKeyFields - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
ReferenceMapping - Class in org.eclipse.persistence.mappings.structures
Purpose: In an object-relational data model, structures reference each other through "Refs"; not through foreign keys as in the relational data model.
ReferenceMapping() - Constructor for class org.eclipse.persistence.mappings.structures.ReferenceMapping
 
referenceMode - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
This stored the reference mode for this UOW.
ReferenceMode - Enum in org.eclipse.persistence.config
Purpose: This class is a configuration property used to specify What type of Referenes EclipseLink will use when referencing Entities within the Persistence Context / UnitOfWork.
referenceNode - Variable in class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap.ReferenceCacheKey
 
referenceQueue - Variable in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
This is used by the garbage collector.
referenceQueue - Variable in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
 
referenceQueue - Variable in class org.eclipse.persistence.internal.identitymaps.WeakUnitOfWorkIdentityMap
 
ReferenceResolver - Class in org.eclipse.persistence.internal.oxm
This class is leveraged by reference mappings.
ReferenceResolver() - Constructor for class org.eclipse.persistence.internal.oxm.ReferenceResolver
The default constructor initializes the list of References.
references - Variable in class org.eclipse.persistence.internal.indirection.CacheBasedValueHolder
 
referenceTable - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
Stores the reference table
referenceTableNotSpecified(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
referencingClasses - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
REFLECTIVE_CALL_ON_TOPLINK_CLASS_FAILED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
REFLECTIVE_EXCEPTION_WHILE_CREATING_CLASS_INSTANCE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
ReflectiveAttributeDefinition - Class in org.eclipse.persistence.internal.codegen
INTERNAL:
ReflectiveAttributeDefinition() - Constructor for class org.eclipse.persistence.internal.codegen.ReflectiveAttributeDefinition
 
reflectiveCallOnTopLinkClassFailed(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
reflectiveExceptionWhileCreatingClassInstance(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Cause: When deploying a JPA application, an Exception was thrown while reflectively instantiating a class that was listed in the metadata.
ReflectiveMethodDefinition - Class in org.eclipse.persistence.internal.codegen
INTERNAL:
ReflectiveMethodDefinition() - Constructor for class org.eclipse.persistence.internal.codegen.ReflectiveMethodDefinition
 
REFRESH - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.refresh"
REFRESH_CASCADE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.refresh.cascade"
REFRESH_NOT_POSSIBLE_WITH_CHECK_CACHE_ONLY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
REFRESH_NOT_POSSIBLE_WITHOUT_CACHE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
REFRESH_REMOTE_OBJECT - Static variable in class org.eclipse.persistence.internal.sessions.MergeManager
 
refreshAndLockObject(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Refresh the attributes of the object and of all of its private parts from the database.
refreshAndLockObject(Object) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Refresh the attributes of the object and of all of its private parts from the database.
refreshAndLockObject(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Refresh the attributes of the object and of all of its private parts from the database.
refreshAndLockObject(Object, short) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Refresh the attributes of the object and of all of its private parts from the database.
refreshAndLockObject(Object, short) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Refresh the attributes of the object and of all of its private parts from the database.
refreshAndLockObject(Object, short) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Refresh the attributes of the object and of all of its private parts from the database.
refreshCascade - Variable in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
 
refreshIdentityMapResult() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
PUBLIC: Refresh the attributes of the object(s) resulting from the query.
refreshIdentityMapResult() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Refresh the attributes of the object(s) resulting from the query.
refreshNotPossibleWithCheckCacheOnly(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
refreshNotPossibleWithoutCache(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
refreshObject(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Refresh the attributes of the object and of all of its private parts from the database.
refreshObject(Object) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Refresh the attributes of the object and of all of its private parts from the database.
refreshObjectIfRequired(ClassDescriptor, CacheKey, Object, ObjectBuildingQuery, JoinedAttributeManager, AbstractRecord, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
This method is called when a cached Entity needs to be refreshed
refreshOnlyIfNewer() - Method in annotation type org.eclipse.persistence.annotations.Cache
(Optional) For all queries that go to the database, refresh the cache only if the data received from the database by a query is newer than the data in the cache (as determined by the optimistic locking field).
refreshProject(String) - Method in class org.eclipse.persistence.services.DevelopmentServices
This method used to reset a project in a session.
refreshProject(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method used to reset a project in a session.
refreshRemoteIdentityMapResult() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
PUBLIC: Refresh the attributes of the object(s) resulting from the query.
refreshRemoteIdentityMapResult() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Refresh the attributes of the object(s) resulting from the query.
refreshRemoteObject() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTERNAL: This is used to refresh remote session object
refToHex() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
RefToHex - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
regexp() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the REGEXP operator.
regexp(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value matches the regular expression.
regexp(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that compares if the receivers value matches the regular expression.
Regexp - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
regexpOperator() - Static method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Create the REGEXP_LIKE operator.
regexpOperator() - Static method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Create the ~ operator.
register(DataSource, Session) - Method in interface org.eclipse.persistence.platform.database.partitioning.DataPartitioningCallback
 
register(Session) - Method in interface org.eclipse.persistence.platform.database.events.DatabaseEventListener
Register for database change events and invalidate the session's cache.
Register - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
registerAllObjects(Collection) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Register the objects with the unit of work.
registerAllObjects(Collection) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Register the objects with the unit of work.
registerAllObjects(Vector) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Register the objects with the unit of work.
registeredObjects - Variable in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Store the objects registered.
registerExistingObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Register the existing object with the unit of work.
registerExistingObject(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Register the existing object with the unit of work.
registerExistingObject(Object, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Register the existing object with the unit of work.
registerExistingObject(Object, ClassDescriptor, Object, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Register the existing object with the unit of work.
registerExistingObjectOfReadOnlyClassInNestedTransaction(Object, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTERNAL: Used to register an existing object used in nested unit of work with read-only class in root unit of work.
registerFinalizer() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Register a finalizer to release this session.
registerIn(Map) - Method in class org.eclipse.persistence.expressions.Expression
 
registerIn(Map) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Override Expression.registerIn to check if the new base expression has already been provided for the clone.
registerIndividualResult(Object, Object, UnitOfWorkImpl, JoinedAttributeManager, ClassDescriptor) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Constructs the final (registered) object for every individual object queried via a UnitOfWork.
registerMBean() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: registerMBean(): Create and deploy the JMX MBean to provide runtime services for my databaseSession.
registerMBean() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: registerMBean(): Create and deploy the JMX MBean to provide runtime services for my databaseSession.
registerNewContainerBean(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Register the new container bean with the unit of work.
registerNewContainerBeanForCMP(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Register the new Bean with the unit of work.
registerNewObject(Object) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
ADVANCED: Register the new object with the unit of work.
registerNewObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Register the new object with the unit of work.
registerNewObject(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Register the new object with the unit of work.
registerNewObject(Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Updated to allow passing in of the object's descriptor Register the new object with the unit of work.
registerNewObjectClone(Object, Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Register the working copy of a new object and its original.
registerNewObjectForPersist(Object, Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Register the new object with the unit of work.
registerNewObjectInIdentityMap(Object, Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Add the new object to the cache if set to.
registerNotRegisteredNewObjectForPersist(Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Called only by registerNewObjectForPersist method, and only if newObject is not already registered.
registerNotRegisteredNewObjectForPersist(Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Called only by registerNewObjectForPersist method, and only if newObject is not already registered.
registerObject(Class<?>, Object, String) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Register the object given its name.
registerObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Register the object with the unit of work.
registerObject(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Register the object with the unit of work.
registerObject(Object, String) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Register the object given its name.
registerObject(Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Allows for calling method to provide the descriptor information for this object.
registerObjectForMergeCloneIntoWorkingCopy(Object, boolean) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTERNAL: When merging from a clone when the cache cannot be guaranteed the object must be first read if it is existing and not in the cache.
registerObjectInIdentityMap(Object, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Store the query object in the identity map.
registerOperator(int, String) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Define a name for a user defined operator.
registerOriginalNewObjectFromNestedUnitOfWork(Object, Object, Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Register a new object from a nested unit of work into its parent.
registerOutputParameter(CallableStatement, int, int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This method is used to register output parameter on CallableStatements for Stored Procedures as each database seems to have a different method.
registerOutputParameter(CallableStatement, int, int) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
This method is used to register output parameter on Callable Statements for Stored Procedures as each database seems to have a different method.
registerOutputParameter(CallableStatement, int, int, String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This method is used to register output parameter on CallableStatements for Stored Procedures as each database seems to have a different method.
registerOutputParameter(CallableStatement, int, int, String) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
registerOutputParameter(CallableStatement, String, int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This method is used to register output parameter on CallableStatements for Stored Procedures as each database seems to have a different method.
registerOutputParameter(CallableStatement, String, int) - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
This method is used to register output parameter on Callable Statements for Stored Procedures as each database seems to have a different method.
registerOutputParameter(CallableStatement, String, int, String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This method is used to register output parameter on CallableStatements for Stored Procedures as each database seems to have a different method.
registerOutputParameter(CallableStatement, String, int, String) - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
This method is used to register output parameter on Callable Statements for Stored Procedures as each database seems to have a different method.
registerRemovedNewObjectIfRequired(Object) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Determine if the object is a registered new object, and that this is a nested unit of work merge into the parent.
registerRemoveNewObjectIfRequired(ObjectChangeSet, MergeManager) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL:
registerResultInUnitOfWork(Object, UnitOfWorkImpl, AbstractRecord, boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: All objects queried via a UnitOfWork get registered here.
registerResultInUnitOfWork(Object, UnitOfWorkImpl, AbstractRecord, boolean) - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: All objects queried via a UnitOfWork get registered here.
registerResultInUnitOfWork(Object, UnitOfWorkImpl, AbstractRecord, boolean) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: All objects queried via a UnitOfWork get registered here.
registerResultSetInUnitOfWork(ResultSet, Vector, DatabaseField[], UnitOfWorkImpl, AbstractRecord) - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Version of the previous method for ResultSet optimization.
registerSession(String, AbstractSession) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Register the session under its name.
registerSession(String, Session) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Register the session under its name.
registerSynchronization_impl(AbstractSynchronizationListener, Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Register the specified synchronization listener with the given active transaction.
registerSynchronization_impl(AbstractSynchronizationListener, Object) - Method in class org.eclipse.persistence.transaction.JTA11TransactionController
INTERNAL: Register the specified synchronization listener with the given active transaction.
registerSynchronization_impl(AbstractSynchronizationListener, Object) - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Register the specified synchronization listener with the given active transaction.
registerSynchronizationListener(UnitOfWorkImpl, AbstractSession) - Method in interface org.eclipse.persistence.sessions.ExternalTransactionController
INTERNAL: Register a listener on the unit of work.
registerSynchronizationListener(UnitOfWorkImpl, AbstractSession) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Associate the given unit of work and EclipseLink session with the current external transaction.
registerWithTransactionIfRequired() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Register this UnitOfWork against an external transaction controller
REGISTRY_NAMING_SERVICE - Static variable in class org.eclipse.persistence.sessions.coordination.TransportManager
 
rehash() - Method in class org.eclipse.persistence.indirection.IndirectMap
 
rehashFieldDependancies(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Rehash any hashtables based on fields.
rehashFieldDependancies(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Rehash any maps based on fields.
rehashFieldDependancies(AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Rehash any hashtables based on fields.
rehashFieldDependancies(AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Rehash any hashtables based on fields.
rehashFieldDependancies(AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Rehash any map based on fields.
rehashFieldDependancies(AbstractSession) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Rehash any maps based on fields.
rehashHashtable(Hashtable<K, V>) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
rehashMap(Map<K, V>) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
reinitialize() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Reset the commits.
reinitializeForSession(AbstractSession, RemoteSessionController) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
INTERNAL: Re-initialize for the server-side session.
reInitializeJoinedAttributes() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: A user should not be setting which attributes to join or not to join after descriptor initialization; provided only for backwards compatibility.
relate() - Static method in class org.eclipse.persistence.internal.expressions.SpatialExpressionOperators
ExpressionOperator for the MDSYS.MDSYS.SDO_RELATE Spatial Operator on the Oracle Database Use of this operator requires the Java spatial classes
relatedNodes - Variable in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
RELATION_KEY_FIELD_NOT_PROPERLY_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
RelationalDescriptor - Class in org.eclipse.persistence.descriptors
Purpose: EclipseLink has been designed to take advantage of the similarities between relational databases and objects while accommodating for their differences, providing an object oriented wrapper for relational databases.
RelationalDescriptor() - Constructor for class org.eclipse.persistence.descriptors.RelationalDescriptor
PUBLIC: Return a new descriptor.
RelationalMapping - Interface in org.eclipse.persistence.mappings
INTERNAL All mappings which can be added to org.eclipse.persistence.mappings.Descriptor must implement this interface.
RelationExpression - Class in org.eclipse.persistence.internal.expressions
Purpose:Used for all relation operators except for between.
RelationExpression() - Constructor for class org.eclipse.persistence.internal.expressions.RelationExpression
 
RelationExpression_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
relationKeyFieldNotProperlySpecified(DatabaseField, ForeignReferenceMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
relationshipMappings - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Cache relationship mappings.
relationshipPartner - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Used to reference the other half of a bi-directional relationship.
relationshipPartnerAttributeName - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Set by users, used to retrieve the backpointer for this mapping
relationshipSourceObject - Variable in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
This attribute is used specifically for relationship support.
relationTable - Variable in class org.eclipse.persistence.mappings.RelationTableMechanism
The intermediate relation table.
RelationTableMechanism - Class in org.eclipse.persistence.mappings
Purpose: Contains relation table functionality that was originally defined in ManyToManyMapping and now is shared with OneToOneMapping.
RelationTableMechanism() - Constructor for class org.eclipse.persistence.mappings.RelationTableMechanism
 
relative(int) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
Moves the cursor a relative number of rows, either positive or negative.
relative(int) - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Moves the cursor a relative number of rows, either positive or negative.
RelativePositionOrderingPolicy - Class in org.eclipse.persistence.oxm.documentpreservation
INTERNAL:
RelativePositionOrderingPolicy() - Constructor for class org.eclipse.persistence.oxm.documentpreservation.RelativePositionOrderingPolicy
 
RelativePositionOrderingPolicyConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.login
 
RelativePositionOrderingPolicyConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.login.RelativePositionOrderingPolicyConfig
Default constructor.
release() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Decrement the depth for the active thread.
release() - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
This method may be called during initialize all identity maps.
release() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Release the lock on the cache key object.
release() - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
This method may be called during initialize all identity maps.
release() - Method in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
Avoid acquiring locks for unit of work.
release() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Release the session.
release() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
PUBLIC: Release the connection resource.
release() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Release the unit of work.
release() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Release the session.
release() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
Release the lock on the cache key object.
release() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Was PUBLIC: customer will be redirected to Session.
release() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Release the session.
release() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Release the unit of work.
releaseActiveLocksOnThread() - Method in class org.eclipse.persistence.internal.helper.DeferredLockManager
Release the active lock on the DLM
releaseAllAcquiredLocks(MergeManager) - Method in class org.eclipse.persistence.internal.helper.WriteLockManager
INTERNAL: This method will release all acquired locks
releaseAllLocksAcquiredByThread(DeferredLockManager) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
For the thread to release all of its locks.
releaseCalendar(Calendar) - Static method in class org.eclipse.persistence.internal.helper.Helper
PERF: This is used to optimize Calendar conversion/printing.
releaseClientSession(ClientSession) - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Release the clients connection resource.
releaseConnection(Accessor) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: Add the connection as single that a new connection is available.
releaseConnection(Accessor) - Method in class org.eclipse.persistence.sessions.server.ExternalConnectionPool
INTERNAL: When you release an external connection, you simply let it go.
releaseConnection(Accessor) - Method in class org.eclipse.persistence.sessions.server.ReadConnectionPool
INTERNAL: Because connections are not exclusive nothing is required.
releaseConnectionAfterCall(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Release (if required) connection after call.
releaseConnectionAfterCall(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Release (if required) connection after call.
releaseConnectionAfterCall(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Release (if required) connection after call.
releaseCustomizer() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Clear customizer if it's active and set it to null.
releaseCustomizer() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Clear customizer if it's active and set it to null.
releaseCustomizer(AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Clear and remove customizer if its session is the same as the passed one; in case prevCustomizer exists set it as a new customizer.
releaseCustomizer(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Clear and remove customizer if its session is the same as the passed one; in case prevCustomizer exists set it as a new customizer.
releaseDeferredLock() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Release the deferred lock.
releaseDeferredLock() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Release the deferred lock
releaseDeferredLock() - Method in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
Avoid acquiring locks for unit of work.
releaseDeferredLock() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
Release the deferred lock
releaseInvalidClientSession(ClientSession) - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Release any invalid connection in the client session.
releaseJTSConnection() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Called in the end of beforeCompletion of external transaction synchronization listener.
releaseJTSConnection() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Called in the end of beforeCompletion of external transaction synchronization listener.
releaseJTSConnection() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Called in the end of beforeCompletion of external transaction synchronization listener.
releaseJTSConnection() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Called in the end of beforeCompletion of external transaction sychronization listener.
releaseJTSConnection() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Called in the end of beforeCompletion of external transaction synchronization listener.
releasePrevious() - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Release all objects read in so far.
releaseReadConnection(Accessor) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL:
releaseReadConnection(Accessor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Release the read connection to the read connection pool.
releaseReadConnection(Accessor) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Release the cursor query's connection.
releaseReadConnection(Accessor) - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Release the read connection back into the read pool.
releaseReadLock() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Decrement the number of readers.
releaseReadLock() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Release the read lock on the cache key object.
releaseReadLock() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Read-release the local-map and the entire cache.
releaseReadLock() - Method in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
Avoid acquiring locks for unit of work.
releaseReadLock() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
Release the read lock on the cache key object.
releaseSemaphoreAllowOtherThreadsToStartDoingObjectBuilding(boolean) - Method in class org.eclipse.persistence.internal.helper.ConcurrencySemaphore
If the call to ConcurrencySemaphore.acquireSemaphoreIfAppropriate(boolean) returned true implying the current thread acquire the semaphore, the same thread on the same method is mandated to release the semaphore.
releaseStatement(Statement, String, DatabaseCall, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Release the statement through closing it or putting it back in the statement cache.
releaseUnitOfWork(UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Release the unit of work, if lazy release the connection.
releaseWrappedValueHolder(AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Releases a wrapped valueholder privately owned by a particular unit of work.
releaseWrappedValueHolder(AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
Releases a wrapped valueholder privately owned by a particular unit of work.
releaseWrappedValueHolder(AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
Releases a wrapped valueholder privately owned by a particular unit of work.
releaseWriteConnection() - Method in class org.eclipse.persistence.internal.sessions.ExclusiveIsolatedClientSession
INTERNAL: As this session type should maintain it's transaction for its entire life- cycle we will wait for 'release' before releasing connection.
releaseWriteConnection() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: This is internal to the unit of work and should not be called otherwise.
releaseWriteLock() - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Lock the entire cache if the cache isolation requires.
releaseWriteLock() - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Lock the entire cache if the cache isolation requires.
releaseWriteLock() - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Lock the entire cache if the cache isolation requires.
releaseWriteLocks() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Release the unit of work cache write locks, if acquired.
Remote - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
REMOTE_PROTOCOL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.remote.protocol" property configures remote JPA for a client or server.
REMOTE_SERVER_NAME - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.remote.server.name" property configures remote JPA for a server.
REMOTE_URL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.remote.client.url" property configures remote JPA for a client.
RemoteChangeSet - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
RemoteCommand - Interface in org.eclipse.persistence.internal.sessions.remote
Purpose: This Interfaces provides the reference part of an remote command framework Whereby, TopLink can issue commands to distributed servers.
RemoteCommandManager - Class in org.eclipse.persistence.sessions.coordination
Purpose: Provide a CommandManager implementation for cache coordination.
RemoteCommandManager(CommandProcessor) - Constructor for class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
RemoteCommandManager(CommandProcessor, TransportManager) - Constructor for class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
RemoteCommandManagerConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.rcm
INTERNAL:
RemoteCommandManagerConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.rcm.RemoteCommandManagerConfig
 
RemoteCommandManagerException - Exception in org.eclipse.persistence.exceptions
Instances of this exception are raised if a problem is detected in the RemoteCommandManager (RCM) feature.
RemoteCommandManagerException() - Constructor for exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
RemoteCommandManagerException(String) - Constructor for exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
RemoteCommandManagerExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for RemoteCommandManagerExceptionResource messages.
RemoteCommandManagerExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.RemoteCommandManagerExceptionResource
Default constructor.
remoteCommandManagerIsClosed() - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
remoteConnection - Variable in class org.eclipse.persistence.sessions.remote.DistributedSession
Connection to remote persistence service.
RemoteConnection - Class in org.eclipse.persistence.internal.sessions.coordination
Purpose: Define an abstract class for the remote object that can execute a remote command using different transport protocols.
RemoteConnection - Class in org.eclipse.persistence.internal.sessions.remote
Defines set of abstract methods which one must overwrite for any kind to implement a communication mechanism.
RemoteConnection() - Constructor for class org.eclipse.persistence.internal.sessions.coordination.RemoteConnection
Default constructor.
RemoteConnection() - Constructor for class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
 
remoteContextProperties - Variable in class org.eclipse.persistence.sessions.coordination.TransportManager
Properties to obtain the context used for remote JNDI access
RemoteCursoredStream - Class in org.eclipse.persistence.internal.sessions.remote
Purpose: The object is used as a wrapper to the CursoredStream object in the remote transaction (via RMI, CORBA, etc.)
RemoteCursoredStream(CursoredStream) - Constructor for class org.eclipse.persistence.internal.sessions.remote.RemoteCursoredStream
 
remoteCursors - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
The original cursor (either CursoredStream or ScrollableCursor, before they were serialized; keyed by ID
remoteExecute() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
This can be used by collection such as cursored stream to gain control over execution.
remoteExecute() - Method in class org.eclipse.persistence.queries.CursoredStreamPolicy
INTERNAL: Execute the cursored select and build the stream.
remoteExecute() - Method in class org.eclipse.persistence.queries.CursorPolicy
INTERNAL: Execute the cursored select and build the stream.
remoteExecute() - Method in class org.eclipse.persistence.queries.DatabaseQuery
 
remoteExecute() - Method in class org.eclipse.persistence.queries.DataReadQuery
INTERNAL: Used by RemoteSession.
remoteExecute() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Execute the query through remote session.
remoteExecute() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
 
remoteExecute() - Method in class org.eclipse.persistence.queries.ScrollableCursorPolicy
INTERNAL: Execute the cursored select and build the stream.
remoteExecute(AbstractSession) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL:
remoteExecute(AbstractSession) - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: Return if this is a read query.
remoteExecute(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Execute query remotely.
remoteExecute(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Execute the query on the server.
remoteExecuteNamedQuery(String, Class<?>, Vector) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Execute query remotely.
remoteExecuteNamedQuery(String, Class<?>, Vector) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Execute query remotely.
RemoteFunctionCall - Interface in org.eclipse.persistence.internal.sessions.remote
Purpose: This Interface provides the reference part of an remote command framework Whereby, TopLink can issue function calls to distributed servers.
remoteIdentityMapClass - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
remoteIdentityMapSize - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
remoteInitialization(AbstractSession) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: Used to initialize a remote DescriptorEventManager.
remoteInitialization(DistributedSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Used to initialize a remote descriptor.
remoteInitialization(DistributedSession) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Used to initialize a remote descriptor.
remoteInitialization(DistributedSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Once a descriptor is serialized to the remote session, all its mappings and reference descriptors are traversed.
remoteInitialization(DistributedSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Once a descriptor is serialized to the remote session, all its mappings and reference descriptors are traversed.
remoteInitialization(DistributedSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Once descriptors are serialized to the remote session.
remoteInitialization(DistributedSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Once descriptors are serialized to the remote session.
remoteInitialization(DistributedSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Once descriptors are serialized to the remote session.
remoteInitialization(DistributedSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Once descriptors are serialized to the remote session.
remoteInitialization(DistributedSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Once descriptors are serialized to the remote session.
remoteInitialize(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: Initialize the CMPPolicy settings for remote sessions.
RemoteLazy - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
remotelyInitialized() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
Set the mapping to be initialized for the remote session.
RemoteMetadata - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
RemoteProtocol - Class in org.eclipse.persistence.config
Remote JPA protocol persistence property values.
remoteReferenceDescriptor - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
In RemoteSession case the mapping needs the reference descriptor serialized from the server, but referenceDescriptor attribute defined as transient in the superclass.
RemoteScrollableCursor - Class in org.eclipse.persistence.internal.sessions.remote
Purpose: The object is used as a wrapper to the ScrollableCursor object in the remote transaction (via RMI, CORBA, etc.)
RemoteScrollableCursor(ScrollableCursor) - Constructor for class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
 
RemoteSession - Class in org.eclipse.persistence.sessions.remote
Purpose: Provide transparent remote three-tiered replacation support.
RemoteSession() - Constructor for class org.eclipse.persistence.sessions.remote.RemoteSession
 
RemoteSession(RemoteConnection) - Constructor for class org.eclipse.persistence.sessions.remote.RemoteSession
PUBLIC: Creates a RemoteSession.
RemoteSessionController - Class in org.eclipse.persistence.internal.sessions.remote
RemoteSessionController sits between the remote session (on the client) and whatever session is running on the server.
RemoteSessionController(AbstractSession) - Constructor for class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
 
remoteUnitOfWork - Variable in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
These cannot be transient because they are required for a remote unit of work.
RemoteUnitOfWork - Class in org.eclipse.persistence.internal.sessions.remote
Counter part of the unit of work which exists on the client side.
RemoteUnitOfWork() - Constructor for class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
RemoteUnitOfWork(RemoteUnitOfWork) - Constructor for class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
RemoteUnitOfWork(RemoteUnitOfWork, ReferenceMode) - Constructor for class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
RemoteUnitOfWork(DistributedSession) - Constructor for class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
RemoteUnitOfWork(DistributedSession, ReferenceMode) - Constructor for class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
RemoteValueHolder<T> - Class in org.eclipse.persistence.internal.sessions.remote
Remote value holders can be invoked locally and remotely.
RemoteValueHolder() - Constructor for class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
 
RemoteValueHolder(ObjID) - Constructor for class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
 
remoteValueHolders - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
The original remote value holders, before they were serialized; keyed by ID
removAllValue() - Method in class org.eclipse.persistence.internal.sessions.ResultSetRecord
 
remove() - Method in class org.eclipse.persistence.internal.mappings.converters.AttributeNameTokenizer.TokensIterator
INTERNAL: Removal of attribute name tokens makes no sense.
remove() - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy.MapContainerPolicyIterator
 
remove() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordEntryIterator
 
remove() - Method in class org.eclipse.persistence.queries.Cursor
PUBLIC: Remove is not support with cursors.
remove() - Method in class org.eclipse.persistence.queries.ReportQueryResult.EntryIterator
 
remove(int) - Method in class org.eclipse.persistence.indirection.IndirectList
 
remove(int) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
remove(int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
remove(int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
remove(int) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
If index is missing wait until is there.
remove(Object) - Method in class org.eclipse.persistence.indirection.IndirectList
 
remove(Object) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
remove(Object) - Method in class org.eclipse.persistence.indirection.IndirectSet
 
remove(Object) - Method in class org.eclipse.persistence.internal.helper.ConcurrentFixedCache
Remove from cache.
remove(Object) - Method in class org.eclipse.persistence.internal.helper.IdentityHashSet
Removes the given object from this IdentityHashSet, if present.
remove(Object) - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Removes the mapping (key and its corresponding value) from this IdentityWeakHashMap, if present.
remove(Object) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
remove(Object) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
remove(Object) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
If object is missing wait until complete.
remove(Object) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
 
remove(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.EntrySet
 
remove(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.KeySet
 
remove(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: Remove the field key from the row.
remove(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.ValuesSet
 
remove(Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult.EntrySet
 
remove(Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult.KeySet
 
remove(Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult
INTERNAL: Remove the name key and value from the result.
remove(Object, Object) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
remove(Object, Object) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Remove the CacheKey with the primaryKey from the map.
remove(Object, Object) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Remove the CacheKey with the primaryKey from the map.
remove(Object, Object) - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Do Nothing.
remove(Object, Object) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
 
remove(Object, Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Remove the CacheKey with the primaryKey from the map.
remove(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: Remove the field key from the row.
remove(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: Remove the field key from the row.
remove(DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
INTERNAL: Remove the field key from the row.
remove(DatabaseField) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Remove the field key from the row.
remove(LinkedNode) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
Allows a node to be efficiently removed.
remove(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Remove the CacheKey from the map.
remove(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.CacheIdentityMap
Remove the LinkedCacheKey from the cache as well as from the linked list.
remove(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Removes the CacheKey from the map.
remove(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap
Remove the cache key from the map and the sub-cache list.
remove(CacheKey) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Remove the CacheKey from the map.
remove(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Do Nothing.
remove(CacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
Avoid acquiring any lock as uow is single threaded.
remove(CacheKey) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Remove the CacheKey from the map.
remove(Field, Node) - Method in class org.eclipse.persistence.internal.oxm.XPathEngine
Remove a node.
remove(Field, Node, boolean) - Method in class org.eclipse.persistence.internal.oxm.XPathEngine
Remove a node.
remove(Session) - Method in interface org.eclipse.persistence.platform.database.events.DatabaseEventListener
Remove registration from database change events.
REMOVE - Static variable in class org.eclipse.persistence.descriptors.changetracking.CollectionChangeEvent
 
REMOVE_CONNECTION_ON_ERROR_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
removeAll(Collection) - Method in class org.eclipse.persistence.internal.helper.IdentityHashSet
This implementation throws an UnsupportedOperationException because removeAll does not work correctly with reference equality testing.
removeAll(Collection) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
removeAll(Collection<?>) - Method in class org.eclipse.persistence.indirection.IndirectList
 
removeAll(Collection<?>) - Method in class org.eclipse.persistence.indirection.IndirectSet
 
removeAll(Collection<?>) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
removeAll(Collection<?>) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
removeAllButAlphaNumericToFit(String, int) - Static method in class org.eclipse.persistence.internal.helper.Helper
Returns a String which has had enough non-alphanumeric characters removed to be equal to the maximumStringLength.
removeAllConnectionsToExternalServices() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Remove all remote connections from the list.
removeAllElements() - Method in class org.eclipse.persistence.indirection.IndirectList
 
removeAllElements() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
removeAllElements() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
removeAllReadOnlyClasses() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Empties the set of read-only classes.
removeAllReadOnlyClasses() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Empties the set of read-only classes.
removeAllSequences() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Remove all sequences, but the default one.
removeAllSequences() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Remove all sequences that were added through addSequence method.
removeAllSequences() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
Remove all sequences but the default one.
removeAllTargetsQuery - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
Query used to update all target rows changing target foreign key value from the one pointing to the source to null.
removeAttribute(String) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Remove an attribute from the group.
removeAttribute(String) - Method in class org.eclipse.persistence.internal.queries.EntityFetchGroup
 
removeCachedExpressionQuery(DatabaseQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Remove the cached expression query.
removeCacheKeyFromMapWriteLockManagerToCacheKeysThatCouldNotBeAcquired(Thread, ConcurrencyManager) - Static method in class org.eclipse.persistence.internal.helper.WriteLockManager
A cache keys was successfully acquired we want to make sure it is not recorded in the map of cache keys that could not be acquired.
removeChange(String) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Remove the change.
removeCharacterToFit(String, char, int) - Static method in class org.eclipse.persistence.internal.helper.Helper
Returns a String which has had enough of the specified character removed to be equal to the maximumStringLength.
removeChildren(ClassDescriptor, Set<Class<?>>, Set<Class<?>>) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
Remove all of the subclasses (and so on) from the set of classes.
removeConnectionToExternalService(RemoteConnection) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL: Remove a remote connection from the list of connections to receive remote commands.
removeConversion(QName, Class<?>) - Method in class org.eclipse.persistence.oxm.XMLField
Remove both a Java to XML Conversion and the corresponding XML to Java Conversion entry
removeDeferredLockManager(Thread) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Remove the deferred lock manager for the thread
removedObjects - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
removeDots(String) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
removeDots(String) - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
 
removeDuplicateAndValidateInfos(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
 
removeElement(Object) - Method in class org.eclipse.persistence.indirection.IndirectList
 
removeElement(Object) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
removeElement(Object) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
If missing wait until complete.
removeElementAt(int) - Method in class org.eclipse.persistence.indirection.IndirectList
 
removeElementAt(int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
removeElementAt(int) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
If index is missing wait until reasched or complete.
removeEntry(Map.Entry, boolean) - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
 
removeExtraNamespacesFromNamespaceResolver(List<Namespace>, CoreAbstractSession) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
removeExtraNamespacesFromNamespaceResolver(List<Namespace>, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
removeExtraNamespacesFromNamespaceResolver(List<Namespace>, CoreAbstractSession) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
removeExtraNamespacesFromNamespaceResolver(List<Namespace>, CoreAbstractSession) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
removeExtraNamespacesFromNamespaceResolver(List<Namespace>, CoreAbstractSession) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL
removeField(DatabaseField) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL:
removeFirst() - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
Removes and returns the first contents from this list.
removeForceUpdateToVersionField(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Remove optimistic read lock from the object See forceUpdateToVersionField(Object)
removeForceUpdateToVersionField(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Remove optimistic read lock from the object See forceUpdateToVersionField(Object)
removeFrom(Object, Object, ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Remove the object from the collection.
removeFrom(Object, Object, Object) - Method in class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
INTERNAL: Remove element from container which implements the Collection interface.
removeFrom(Object, Object, Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Remove element from container.
removeFrom(Object, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Remove the object from the collection.
removeFrom(Object, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Remove element from container which implements the Map interface.
removeFrom(Object, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Remove the object from the collection.
removeFromAtIndex(int, Object) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Remove the element at the specified index.
removeFromCollectionChangeRecord(Object, Object, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Remove a value and its change set from the collection change record.
removeFromIdentityMap(Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Remove the object from the object cache.
removeFromIdentityMap(Object) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Removes the Object from the Object cache.
removeFromIdentityMap(Object, Class<?>) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Remove the object from the object cache.
removeFromIdentityMap(Object, Class<?>) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Removes the Object with given primary key and Class from the Object cache.
removeFromIdentityMap(Object, Class<?>, ClassDescriptor, Object) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Remove the object from the object cache.
removeFromIdentityMap(Object, Class<?>, ClassDescriptor, Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Remove the object from the object cache.
removeFromIdentityMap(Object, Class<?>, ClassDescriptor, Object) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
ADVANCED: Remove the object from the object cache.
removeFromIdentityMap(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Remove object represent this change set from identity map.
removeFromOwningMap() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Removes this cacheKey from the owning map
removeFromOwningMap() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
Removes this cacheKey from the owning map
removeFromValuesToExclude(Object) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: Considers all attributes set to a previously excluded value on the example object.
removeGroupingElement(XPathNode) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
removeGroupingElement(XPathNode) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
INTERNAL:
removeGroupingElement(XPathNode) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
removeIdentitySequences(Session, String, Set<String>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Remove platform specific identity sequences for specified tables.
removeIdentitySequences(Session, String, Set<String>) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
INTERNAL: Remove platform specific identity sequences for specified tables.
removeIf(Predicate<? super E>) - Method in class org.eclipse.persistence.indirection.IndirectList
 
removeIf(Predicate<? super E>) - Method in class org.eclipse.persistence.indirection.IndirectSet
 
removeJavaConversion(Class<?>) - Method in class org.eclipse.persistence.oxm.XMLField
Remove a Java to XML Conversion entry
removeLast() - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
Removes and returns the last contents from this list.
removeLink(LinkedCacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.CacheIdentityMap
Remove the LinkedCacheKey from the linked list.
removeListener(DescriptorEventListener) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: Remove a event listener.
removeListener(SessionEventListener) - Method in class org.eclipse.persistence.sessions.SessionEventManager
PUBLIC: Remove the event listener from the session.
removeLocalConnection() - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
INTERNAL: No-op, as the local connection does not need to be removed from JMSPublishingTransportManager.
removeLocalConnection() - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSTopicTransportManager
INTERNAL: caches local connection, set localConnection to null, closes the cached connection in a new thread.
removeLocalConnection() - Method in class org.eclipse.persistence.sessions.coordination.rmi.RMITransportManager
ADVANCED: Remove the local connection from remote accesses.
removeLocalConnection() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
ADVANCED: Remove the local connection from remote accesses.
removeMappingForAttributeName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Removes the locally defined mapping associated with a given attribute name.
removeNamespace(String) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
 
removeNonIndirectionValues() - Method in class org.eclipse.persistence.internal.sessions.ResultSetRecord
Remove values corresponding to all fields not related to indirection.
removeNullCapableValue(NullCapableValue) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
removeNullCapableValue(NullCapableValue) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
removeNullCapableValue(NullCapableValue) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
removeObject(Class<?>, String) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Remove the object given its class and name.
removeObject(Object, String) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Remove the object given its name.
removeObjectChangeSet(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Add the changed Object's records to the ChangeSet.
removeObjectChangeSetFromNewList(ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Used to remove a new object from the new objects list once it has been inserted and added to the objectChangesList
removeObjectList - Variable in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Contains the removed values from the collection and their corresponding ChangeSets.
removeObjectMap - Variable in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
removeObjectsList - Variable in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
 
removePrivateOwnedObject(DatabaseMapping, Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Remove a privately owned object from the privateOwnedObjects Map.
removeProperty(Object) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Property support used by mappings.
removeProperty(Object) - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: This method is used to remove a custom property from the Connection Policy.
removeProperty(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Remove the user defined property.
removeProperty(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Remove the user defined property.
removeProperty(String) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Some drivers don't like the "user" and "password" properties.
removeProperty(String) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Remove the user defined property.
removeQuery(String) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Remove all queries with the given query name from the set of pre-defined queries
removeQuery(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Remove all queries with the given queryName regardless of the argument types.
removeQuery(String) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Remove the query name from the set of pre-defined queries
removeQuery(String, Vector) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Remove the specific query with the given queryName and argumentTypes.
removeQuery(String, Vector) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Remove the specific query with the given queryName and argumentTypes.
removeRange(int, int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
removeReadLock(ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.ReadLockManager
During normal operation of the concurrency manager, each time a cache key is decrement in the number of readers, so must the corresponding read lock manager of the thread be told let go of the cache key object acquired for reading.
removeReadLockFromReadLockManager() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
The current thread is about to decrement the number of readers in cache key.
removeReadLockManagerIfEmpty(Thread) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Just like we see that the satic map of deffered locks is cleared of cache values for the current thread we also want to try to keep the static map of acquired read locks by a thread light weight by removing the association between the current thread and a read lock manager whenever the read lock manager becomes empty.
removeReadOnlyClass(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Removes a Class from the receiver's set of read-only classes.
removeReadOnlyClass(Class<?>) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Removes a Class from the receiver's set of read-only classes.
removeResultSet() - Method in class org.eclipse.persistence.internal.sessions.ResultSetRecord
 
removeSequence(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Remove sequence corresponding to name.
removeSequence(String) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Remove sequence corresponding to the name (the sequence was added through addSequence method) Don't use if the session is connected.
removeSequence(String) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
Remove sequence corresponding to name.
removeSequencingListener(Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Clears sequencingCallbacks.
RemoveServerSideRemoteValueHolderCommand - Class in org.eclipse.persistence.internal.sessions.remote
Purpose: This class provides an implementation of a RemoteSessionCommand
RemoveServerSideRemoteValueHolderCommand(ObjID) - Constructor for class org.eclipse.persistence.internal.sessions.remote.RemoveServerSideRemoteValueHolderCommand
 
removeTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Remove a table from the statement.
removeTargetQuery - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
Query used to update a single target row changing its foreign key value from the one pointing to the source to null.
removeThreadNoLongerWaitingToAcquireLockForReading(Thread) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
removeThreadNoLongerWaitingToAcquireLockForWriting(Thread) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
The thread has acquired the lock for writing or decided to defer acquiring the lock putting this lock into its deferred lock list.
removeType(String) - Method in class org.eclipse.persistence.dynamic.DynamicHelper
Remove a dynamic type from the system.
removeUnitOfWork(Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Remove the unit of work associated with the transaction passed in.
removeVowels(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Returns a String which has had enough of the specified character removed to be equal to the maximumStringLength.
removeXMLConversion(QName) - Method in class org.eclipse.persistence.oxm.XMLField
Remove an XML to Java Conversion entry
RepeatableWriteUnitOfWork - Class in org.eclipse.persistence.internal.sessions
 
RepeatableWriteUnitOfWork() - Constructor for class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
 
RepeatableWriteUnitOfWork(AbstractSession, ReferenceMode) - Constructor for class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
 
replace() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
replace(Object, Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the string with occurances of the first substring replaced with the second substring.
replace(String, String) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
 
replace(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
 
replace(String, String, String) - Static method in class org.eclipse.persistence.tools.PackageRenamer
Do a search and replace in a string.
replace(K, V) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
replace(K, V, V) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
Replace - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
replaceAll(BiFunction<? super String, ? super String, ? extends String>) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.eclipse.persistence.indirection.IndirectMap
 
replaceAll(UnaryOperator<E>) - Method in class org.eclipse.persistence.indirection.IndirectList
 
replaceAll(UnaryOperator<E>) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
replaceArgumentTypeName(String, String) - Method in class org.eclipse.persistence.internal.codegen.NonreflectiveMethodDefinition
 
replaceAt(Object, int) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: replaces the value at index with value
replaceAt(Object, int) - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
INTERNAL: replaces the value at index with value
replaceAt(Object, int) - Method in class org.eclipse.persistence.internal.sessions.EmptyRecord
 
replaceAt(Object, int) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: replaces the value at index with value
replaceAt(Object, DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: replaces the value at field with value
replaceAt(Object, DatabaseField) - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
INTERNAL: replaces the value at field with value
replaceCollection(List<Field>, List<XMLEntry>, Node, DocumentPreservationPolicy, Field, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XPathEngine
 
replaceCollection(Field, Node, Collection, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XPathEngine
 
replaceDefaultTables() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Drop and recreate the default table schema for the project this session associated with.
replaceDefaultTables(boolean, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Drop and recreate the default table schema for the project this session associated with.
replaceDefaultTables(boolean, boolean, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Drop and recreate the default table schema for the project this session associated with.
replaceException(String, String) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
replaceFirstSubString(String, String, String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Replaces the first subString of the source with the replacement.
replaceInterface(String, String) - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
replaceLine(String, String) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
replaceLocalHostIPAddress(String) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
ADVANCED: Allow user to replace the $HOST subString of the local host URL with the user user input at runtime.
replaceObject(DatabaseObjectDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Use the definition object to drop and recreate the schema entity on the database.
replaceSequences() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
Drop and recreate all the receiver's sequences on the database for all of the loaded descriptors.
replaceTables(DatabaseSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Recreate the tables on the database.
replaceTables(DatabaseSession, SchemaManager) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Recreate the tables on the database.
replaceTables(DatabaseSession, SchemaManager, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Recreate the tables on the database.
replaceTables(DatabaseSession, SchemaManager, boolean, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Recreate the tables on the database.
replaceTablesAndConstraints(SchemaManager, DatabaseSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
 
replaceTablesAndConstraints(SchemaManager, DatabaseSession, boolean, boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
 
replaceTransportPortNumber(String) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
ADVANCED: Allow user to replace the $PORT subString of the local host URL with the user user input at runtime.
replaceValue(Field, Node, Object, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XPathEngine
Replace the value of the nodes matching xpathString with value.
replaceValueHoldersIn(Object) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Traverse the specified object, replacing the standard value holders with remote value holders.
replaceValueHoldersIn(Object, Map) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Traverse the specified object, replacing the standard value holders with remote value holders.
replaceValueHoldersIn(Object, RemoteSessionController) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: replace the value holders in the specified reference object(s)
replaceValueHoldersIn(Object, RemoteSessionController) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: replace the value holders in the specified reference object(s)
replaceValueHoldersIn(Object, RemoteSessionController) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: replace the value holders in the specified reference object(s)
replaceValueHoldersIn(Object, RemoteSessionController) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: replace the value holders in the specified reference object(s)
replaceValueHoldersIn(Object, RemoteSessionController) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: replace the value holders in the specified result object(s)
replaceValueHoldersIn(Object, RemoteSessionController) - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: replace the value holders in the specified result object(s)
replaceValueHoldersIn(Object, RemoteSessionController) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
INTERNAL: replace the value holders in the specified result object(s)
replaceValueHoldersIn(Object, RemoteSessionController) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: replace the value holders in the specified result object(s)
replaceValueHoldersInAll(Object, ContainerPolicy) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Traverse the specified objects, replacing the standard value holders with remote value holders.
ReplaceValueHoldersIterator - Class in org.eclipse.persistence.internal.sessions.remote
Helper class for RemoteSessionController.
ReplaceValueHoldersIterator(RemoteSessionController) - Constructor for class org.eclipse.persistence.internal.sessions.remote.ReplaceValueHoldersIterator
public constructor
replicate() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
replicate(int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: return the result of this query repeated a given number of times.
replicate(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: return the result of this query repeated a given number of times.
Replicate - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
replicateWrites - Variable in class org.eclipse.persistence.descriptors.partitioning.RoundRobinPartitioningPolicy
 
replicateWrites - Variable in class org.eclipse.persistence.descriptors.partitioning.UnionPartitioningPolicy
 
replicateWrites() - Method in annotation type org.eclipse.persistence.annotations.RoundRobinPartitioning
This allows for a set of database to be written to and kept in synch, and have reads load-balanced across the databases.
replicateWrites() - Method in annotation type org.eclipse.persistence.annotations.UnionPartitioning
Defines if write queries should be replicated.
ReplicationPartitioning - Annotation Type in org.eclipse.persistence.annotations
ReplicationPartitioning sends requests to a set of connection pools.
ReplicationPartitioningPolicy - Class in org.eclipse.persistence.descriptors.partitioning
PUBLIC: ReplicationPartitioningPolicy sends requests to a set of connection pools.
ReplicationPartitioningPolicy() - Constructor for class org.eclipse.persistence.descriptors.partitioning.ReplicationPartitioningPolicy
 
ReplicationPartitioningPolicy(String...) - Constructor for class org.eclipse.persistence.descriptors.partitioning.ReplicationPartitioningPolicy
 
ReplicationPartitioningPolicy(List<String>) - Constructor for class org.eclipse.persistence.descriptors.partitioning.ReplicationPartitioningPolicy
 
report() - Method in annotation type org.eclipse.persistence.annotations.QueryRedirectors
A Default ReportQuery Redirector will be applied to any executing ReportQuery that does not have a redirector set directly on the query.
Report - Static variable in class org.eclipse.persistence.config.QueryType
 
REPORT_IGNORED_ELEMENT_CONTENT_WHITESPACE_FEATURE - Static variable in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
REPORT_QUERY_RESULT_SIZE_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
REPORT_RESULT_WITHOUT_PKS - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
reportElementEvents(Element) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
reportElementEvents(Element) - Method in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
 
reportElementEvents(Element, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
ReportItem - Class in org.eclipse.persistence.internal.queries
Purpose: represents an item requested (i.e.
ReportItem() - Constructor for class org.eclipse.persistence.internal.queries.ReportItem
 
ReportItem(String, Expression) - Constructor for class org.eclipse.persistence.internal.queries.ReportItem
 
reportItems - Variable in class org.eclipse.persistence.queries.ConstructorReportItem
 
ReportQuery - Class in org.eclipse.persistence.queries
Purpose: Query for information about a set of objects instead of the objects themselves.
ReportQuery() - Constructor for class org.eclipse.persistence.queries.ReportQuery
INTERNAL: The builder should be provided.
ReportQuery(Class<?>, Expression) - Constructor for class org.eclipse.persistence.queries.ReportQuery
 
ReportQuery(Class<?>, ExpressionBuilder) - Constructor for class org.eclipse.persistence.queries.ReportQuery
PUBLIC: The report query is require to be constructor with an expression builder.
ReportQuery(ExpressionBuilder) - Constructor for class org.eclipse.persistence.queries.ReportQuery
PUBLIC: The report query is require to be constructor with an expression builder.
ReportQueryResult - Class in org.eclipse.persistence.queries
Purpose: A single row (type) result for a ReportQuery
ReportQueryResult(List<Object>, Object) - Constructor for class org.eclipse.persistence.queries.ReportQueryResult
INTERNAL: Used to create test results
ReportQueryResult(ReportQuery, AbstractRecord, Vector) - Constructor for class org.eclipse.persistence.queries.ReportQueryResult
 
ReportQueryResult.EntryIterator - Class in org.eclipse.persistence.queries
Defines the virtual entrySet iterator.
ReportQueryResult.EntrySet - Class in org.eclipse.persistence.queries
Defines the virtual entrySet.
ReportQueryResult.KeyIterator - Class in org.eclipse.persistence.queries
Defines the virtual keySet iterator.
ReportQueryResult.KeySet - Class in org.eclipse.persistence.queries
Defines the virtual keySet.
ReportQueryResult.RecordEntry - Class in org.eclipse.persistence.queries
Entry class for implementing Map interface.
reportQueryResultSizeMismatch(int, int) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
reportQueryResultWithoutPKs(ReportQueryResult) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
REQUIRED - Static variable in class org.eclipse.persistence.internal.oxm.schema.model.Attribute
 
requiresAliases - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Variables used for aliasing and normalizing.
requiresAliases() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Returns true if aliases are required, false otherwise.
requiresAutoCommit - Variable in class org.eclipse.persistence.eis.EISPlatform
Can be used if a commit is required after every interaction outside of a local transaction.
requiresAutoCommit() - Method in class org.eclipse.persistence.eis.EISPlatform
Return if this platform requires auto commit of the local transaction for interactions outside of an interaction.
requiresDataModificationEvents() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Returns whether this ContainerPolicy should requires data modification events when objects are added or deleted during update
requiresDataModificationEvents() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Returns whether this ContainerPolicy requires data modification events when objects are added or deleted during update.
requiresDataModificationEvents() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Returns whether this mapping uses data modification events to complete its writes
requiresDataModificationEvents() - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL: UnidirectionalOneToManyMapping performs some events after INSERT/UPDATE to maintain the keys
requiresDataModificationEventsForMapKey() - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Return whether this mapping requires extra queries to update the rows if it is used as a key in a map.
requiresDataModificationEventsForMapKey() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Return whether this mapping requires extra queries to update the rows if it is used as a key in a map.
requiresDataModificationEventsForMapKey() - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Return whether this mapping requires extra queries to update the rows if it is used as a key in a map.
requiresDataModificationEventsForMapKey() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return whether this mapping requires extra queries to update the rows if it is used as a key in a map.
requiresDeferredLocks - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
When reading across relationships, queries may be set to acquire deferred locks This is used to ensure any Eagerly fetched object that is the target of a relationship with an object the acquires deferred locks behaves the same as its owner
requiresDeferredLocks() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: When reading across relationships, queries may be set to acquire deferred locks This is used to ensure any Eagerly fetched object that is the target of a relationship with an object the acquires deferred locks behaves the same as its owner
requiresDistinct - Variable in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
Used for distincts in functions.
requiresDistinct() - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
If a distinct has been set the DISTINCT clause will be printed.
requiresInitialization(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Aggregate and Interface descriptors do not require initialization as they are cloned and initialized by each mapping.
requiresInitialization(AbstractSession) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: XML descriptors are initialized normally, since they do not need to be cloned by ESI aggregate mappings.
requiresInitialization(AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Aggregates obj-rel are initialized normally as no cloning is required.
requiresInitialization(AbstractSession) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: XML descriptors are initialized normally, since they do not need to be cloned by XML aggregate mappings.
requiresMultipleTableSubclassRead() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return if this descriptor has children that define additional tables and needs to read them.
requiresNamedPrimaryKeyConstraints() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This is used as some databases create the primary key constraint differently, i.e.
requiresNamedPrimaryKeyConstraints() - Method in class org.eclipse.persistence.platform.database.AccessPlatform
This is used as some databases create the primary key constraint differently, i.e.
requiresProcedureBrackets() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for stored procedure creation: Some platforms need brackets around arguments declaration even if no arguments exist.
requiresProcedureBrackets() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
Used for stored procedure creation: MySQL platforms need brackets around arguments declaration even if no arguments exist.
requiresProcedureBrackets() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
In CREATE PROCEDURE, Pervasive requires brackets after the procedure name, even if there are no arguments.
requiresProcedureBrackets() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
requiresProcedureBrackets() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Used for stored procedure creation: Symfoware needs brackets around arguments declaration even if no arguments exist, and so returns true.
requiresProcedureCallBrackets() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
USed for sp calls.
requiresProcedureCallBrackets() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Used for sp calls.
requiresProcedureCallBrackets() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
requiresProcedureCallBrackets() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
USed for sp calls.
requiresProcedureCallBrackets() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
USed for sp calls.
requiresProcedureCallOuputToken() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for sp calls.
requiresProcedureCallOuputToken() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Pervasive requires the OUTPUT keyword for output parameters
requiresProcedureCallOuputToken() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Used for sp calls.
requiresProcedureCallOuputToken() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Used for sp calls.
requiresTableInIndexDropDDL() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Return if this database requires the table name when dropping an index.
requiresTableInIndexDropDDL() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Return if this database requires the table name when dropping an index.
requiresTransientWeavedFields - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Flag used to determine if we need to weave the transient annotation on weaved fields.
requiresTransientWeavedFields() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Returns true if this mappings associated weaved field requires a transient setting to avoid metadata processing.
requiresTypeNameToRegisterOutputParameter() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether the version of CallableStatement.registerOutputParameter method that takes type name should be used.
requiresTypeNameToRegisterOutputParameter() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
INTERNAL: Indicates whether the version of CallableStatement.registerOutputParameter method that takes type name should be used.
requiresTypeNameToRegisterOutputParameter() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Indicates whether the version of CallableStatement.registerOutputParameter method that takes type name should be used.
requiresUniqueConstraintCreationOnTableCreate() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for table creation.
requiresUniqueConstraintCreationOnTableCreate() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
requiresUniqueConstraintCreationOnTableCreate() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Used for table creation.
reset() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Reset the accessor before being released.
reset() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Reset statement count.
reset() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.IndexedAttributeList
 
reset() - Method in class org.eclipse.persistence.internal.oxm.StrBuffer
 
reset() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Reset the JoinedAttributeManager.
reset() - Method in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
 
reset() - Method in class org.eclipse.persistence.queries.CursoredStream
PUBLIC: Repositions this stream to the position at the time the mark method was last called on this stream.
reset(Object) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Reset object attributes to the default values.
reset(Object) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
Reset the wrapper used to store the value.
reset(Object) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
Reset the wrapper used to store the value.
reset(Object) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
Reset the wrapper used to store the value.
reset(Object) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
Reset the wrapper used to store the value.
resetAllConnections() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to reset connections from the session to the database.
resetAllConnections() - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to reset connections from the session to the database.
resetCache() - Method in class org.eclipse.persistence.expressions.Expression
Reset cached information here so that we can be sure we're accurate.
resetCache() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
Reset cached information here so that we can be sure we're accurate.
resetCacheKey(CacheKey, Object, Object, long) - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
Reset the cache key with new data.
resetCacheKey(CacheKey, Object, Object, long) - Method in class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
Avoid acquiring any lock as uow is single threaded.
resetConnections() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: Reset the connections on shutDown and when the pool is started.
resetDefaultManager() - Static method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Reset the default instance.
resetDistinct() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
ADVANCED: If a distinct has been set the DISTINCT clause will be printed.
resetDistinct() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
ADVANCED: If a distinct has been set the DISTINCT clause will be printed.
resetFields() - Method in class org.eclipse.persistence.internal.indirection.BatchValueHolder
Reset all the fields that are not needed after instantiation.
resetFields() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Reset all the fields that are not needed after instantiation.
resetFields() - Method in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
Reset all the fields that are not needed after instantiation.
resetFields() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
Reset all the fields that are not needed after instantiation.
resetFieldTypeForLOB(DirectToFieldMapping) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Reset field type to use BLOB/CLOB with type conversion mapping fix for 4k oracle thin driver bug.
resetMonitorName() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return the name to use for the query in performance monitoring.
resetMonitorName() - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
INTERNAL: Return the name to use for the query in performance monitoring.
resetOperators() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Reset all the operators.
resetPlaceHolderBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Search the tree for any expressions (like SubSelectExpressions) that have been built using a builder that is not attached to the query.
resetPlaceHolderBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Search the tree for any expressions (like SubSelectExpressions) that have been built using a builder that is not attached to the query.
resetPlaceHolderBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.internal.expressions.BaseExpression
INTERNAL: Search the tree for any expressions (like SubSelectExpressions) that have been built using a builder that is not attached to the query.
resetPlaceHolderBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: Search the tree for any expressions (like SubSelectExpressions) that have been built using a builder that is not attached to the query.
resetPlaceHolderBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: Search the tree for any expressions (like SubSelectExpressions) that have been built using a builder that is not attached to the query.
resetPlaceHolderBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Search the tree for any expressions (like SubSelectExpressions) that have been built using a builder that is not attached to the query.
resetPlaceHolderBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
INTERNAL: Search the tree for any expressions (like SubSelectExpressions) that have been built using a builder that is not attached to the query.
resetPlaceHolderBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Search the tree for any expressions (like SubSelectExpressions) that have been built using a builder that is not attached to the query.
resetPlaceHolderBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
INTERNAL: Search the tree for any expressions (like SubSelectExpressions) that have been built using a builder that is not attached to the query.
resetQualifiedName() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
resetQualifiedName(String) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Reset the field's name and table from the qualified name.
resetSequencing() - Method in interface org.eclipse.persistence.sequencing.SequencingControl
ADVANCED: Immediately re-create sequencing object.
resetSize() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
Reset the row size.
resetStatementFromCall(Statement, DatabaseCall) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Reset the Query Timeout, Max Rows, Resultset fetch size on the Statement if the DatabaseCall has values which differ from the default settings.
resetStringBuffer() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
resetStringBuffer() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
resetStringBuffer() - Method in class org.eclipse.persistence.internal.oxm.XMLInlineBinaryHandler
 
resetStringBuffer() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
resetTransformedFieldType(TransformationMapping) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Reset the transformation mapping field types
resolutionClassNotFoundException - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
resolutionClassNotFoundException(String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
resolutionClassNotFoundException2 - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
resolutionClassNotFoundException2(String, int, int, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
resolve(Object, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.IDResolver
Resolve the object of Class type, uniquely identified by id.
resolve(Map<String, Object>, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.IDResolver
Resolve the object of Class type, uniquely identified by the composite key information specified in the id Map.
resolveClass(ObjectStreamClass) - Method in class org.eclipse.persistence.internal.helper.CustomObjectInputStream
 
resolveDatabaseField(DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Resolve the foreign key database field metadata in relation table or direct collection/map table.
resolveEntity(String, String) - Method in class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
INTERNAL:
resolveNamespacePrefix(String) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
Returns the namespace URI associated with a specified namespace prefix
resolveNamespacePrefix(String) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
resolveNamespacePrefix(String) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
resolveNamespacePrefix(String) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractUnmarshalRecord
 
resolveNamespacePrefix(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
resolveNamespacePrefix(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
Convenience method that iterates over each namespace resolver in the resolver list until it locates a uri for 'prefix' or the final resolver is reached w/o success.
resolveNamespacePrefix(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLTransformationRecord
 
resolveNamespacePrefix(String) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
 
resolveNamespacePrefix(String) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
resolveNamespacePrefix(String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
resolveNamespacePrefix(String) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
resolveNamespacePrefix(String) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
resolveNamespacePrefix(String) - Method in interface org.eclipse.persistence.platform.xml.XMLNamespaceResolver
 
resolveNamespacePrefix(XPathFragment, NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
 
resolveNamespacePrefix(Node, String) - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
Return the namespace URI for the specified namespace prefix relative to the context node.
resolveNamespaceUri(String) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
resolveNamespaceUri(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
resolveNamespaceUri(String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
resolveNamespaceURI(String) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
Return the namespace prefix associated with a namespace URI.
resolveNamespaceURI(String) - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.PrefixMapperNamespaceResolver
 
resolvePrimaryNamespace() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
resolver - Variable in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
resolveReferences() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
INTERNAL: Resolve any mapping references.
resolveReferences(ABSTRACT_SESSION, ID_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
resolveReferences(CoreAbstractSession, IDResolver) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
INTERNAL: If the UnmarshalRecord has a ReferenceResolver, tell it to resolve its references.
resolveReferences(CoreAbstractSession, IDResolver, ErrorHandler) - Method in class org.eclipse.persistence.internal.oxm.ReferenceResolver
INTERNAL: Iterates through all references.
resolveReferences(CoreAbstractSession, IDResolver) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: If the UnmarshalRecord has a ReferenceResolver, tell it to resolve its references.
resolveReferences(AbstractSession, IDResolver) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
resolveSecondaryNamespace() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
resource - Variable in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
The string used to access the XMLSchema, be it classpath resource, URL, or file name
RESOURCE_EXCEPTION - Static variable in exception org.eclipse.persistence.eis.EISException
 
resourceException(ResourceException, EISAccessor, AbstractSession) - Static method in exception org.eclipse.persistence.eis.EISException
 
resourceException(ResourceException, Call, EISAccessor, AbstractSession) - Static method in exception org.eclipse.persistence.eis.EISException
 
resourceException(Exception, EISAccessor, AbstractSession) - Static method in exception org.eclipse.persistence.eis.EISException
 
resourceName - Variable in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
 
resourcePath - Variable in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
Stores the resource path to provide a better error message if the load fails.
RESPONSE_COULD_NOT_BE_BUILT_FOR_FIND_ATTRIBUTE_REQUEST - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
RESPONSE_COULD_NOT_BE_BUILT_FOR_NAMED_QUERY_REQUEST - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
Restrictable - Interface in org.eclipse.persistence.internal.oxm.schema.model
 
Restriction - Class in org.eclipse.persistence.internal.oxm.schema.model
 
Restriction() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
Restriction(String) - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
result - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
result - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
result - Variable in class org.eclipse.persistence.internal.expressions.ExpressionIterator
Allow the iteration to build a result.
result - Variable in class org.eclipse.persistence.queries.ComplexQueryResult
 
result - Variable in class org.eclipse.persistence.queries.ModifyAllQuery
Number of modified objects
result - Variable in class org.eclipse.persistence.sessions.SessionEvent
Some events may have a result associated with them (pre/postExecuteQuery).
RESULT_COLLECTION_TYPE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.result-collection-type"
RESULT_DOES_NOT_EXIST_FOR_OPERATION - Static variable in exception org.eclipse.persistence.exceptions.DBWSException
 
RESULT_HAS_NO_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.DBWSException
 
RESULT_SET_ACCESS - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.result-set-access"
RESULT_SET_ACCESS_OPTIMIZATION_IS_NOT_POSSIBLE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
RESULT_SET_CONCURRENCY - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.cursor.scrollable.result-set-concurrency"
RESULT_SET_TYPE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.cursor.scrollable.result-set-type"
RESULT_TYPE - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.result-type"
resultClass() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredProcedureQuery
Deprecated. 
resultClass() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredProcedureQuery
(Optional) Refers to the class of the result.
resultClasses() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredProcedureQuery
(Optional) Refers to the classes of the result.
resultDoesNotExistForOperation(String, String) - Static method in exception org.eclipse.persistence.exceptions.DBWSException
INTERNAL: Exception when processing DBWS metadata and the descriptor cannot be located for the operation
resultHasNoMapping(String, String) - Static method in exception org.eclipse.persistence.exceptions.DBWSException
INTERNAL: Exception when processing DBWS metadata and the descriptor cannot be located for the operation
resultIndex - Variable in class org.eclipse.persistence.internal.queries.ReportItem
Stores the row index for this item, given multiple results and joins
resultRows - Variable in class org.eclipse.persistence.queries.ResultSetMappingQuery
 
results - Variable in class org.eclipse.persistence.queries.ReportQueryResult
Actual converted attribute values
results - Variable in class org.eclipse.persistence.queries.SQLResultSetMapping
Stores the list of SQLResult in the order they were added to the Mapping
resultSet - Variable in class org.eclipse.persistence.internal.sessions.ResultSetRecord
 
resultSet - Variable in class org.eclipse.persistence.queries.Cursor
The result set (cursor) that holds the handle to the database that the results are read from.
resultSetAccessOptimizationIsNotPossible(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
resultSetConcurrency - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
resultSetConcurrency - Variable in class org.eclipse.persistence.queries.ScrollableCursorPolicy
 
ResultSetConcurrency - Class in org.eclipse.persistence.config
JDBC ResultSet concurrency hint values.
ResultSetConcurrency() - Constructor for class org.eclipse.persistence.config.ResultSetConcurrency
 
resultSetFetchSize - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
resultSetMapping() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredFunctionQuery
(Optional) The name of the SQLResultMapping.
resultSetMapping() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredProcedureQuery
Deprecated. 
resultSetMapping() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredFunctionQuery
(Optional) The name of the SQLResultMapping.
resultSetMapping() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredProcedureQuery
(Optional) The name of the SQLResultMapping.
ResultSetMapping - Static variable in class org.eclipse.persistence.config.QueryType
 
resultSetMappingNames - Variable in class org.eclipse.persistence.queries.ResultSetMappingQuery
 
ResultSetMappingQuery - Class in org.eclipse.persistence.queries
Purpose: Concrete class to perform read using raw SQL and the SQLResultSetMapping.
ResultSetMappingQuery() - Constructor for class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: Initialize the state of the query.
ResultSetMappingQuery(Call) - Constructor for class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: Initialize the query to use the specified call.
ResultSetMappingQuery(Call, String) - Constructor for class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: Initialize the query to use the specified call and SQLResultSetMapping
resultSetMappings - Variable in class org.eclipse.persistence.queries.ResultSetMappingQuery
 
resultSetMappings() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredProcedureQuery
(Optional) The names of the SQLResultMappings.
ResultSetRecord - Class in org.eclipse.persistence.internal.sessions
PERF: Record used by ObjectLevelReadQuery ResultSet optimization.
ResultSetRecord() - Constructor for class org.eclipse.persistence.internal.sessions.ResultSetRecord
 
ResultSetRecord(Vector, DatabaseField[], ResultSet, ResultSetMetaData, DatabaseAccessor, AbstractSession, DatabasePlatform, boolean) - Constructor for class org.eclipse.persistence.internal.sessions.ResultSetRecord
 
resultSetType - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
resultSetType - Variable in class org.eclipse.persistence.queries.ScrollableCursorPolicy
 
ResultSetType - Class in org.eclipse.persistence.config
JDBC ResultSet type hint values.
resultType - Variable in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
resultType - Variable in class org.eclipse.persistence.internal.queries.ReportItem
Result type for this report item.
resultType - Variable in class org.eclipse.persistence.queries.DataReadQuery
Allow return type to be configured, MAP, ARRAY, VALUE, ATTRIBUTE (MAP is the default, i.e.
ResultType - Class in org.eclipse.persistence.config
Result type hint values.
ResultType() - Constructor for class org.eclipse.persistence.config.ResultType
 
resumeOnTransactionCompletion - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
True if UnitOfWork should be resumed on completion of transaction.
resumeUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
INTERNAL: Resume is not required on the server.
resumeUnitOfWork() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Resume the unit of work state after a flush, or resume operation.
retainAll(Collection) - Method in class org.eclipse.persistence.internal.helper.IdentityHashSet
This implementation throws an UnsupportedOperationException.
retainAll(Collection) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
retainAll(Collection<?>) - Method in class org.eclipse.persistence.indirection.IndirectList
 
retainAll(Collection<?>) - Method in class org.eclipse.persistence.indirection.IndirectSet
 
retainAll(Collection<?>) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
retainAll(Collection<?>) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
retrieveBypassCache() - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: JPA flag used to control the behavior of the shared cache.
retrieveCacheKey(Object, ClassDescriptor, JoinedAttributeManager, ObjectBuildingQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
 
retrieveFirstPrimaryKeyOrOne(ReportQuery) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Used by Exists queries because they just need to select a single row.
retrieveFirstPrimaryKeyOrOne(ReportQuery) - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
INTERNAL: Used by Exists queries because they just need to select a single row.
retrieveNextObject() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
INTERNAL: This method differs slightly from conventional read() operation on a Java stream.
retrieveNextObject() - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Read the next row from the result set.
retrieveNextObject() - Method in class org.eclipse.persistence.queries.CursoredStream
 
retrieveNextObject() - Method in class org.eclipse.persistence.queries.ScrollableCursor
INTERNAL: Read the next row from the result set.
retrieveNextPage() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteCursoredStream
Read the next page of objects from the server.
retrieveNextPage() - Method in class org.eclipse.persistence.queries.CursoredStream
INTERNAL: Retrieve and add the next page size of rows to the vector.
retrievePreviousObject() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteScrollableCursor
INTERNAL: CR#4139 Read the previous row from the result set.
retrievePreviousObject() - Method in class org.eclipse.persistence.queries.ScrollableCursor
INTERNAL: CR#4139 Read the previous row from the result set.
retrievePrimaryKeys() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Set if the query results should contain the primary keys or each associated object.
retrieveTimeFrom - Variable in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
 
retryQuery(DatabaseQuery, AbstractRecord, DatabaseException, int, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: A query execution failed due to an invalid query.
retryQuery(DatabaseQuery, AbstractRecord, DatabaseException, int, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: A query execution failed due to an invalid query.
retryQuery(DatabaseQuery, AbstractRecord, DatabaseException, int, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: A query execution failed due to an invalid query.
retryQuery(DatabaseQuery, AbstractRecord, DatabaseException, int, AbstractSession) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: A query execution failed due to an invalid query.
retryQuery(DatabaseQuery, AbstractRecord, DatabaseException, int, AbstractSession) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: A query execution failed due to an invalid query.
retryTransaction(Accessor, DatabaseException, int, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: A begin transaction failed.
retryTransaction(Accessor, DatabaseException, int, AbstractSession) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: A begin transaction failed.
RETURN_AND_MAPPING_WITH_INDIRECTION_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
RETURN_AND_MAPPING_WITH_TRANSPARENT_INDIRECTION_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
RETURN_AND_MAPPING_WITHOUT_INDIRECTION_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
RETURN_CURSOR - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
RETURN_MANY_ROWS - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
RETURN_NAME_VALUE_PAIRS - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.query-return-name-value-pairs"
RETURN_ONE_ROW - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
RETURN_ONLY - Static variable in class org.eclipse.persistence.descriptors.ReturningPolicy
 
RETURN_TYPE_IN_GET_ATTRIBUTE_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
returnAndMappingWithIndirectionMismatch(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
returnAndMappingWithoutIndirectionMismatch(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
returnAndMappingWithTransparentIndirectionMismatch(DatabaseMapping, Class<?>, String) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
returnChoice - Variable in class org.eclipse.persistence.queries.ReportQuery
Can be one of (ShouldReturnSingleResult, ShouldReturnSingleValue, ShouldReturnSingleAttribute) Simplifies the result by only returning the first result, first value, or all attribute values
returnCursor() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Cursor return is used for cursored streams.
returnedKeys - Variable in class org.eclipse.persistence.queries.ReportQuery
 
returnFields - Variable in class org.eclipse.persistence.internal.expressions.SQLModifyStatement
 
returnFieldsToGenerateInsert - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
returnFieldsToGenerateUpdate - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
returnFieldsToMergeInsert - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
returnFieldsToMergeUpdate - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
RETURNING_POLICY_AND_DESCRIPTOR_FIELD_TYPE_CONFLICT - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
RETURNING_POLICY_FIELD_INSERT_CONFLICT - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
RETURNING_POLICY_FIELD_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
RETURNING_POLICY_FIELD_TYPE_CONFLICT - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
RETURNING_POLICY_MAPPED_FIELD_TYPE_NOT_SET - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
RETURNING_POLICY_MAPPING_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
RETURNING_POLICY_UNMAPPED_FIELD_TYPE_NOT_SET - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
returningPolicies - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
returningPolicy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
ReturningPolicy - Class in org.eclipse.persistence.descriptors
Purpose: Allows for INSERT or UPDATE operations to return values back into the object being written.
ReturningPolicy() - Constructor for class org.eclipse.persistence.descriptors.ReturningPolicy
 
ReturningPolicy.Info - Class in org.eclipse.persistence.descriptors
INTERNAL:
returningPolicyAndDescriptorFieldTypeConflict(String, String, String, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
returningPolicyFieldInsertConflict(String, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
returningPolicyFieldNotSupported(String, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
returningPolicyFieldTypeConflict(String, String, String, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
returningPolicyMappedFieldTypeNotSet(String, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
returningPolicyMappingNotSupported(String, String, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
returningPolicyUnmappedFieldTypeNotSet(String, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
ReturnInsert - Annotation Type in org.eclipse.persistence.annotations
A ReturnInsert annotation allows for INSERT operations to return values back into the object being written.
returnManyRows() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Many rows are returned for read-all queries.
returnMapEntry - Variable in class org.eclipse.persistence.internal.expressions.MapEntryExpression
 
returnMapEntry() - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
Set this expression to represent a Map.Entry rather than the Map's key
returnMultipleResultSetCollections - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Support returning multiple results sets instead of just one list, i.e.
returnMultipleResultSetCollections() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Return true if the multiple results 'lists' should be returned.
returnNameValuePairs - Variable in class org.eclipse.persistence.queries.ResultSetMappingQuery
 
returnNewFileNameIfRequired(String) - Method in class org.eclipse.persistence.tools.PackageRenamer
Renames a file based on the properties passed.
returnNothing() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
No return is used for modify calls like insert / update / delete.
returnOneRow() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
One row is returned for read-object queries.
returnOnly() - Method in annotation type org.eclipse.persistence.annotations.ReturnInsert
Set return only to true if you want the mapping field to be excluded from the INSERT clause during SQL generation.
returnParameter() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredFunctionQuery
(Required) Defines the return value of the stored function.
returnParameter() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredFunctionQuery
(Required) Defines the return value of the stored function.
returnSingleAttribute() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplify the result by returning a single attribute.
returnSingleResult() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by only returning the first result.
returnSingleValue() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by only returning a single value.
returnsResultSet - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
returnsResultSet() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredProcedureQuery
(Optional) Defines if stored procedure returns a result set.
returnType - Variable in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
returnType - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
returnType - Variable in class org.eclipse.persistence.internal.expressions.SubSelectExpression
 
returnTypeInGetAttributeAccessor(String, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
ReturnUpdate - Annotation Type in org.eclipse.persistence.annotations
A ReturnUpdate annotation allows for UPDATE operations to return values back into the object being written.
returnWithoutReportQueryResult() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by only returning a single value.
reuseContainer - Variable in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
reuseJMSTopicPublisher - Variable in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
 
reverse() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function return the reverse of the query result.
reverse() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
Reverse - Static variable in class org.eclipse.persistence.config.ResultSetType
The rows in a result set will be processed in a reverse direction; last-to-first.
Reverse - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
reverseVector(Vector<T>) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
revertAndResume() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Revert all changes made to any registered object.
revertAndResume() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Revert all changes made to any registered object.
revertChanges(Object, ClassDescriptor, UnitOfWorkImpl, Map, boolean) - Method in class org.eclipse.persistence.descriptors.changetracking.AttributeChangeTrackingPolicy
INTERNAL: Clear the change set in the change event listener.
revertChanges(Object, ClassDescriptor, UnitOfWorkImpl, Map, boolean) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: This method is used to revert an object within the unit of work
revertChanges(Object, ClassDescriptor, UnitOfWorkImpl, Map, boolean) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: This method is used to revert an object within the unit of work
revertObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Revert the object's attributes from the parent.
revertObject(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Revert the object's attributes from the parent.
revertObject(Object, int) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Revert the object's attributes from the parent.
right() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
right(int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function return a given number of characters starting at the right of a string.
right(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function return a given number of characters starting at the right of a string.
Right - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
RIGHT_BRACE - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
Right brace.
RIGHT_BRACKET - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
Right bracket.
rightPad() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
rightPad(int, Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the string padded with the substring to the size.
rightPad(Object, Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the string padded with the substring to the size.
RightPad - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
rightTrim() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the string right trimmed for white space.
rightTrim() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
rightTrim() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
INTERNAL: Build FB equivalent to LTRIM(string_exp).
rightTrim() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the string right trimmed for white space.
Builds Symfoware equivalent to RTRIM(character).
Symfoware: TRIM(TRAILING FROM string_exp)
rightTrim(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the string with the substring trimed from the right.
RightTrim - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
rightTrim2() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build rightTrim operator that takes one parameter.
rightTrim2() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
INTERNAL: Build FB equivalent to RTRIM(string_exp, character).
rightTrim2() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
INTERNAL: Build HSQL equivalent to RTRIM(string_exp, character).
rightTrim2() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Build MySQL equivalent to RTRIM(string_exp, character).
rightTrim2() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the string right trimmed for white space.
Builds Symfoware equivalent to RTRIM(string_exp, character).
Symfoware: TRIM(TRAILING character FROM string_exp)
RightTrim2 - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
rightTrimString(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Returns a new string with all space characters removed from the right
RMI - Static variable in class org.eclipse.persistence.config.CacheCoordinationProtocol
 
RMI - Static variable in class org.eclipse.persistence.config.RemoteProtocol
 
RMIConnection - Class in org.eclipse.persistence.sessions.remote.rmi
This class exists on on the client side which talks to remote session controller through RMI connection.
RMIConnection(RMIRemoteSessionController) - Constructor for class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
PUBLIC: The connection must be create from the server-side session controllers stub.
RMIIIOP - Static variable in class org.eclipse.persistence.config.CacheCoordinationProtocol
 
RMIIIOPTransportManagerConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.transport
INTERNAL:
RMIIIOPTransportManagerConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.transport.RMIIIOPTransportManagerConfig
 
RMIRegistryNamingServiceConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.transport.naming
INTERNAL:
RMIRegistryNamingServiceConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.RMIRegistryNamingServiceConfig
 
RMIRemoteCommandConnection - Interface in org.eclipse.persistence.internal.sessions.coordination.rmi
Purpose: The interface for the remote RMI object used for transporting the remote command.
RMIRemoteCommandConnectionImpl - Class in org.eclipse.persistence.internal.sessions.coordination.rmi
Purpose: The implementation for the remote RMI object used for transporting the remote command.
RMIRemoteCommandConnectionImpl(RemoteCommandManager) - Constructor for class org.eclipse.persistence.internal.sessions.coordination.rmi.RMIRemoteCommandConnectionImpl
 
RMIRemoteConnection - Class in org.eclipse.persistence.internal.sessions.coordination.rmi
Purpose: Define an RMI implementation class for the remote object that can execute a remote command.
RMIRemoteConnection(RMIRemoteCommandConnection) - Constructor for class org.eclipse.persistence.internal.sessions.coordination.rmi.RMIRemoteConnection
 
RMIRemoteSessionController - Interface in org.eclipse.persistence.sessions.remote.rmi
Defines the public methods remote connection can invoke on the remote session controller.
RMIRemoteSessionControllerDispatcher - Class in org.eclipse.persistence.sessions.remote.rmi
RemoteSessionController sits between the remote session and the session.
RMIRemoteSessionControllerDispatcher(AbstractSession) - Constructor for class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
 
RMIRemoteSessionControllerDispatcher(Session) - Constructor for class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
 
RMIServerSessionManager - Interface in org.eclipse.persistence.sessions.remote.rmi
 
RMIServerSessionManagerDispatcher - Class in org.eclipse.persistence.sessions.remote.rmi
 
RMIServerSessionManagerDispatcher(Session) - Constructor for class org.eclipse.persistence.sessions.remote.rmi.RMIServerSessionManagerDispatcher
 
RMITransportManager - Class in org.eclipse.persistence.sessions.coordination.rmi
Purpose: Provide an RMI transport implementation for RCM.
RMITransportManager(RemoteCommandManager) - Constructor for class org.eclipse.persistence.sessions.coordination.rmi.RMITransportManager
 
RMITransportManagerConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.transport
INTERNAL:
RMITransportManagerConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.transport.RMITransportManagerConfig
 
rollbackExternalTransaction() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PROTECTED: Attempts to rollback the running internally started external transaction.
rollbackTransaction() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Rollback the active database transaction.
rollbackTransaction() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Rollback a transaction on the database.
rollbackTransaction() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Rollback a transaction on the database.
rollbackTransaction() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: This is internal to the uow, transactions should not be used explicitly in a uow.
rollbackTransaction() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This is internal to the uow, transactions should not be used explicitly in a uow.
rollbackTransaction() - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Rollback the active database transaction.
rollbackTransaction() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Rollback a transaction on the server.
rollbackTransaction() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Rollback a transaction on the database.
rollbackTransaction() - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Rollback a transaction on the database.
rollbackTransaction() - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Rollback a transaction on the database.
rollbackTransaction(boolean) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: This is internal to the uow, transactions should not be used explicitly in a uow.
rollbackTransaction(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: rollbackTransaction() with a twist for external transactions.
rollbackTransaction(DatabaseAccessor) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for jdbc drivers which do not support autocommit to explicitly rollback a transaction This method is a no-op for databases which implement autocommit as expected.
rollbackTransaction(AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Roll back a transaction on the data store.
rollbackTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Rollback a transaction on the database.
rollbackTransaction(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Rollback the transaction on the datasource.
rollbackTransaction(AbstractSession) - Method in interface org.eclipse.persistence.sessions.ExternalTransactionController
INTERNAL: Rollback a transaction externally.
rollbackTransaction(AbstractSession) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Roll back the external transaction.
rollbackTransaction_impl() - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Roll back the external transaction.
rollbackTransaction_impl() - Method in class org.eclipse.persistence.transaction.JTATransactionController
INTERNAL: Roll back the external transaction.
Root - Class in org.eclipse.persistence.internal.oxm
Root is used to hold an Object along with the corresponding QName and some other related information.
Root() - Constructor for class org.eclipse.persistence.internal.oxm.Root
Default constructor.
rootElementLocalName - Variable in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
rootElementName - Variable in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
rootElementNamespaceUri - Variable in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
rootEntity - Variable in class org.eclipse.persistence.queries.FetchGroup
Stores a reference to the root entity for an Aggregate Object relationship.
rootObject - Variable in class org.eclipse.persistence.internal.oxm.Root
 
rootParentDescriptor - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
PERF: Cache root descriptor.
round() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
round(Expression, int) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
round(Expression, Object) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Round - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
roundDate() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
roundDate() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the date rounded to the year, month or day.
Builds Symfoware equivalent to ROUNDDATE(Date, rounded).
Symfoware: ROUND_DATE(Date, rounded)
roundDate(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the date rounded to the year, month or day.
RoundDate - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
RoundRobinPartitioning - Annotation Type in org.eclipse.persistence.annotations
RoundRobinPartitioning sends requests in a round robin fashion to the set of connection pools.
RoundRobinPartitioningPolicy - Class in org.eclipse.persistence.descriptors.partitioning
PUBLIC: RoundRobinPartitioningPolicy sends requests in a round robin fashion to the set of connection pools.
RoundRobinPartitioningPolicy() - Constructor for class org.eclipse.persistence.descriptors.partitioning.RoundRobinPartitioningPolicy
 
RoundRobinPartitioningPolicy(boolean) - Constructor for class org.eclipse.persistence.descriptors.partitioning.RoundRobinPartitioningPolicy
 
RoundRobinPartitioningPolicy(String...) - Constructor for class org.eclipse.persistence.descriptors.partitioning.RoundRobinPartitioningPolicy
 
RoundRobinPartitioningPolicy(List<String>) - Constructor for class org.eclipse.persistence.descriptors.partitioning.RoundRobinPartitioningPolicy
 
row - Variable in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Stores the row representation of the object.
rowCollection - Variable in class org.eclipse.persistence.internal.sessions.TransformationMappingChangeRecord
 
RowFetch - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
rowFromArguments(List, AbstractSession) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Translate argumentValues into a database row.
rtrim2Operator() - Method in class org.eclipse.persistence.platform.database.DB2Platform
DB2 does not support untyped parameter binding for <operand2>
rtrim2Operator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
rtrim2Operator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Enable binding since DB2 disables it
rtrimOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedClassForName
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetClassLoaderForClass
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetClassLoaderFromCurrentThread
INTERNAL: Performs current Thread context ClassLoader retrieval.
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetConstructorFor
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetContextClassLoader
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetDeclaredConstructorFor
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetDeclaredField
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetDeclaredFields
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetDeclaredMethod
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetDeclaredMethods
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetField
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetFields
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetFieldType
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetMethod
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetMethodParameterTypes
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetMethodReturnType
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetMethods
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetSystemProperty
INTERNAL: Performs System property retrieval.
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetThreadInfo
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedGetValueFromField
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedInvokeConstructor
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedMethodInvoker
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedNewInstanceFromClass
 
run() - Method in class org.eclipse.persistence.internal.security.PrivilegedSetValueInField
 
run() - Method in class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
INTERNAL: This is the execution method of the async propagation thread.
run() - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: This method is used by local (listening) connection only.
run() - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
INTERNAL: This is the main execution method of discovery.
run() - Method in class org.eclipse.persistence.tools.PackageRenamer
This run() method performs, reading the properties file into properties variable to be a reference for changing package name.
runSearchAndReplacePackageName(File) - Method in class org.eclipse.persistence.tools.PackageRenamer
This runSearchAndReplacePackageName() reads a pre-rename source file all into string variable and replacing the old package names with the new ones according to the properties file.
RuntimeServices - Class in org.eclipse.persistence.services
Purpose: Provide a dynamic interface into the EclipseLink Session.
RuntimeServices() - Constructor for class org.eclipse.persistence.services.RuntimeServices
Default Constructor
RuntimeServices(Session) - Constructor for class org.eclipse.persistence.services.RuntimeServices
Constructor

S

Safe - Static variable in class org.eclipse.persistence.config.TunerType
 
SafeModeTuner - Class in org.eclipse.persistence.tools.tuning
Configures the persistence unit for debugging.
SafeModeTuner() - Constructor for class org.eclipse.persistence.tools.tuning.SafeModeTuner
 
SAME_PROPERTY_IN_MULTIPLE_BINDINGS_FILES - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
samePropertyInMultipleFiles(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
SAPNetWeaver_7_1 - Static variable in class org.eclipse.persistence.config.TargetServer
 
SAPNetWeaverTransactionController - Class in org.eclipse.persistence.transaction.sap
TransactionController implementation for SAP NetWeaver AS Java 7.1 (including EhP 1), 7.2 and follow-up releases.
SAPNetWeaverTransactionController() - Constructor for class org.eclipse.persistence.transaction.sap.SAPNetWeaverTransactionController
Default constructor.
SAPNetWeaverTransactionController(TransactionManager) - Constructor for class org.eclipse.persistence.transaction.sap.SAPNetWeaverTransactionController
 
saveRemoteValueHolder(RemoteValueHolder) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Save the pre-serialized version of the remote value holder so that it can be used when the serialized version (on the client) is instantiated and needs to come back to the server to get its "value".
saveRemoteValueHolder(RemoteValueHolder) - Method in class org.eclipse.persistence.internal.sessions.remote.ReplaceValueHoldersIterator
save the remote value holder for later use
SAXDocumentBuilder - Class in org.eclipse.persistence.platform.xml
Purpose: Build a DOM from SAX events.
SAXDocumentBuilder() - Constructor for class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
SAXFragmentBuilder - Class in org.eclipse.persistence.internal.oxm
 
SAXFragmentBuilder(UnmarshalRecord) - Constructor for class org.eclipse.persistence.internal.oxm.SAXFragmentBuilder
 
SAXPlatform - Class in org.eclipse.persistence.oxm.platform
 
SAXPlatform() - Constructor for class org.eclipse.persistence.oxm.platform.SAXPlatform
 
SAXUnmarshaller - Class in org.eclipse.persistence.internal.oxm.record
INTERNAL:
SAXUnmarshaller(Unmarshaller, Map<String, Boolean>) - Constructor for class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
SAXUnmarshallerHandler - Class in org.eclipse.persistence.internal.oxm.record
INTERNAL:
SAXUnmarshallerHandler(Context) - Constructor for class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
scale - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
Variables used for generating DDL
scale - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
scale() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLParameter
(Optional) If a numeric, the max scale value.
scanForConformingInstances(Expression, Class<?>, AbstractRecord, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Scans the UnitOfWork identity map for conforming instances.
schema() - Method in annotation type org.eclipse.persistence.annotations.CollectionTable
Deprecated.
(Optional) The schema of the table.
schema() - Method in annotation type org.eclipse.persistence.annotations.Index
The schema of the INDEX
schema() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlVirtualAccessMethods
(Optional) Configure the way that virtual properties will appear in generated schemas.

XmlExtensibleSchema.NODES (default) - Virtual properties will appear as individual nodes
XmlExtensibleSchema.ANY - An XSD <any> element will be written to the schema to represent all of the defined virtual properties
Schema - Class in org.eclipse.persistence.internal.oxm.schema.model
 
Schema() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
SCHEMA - org.eclipse.persistence.annotations.TenantTableDiscriminatorType
Apply the tenant table discriminator as a schema to all multitenant tables.
SCHEMA_DATABASE_MAJOR_VERSION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
If sufficient database version information is not included from the JDBC DatabaseMetaData method getDatabaseProductName, the "jakarta.persistence.database-major-version" property should be specified as needed.
SCHEMA_DATABASE_MINOR_VERSION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
If sufficient database version information is not included from the JDBC DatabaseMetaData method getDatabaseProductName, the "jakarta.persistence.database-minor-version" property should be specified as needed.
SCHEMA_DATABASE_PRODUCT_NAME - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
If scripts are to be generated by the persistence provider and a connection to the target database is not supplied, the "jakarta.persistence.database-product-name" property must be specified.
SCHEMA_DIR - Static variable in class org.eclipse.persistence.sessions.factories.XMLProjectReader
 
SCHEMA_FILE_EXT - Static variable in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
 
SCHEMA_FILE_NAME - Static variable in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
 
SCHEMA_GENERATION_CONNECTION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.schema-generation.connection" property specifies the JDBC connection to be used for schema generation.
SCHEMA_GENERATION_CREATE_ACTION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "create"
SCHEMA_GENERATION_CREATE_DATABASE_SCHEMAS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
In Java EE environments, it is anticipated that the Java EE platform provider may wish to control the creation of database schemas rather than delegate this task to the persistence provider.
SCHEMA_GENERATION_CREATE_SCRIPT_SOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.schema-generation.create-script-source" is used for script execution.
SCHEMA_GENERATION_CREATE_SOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.schema-generation.create-source" property specifies whether the creation of database artifacts is to occur on the basis of the object/relational mapping metadata, DDL script, or a combination of the two.
SCHEMA_GENERATION_DATABASE_ACTION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.schema-generation.database.action" property specifies the action to be taken by the persistence provider with regard to the database artifacts.
SCHEMA_GENERATION_DROP_ACTION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "drop"
SCHEMA_GENERATION_DROP_AND_CREATE_ACTION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "drop-and-create"
SCHEMA_GENERATION_DROP_SCRIPT_SOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.schema-generation.drop-script-source" is used for script execution.
SCHEMA_GENERATION_DROP_SOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.schema-generation.drop-source" property specifies whether the dropping of database artifacts is to occur on the basis of the object/relational mapping metadata, DDL script, or a combination of the two.
SCHEMA_GENERATION_METADATA_SOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "metadata"
SCHEMA_GENERATION_METADATA_THEN_SCRIPT_SOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "metadata-then-script"
SCHEMA_GENERATION_NONE_ACTION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "none"
SCHEMA_GENERATION_SCRIPT_SOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "script"
SCHEMA_GENERATION_SCRIPT_TERMINATE_STATEMENTS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
When the "eclipselink.ddlgen-terminate-statements" property is set to true and a DDL script is being generated, the value of DatabasePlatform.getStoredProcedureTerminationToken() is appended to the end of each statement.
SCHEMA_GENERATION_SCRIPT_THEN_METADATA_SOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The parameter value "script-then-metadata"
SCHEMA_GENERATION_SCRIPTS_ACTION - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.schema-generation.scripts.action" property specifies which scripts are to be generated by the persistence provider.
SCHEMA_GENERATION_SCRIPTS_CREATE_TARGET - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
If scripts are to be generated, the target locations for the writing of these scripts must be specified.
SCHEMA_GENERATION_SCRIPTS_DROP_TARGET - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
If scripts are to be generated, the target locations for the writing of these scripts must be specified.
SCHEMA_GENERATION_SQL_LOAD_SCRIPT_SOURCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
In Java EE container environments, it is generally expected that the container will be responsible for executing data load scripts, although the container is permitted to delegate this task to the persistence provider.
SCHEMA_INSTANCE_PREFIX - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
SCHEMA_INSTANCE_URL - Static variable in class org.eclipse.persistence.oxm.XMLConstants
 
SCHEMA_LOCATION - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
SCHEMA_NIL_ATTRIBUTE - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
SCHEMA_PREFIX - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
SCHEMA_REFERENCE_NOT_SET - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
SCHEMA_TYPE_ATTRIBUTE - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
SCHEMA_URL - Static variable in class org.eclipse.persistence.oxm.XMLConstants
 
SCHEMA_VALIDATION - Static variable in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
SCHEMA_VALIDATION - Static variable in class org.eclipse.persistence.oxm.XMLUnmarshaller
 
SCHEMA_VALIDATION - Static variable in class org.eclipse.persistence.oxm.XMLValidator
 
SCHEMA_VALIDATION - Static variable in interface org.eclipse.persistence.platform.xml.XMLParser
 
SchemaCompareByNamespace - Class in org.eclipse.persistence.internal.oxm.schema.model
 
SchemaCompareByNamespace() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.SchemaCompareByNamespace
 
schemaContext - Variable in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
The path to a simple/complex type definition or element in the schema
schemaContextAsQName - Variable in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
 
schemaLocation - Variable in class org.eclipse.persistence.internal.oxm.Root
 
schemaManager - Variable in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
 
SchemaManager - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Define all user level protocol for development time database manipulation.
SchemaManager(DatabaseSessionImpl) - Constructor for class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
SchemaManager(DatabaseSession) - Constructor for class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
SchemaModelGenerator - Class in org.eclipse.persistence.internal.oxm.schema
INTERNAL:
SchemaModelGenerator(ConversionManager) - Constructor for class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
The default constructor.
SchemaModelGenerator(ConversionManager, boolean) - Constructor for class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
This constructor should be used with a value of 'true' when the schemaLocation attribute of the import for swaRef should be swaref.xsd.
SchemaModelGeneratorProperties - Class in org.eclipse.persistence.internal.oxm.schema
INTERNAL:
SchemaModelGeneratorProperties() - Constructor for class org.eclipse.persistence.internal.oxm.schema.SchemaModelGeneratorProperties
 
SchemaModelOutputResolver - Interface in org.eclipse.persistence.internal.oxm.schema
Interface for controlling where schema files are generated.
SchemaModelProject - Class in org.eclipse.persistence.internal.oxm.schema
Purpose: TopLink OX project to map org.eclipse.persistence.internal.schema.model.* Used by TopLink SDO and JAXB implementations
SchemaModelProject() - Constructor for class org.eclipse.persistence.internal.oxm.schema.SchemaModelProject
 
SchemaPerMultitenantPolicy - Class in org.eclipse.persistence.descriptors
A schema per tenant multitenant policy.
SchemaPerMultitenantPolicy() - Constructor for class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
SchemaPerMultitenantPolicy(ClassDescriptor) - Constructor for class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
schemaReferenceNotSet(XMLDescriptor) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
schemasAreInitialized - Variable in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
schemaType - Variable in class org.eclipse.persistence.internal.oxm.Root
 
schemaType(Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.ConversionManager
 
schemaType(Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
SCROLLABLE_CURSOR - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.cursor.scrollable"
ScrollableCursor - Class in org.eclipse.persistence.queries
 
ScrollableCursor() - Constructor for class org.eclipse.persistence.queries.ScrollableCursor
INTERNAL: Default constructor.
ScrollableCursor(DatabaseCall, ScrollableCursorPolicy) - Constructor for class org.eclipse.persistence.queries.ScrollableCursor
INTERNAL: constructor.
ScrollableCursor_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
scrollableCursorAbsolute(ObjID, int) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Moves the cursor to the given row number in the result set
scrollableCursorAbsolute(ObjID, int) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Moves the cursor to the given row number in the result set
scrollableCursorAbsolute(Transporter, int) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Moves the cursor to the given row number in the result set
scrollableCursorAbsolute(Transporter, int) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Moves the cursor to the given row number in the result set
scrollableCursorAbsolute(Transporter, int) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Moves the cursor to the given row number in the result set
scrollableCursorAfterLast(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Moves the cursor to the end of the result set, just after the last row.
scrollableCursorAfterLast(ObjID) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Moves the cursor to the end of the result set, just after the last row.
scrollableCursorAfterLast(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Moves the cursor to the end of the result set, just after the last row.
scrollableCursorAfterLast(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Moves the cursor to the end of the result set, just after the last row.
scrollableCursorAfterLast(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Moves the cursor to the end of the result set, just after the last row.
scrollableCursorBeforeFirst(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Moves the cursor to the front of the result set, just before the first row
scrollableCursorBeforeFirst(ObjID) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Moves the cursor to the front of the result set, just before the first row
scrollableCursorBeforeFirst(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Moves the cursor to the front of the result set, just before the first row
scrollableCursorBeforeFirst(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Moves the cursor to the front of the result set, just before the first row
scrollableCursorBeforeFirst(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Moves the cursor to the front of the result set, just before the first row
scrollableCursorClose(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Used for closing scrolable cursor across RMI.
scrollableCursorClose(ObjID) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Used for closing scrollable cursor across RMI.
scrollableCursorClose(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Used for closing cursored streams across RMI.
scrollableCursorClose(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Used for closing scrollable cursor across RMI.
scrollableCursorClose(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Used for closing scrollable cursor across RMI.
scrollableCursorCurrentIndex(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Retrieves the current row index number
scrollableCursorCurrentIndex(ObjID) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Retrieves the current row index number
scrollableCursorCurrentIndex(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Retrieves the current row index number
scrollableCursorCurrentIndex(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Retrieves the current row index number
scrollableCursorCurrentIndex(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Retrieves the current row index number
scrollableCursorFirst(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Moves the cursor to the first row in the result set
scrollableCursorFirst(ObjID) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Moves the cursor to the first row in the result set
scrollableCursorFirst(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Moves the cursor to the first row in the result set
scrollableCursorFirst(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Moves the cursor to the first row in the result set
scrollableCursorFirst(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Moves the cursor to the first row in the result set
scrollableCursorIsAfterLast(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Indicates whether the cursor is after the last row in the result set.
scrollableCursorIsAfterLast(ObjID) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Indicates whether the cursor is after the last row in the result set.
scrollableCursorIsAfterLast(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Indicates whether the cursor is after the last row in the result set.
scrollableCursorIsAfterLast(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Indicates whether the cursor is after the last row in the result set.
scrollableCursorIsAfterLast(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Indicates whether the cursor is after the last row in the result set.
scrollableCursorIsBeforeFirst(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Indicates whether the cursor is before the first row in the result set.
scrollableCursorIsBeforeFirst(ObjID) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Indicates whether the cursor is before the first row in the result set.
scrollableCursorIsBeforeFirst(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Indicates whether the cursor is before the first row in the result set.
scrollableCursorIsBeforeFirst(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Indicates whether the cursor is before the first row in the result set.
scrollableCursorIsBeforeFirst(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Indicates whether the cursor is before the first row in the result set.
scrollableCursorIsFirst(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Indicates whether the cursor is on the first row of the result set.
scrollableCursorIsFirst(ObjID) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Indicates whether the cursor is on the first row of the result set.
scrollableCursorIsFirst(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Indicates whether the cursor is on the first row of the result set.
scrollableCursorIsFirst(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Indicates whether the cursor is on the first row of the result set.
scrollableCursorIsFirst(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Indicates whether the cursor is on the first row of the result set.
scrollableCursorIsLast(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Indicates whether the cursor is on the last row of the result set.
scrollableCursorIsLast(ObjID) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Indicates whether the cursor is on the last row of the result set.
scrollableCursorIsLast(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Indicates whether the cursor is on the last row of the result set.
scrollableCursorIsLast(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Indicates whether the cursor is on the last row of the result set.
scrollableCursorIsLast(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Indicates whether the cursor is on the last row of the result set.
scrollableCursorLast(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Moves the cursor to the last row in the result set
scrollableCursorLast(ObjID) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Moves the cursor to the last row in the result set
scrollableCursorLast(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Moves the cursor to the last row in the result set
scrollableCursorLast(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Moves the cursor to the last row in the result set
scrollableCursorLast(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Moves the cursor to the last row in the result set
scrollableCursorNextObject(ObjID, ReadQuery, DistributedSession) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Retrieve next object from the remote scrollable cursor
scrollableCursorNextObject(ObjID, ReadQuery, DistributedSession) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Retrieve next object from the remote scrollable cursor
scrollableCursorNextObject(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Retrieve next object from the scrollable cursor
scrollableCursorNextObject(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
INTERNAL: Retrieve next object from the scrollable cursor
scrollableCursorNextObject(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Retrieve next object from the scrollable cursor
ScrollableCursorPolicy - Class in org.eclipse.persistence.queries
PUBLIC: ScrollableCursorPolicy allows for additional options to be specified for ReadAllQuery or DataReadQuery.
ScrollableCursorPolicy() - Constructor for class org.eclipse.persistence.queries.ScrollableCursorPolicy
PUBLIC: Create a new scrollable cursor policy.
ScrollableCursorPolicy(ReadQuery, int) - Constructor for class org.eclipse.persistence.queries.ScrollableCursorPolicy
INTERNAL: Create a cursor policy with the pagesize.
scrollableCursorPreviousObject(ObjID, ReadQuery, DistributedSession) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Retrieve previous object from the remote scrollable cursor
scrollableCursorPreviousObject(ObjID, ReadQuery, DistributedSession) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Retrieve previous object from the remote scrollable cursor
scrollableCursorPreviousObject(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Retrieve previous object from the scrollable cursor
scrollableCursorPreviousObject(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
INTERNAL: Retrieve previous object from the scrollable cursor
scrollableCursorPreviousObject(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Retrieve previous object from the scrollable cursor
scrollableCursorRelative(ObjID, int) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Moves the cursor a relative number of rows, either positive or negative.
scrollableCursorRelative(ObjID, int) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Moves the cursor to the given row number in the result set
scrollableCursorRelative(Transporter, int) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Moves the cursor to the given row number in the result set
scrollableCursorRelative(Transporter, int) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
Moves the cursor to the given row number in the result set
scrollableCursorRelative(Transporter, int) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Moves the cursor to the given row number in the result set
scrollableCursorSize(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Return the scrollable cursor size
scrollableCursorSize(ObjID) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
Return the scrollable cursor size
scrollableCursorSize(Transporter) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Return the scrollable cursor size from the server
scrollableCursorSize(Transporter) - Method in interface org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionController
INTERNAL: Return the cursor size
scrollableCursorSize(Transporter) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Return the cursor size
ScrollInsensitive - Static variable in class org.eclipse.persistence.config.ResultSetType
The type for a ResultSet object that is scrollable but generally not sensitive to changes made by others.
ScrollSensitive - Static variable in class org.eclipse.persistence.config.ResultSetType
The type for a ResultSet object that is scrollable and generally sensitive to changes made by others.
SDO_FILTER - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
SDO_JAXB_ERROR_CREATING_JAXB_UNMARSHALLER - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
SDO_JAXB_NO_DESCRIPTOR_FOR_TYPE - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
SDO_JAXB_NO_MAPPING_FOR_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
SDO_JAXB_NO_SCHEMA_CONTEXT - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
SDO_JAXB_NO_SCHEMA_REFERENCE - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
SDO_JAXB_NO_TYPE_FOR_CLASS - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
SDO_JAXB_NO_TYPE_FOR_CLASS_BY_SCHEMA_CONTEXT - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
SDO_NN - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
SDO_RELATE - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
SDO_WITHIN_DISTANCE - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
SDOException - Exception in org.eclipse.persistence.exceptions
Purpose: This class provides an implementation of EclipseLinkException specific to the EclipseLink SDO (Service Data Objects) API.
SDOException(String) - Constructor for exception org.eclipse.persistence.exceptions.SDOException
 
SDOException(String, Exception) - Constructor for exception org.eclipse.persistence.exceptions.SDOException
 
SDOExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: Purpose:
SDOExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.SDOExceptionResource
Default constructor.
sdoJaxbErrorCreatingJAXBUnmarshaller(Exception) - Static method in exception org.eclipse.persistence.exceptions.SDOException
 
sdoJaxbNoDescriptorForType(QName, QName) - Static method in exception org.eclipse.persistence.exceptions.SDOException
 
sdoJaxbNoMappingForProperty(String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
 
sdoJaxbNoSchemaContext(Class<?>) - Static method in exception org.eclipse.persistence.exceptions.SDOException
 
sdoJaxbNoSchemaReference(Class<?>) - Static method in exception org.eclipse.persistence.exceptions.SDOException
 
sdoJaxbNoTypeForClass(Class<?>) - Static method in exception org.eclipse.persistence.exceptions.SDOException
 
sdoJaxbNoTypeForClassBySchemaContext(Class<?>, QName) - Static method in exception org.eclipse.persistence.exceptions.SDOException
 
second() - Method in annotation type org.eclipse.persistence.annotations.TimeOfDay
(Optional) Second of the day.
secondaryPrefix - Variable in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolverWithPrefixes
 
secondChild - Variable in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
Securable - Interface in org.eclipse.persistence.internal.security
TopLink encryption interface
securableObjectHolder - Variable in class org.eclipse.persistence.sessions.coordination.TransportManager
Security util that is used to decrypt and encrypt password
SecurableObjectHolder - Class in org.eclipse.persistence.internal.security
Holder of a SecurableObject.
SecurableObjectHolder() - Constructor for class org.eclipse.persistence.internal.security.SecurableObjectHolder
 
SecurableObjectHolder(String) - Constructor for class org.eclipse.persistence.internal.security.SecurableObjectHolder
 
SECURITY_ON_FIND_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
SECURITY_ON_FIND_OBSOLETE_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
SECURITY_ON_INITIALIZING_ATTRIBUTE_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
SECURITY_WHILE_CONVERTING_TO_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
SECURITY_WHILE_INITIALIZING_ATTRIBUTES_IN_INSTANCE_VARIABLE_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
SECURITY_WHILE_INITIALIZING_ATTRIBUTES_IN_METHOD_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
SECURITY_WHILE_INITIALIZING_CLASS_EXTRACTION_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
SECURITY_WHILE_INITIALIZING_COPY_POLICY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
SECURITY_WHILE_INITIALIZING_INSTANTIATION_POLICY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
securityOnFindMethod(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
securityOnFindObsoleteMethod(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
securityOnInitializingAttributeMethod(String, DatabaseMapping, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
securityWhileConvertingToMethod(String, DatabaseMapping, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
securityWhileInitializingAttributesInInstanceVariableAccessor(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
securityWhileInitializingAttributesInMethodAccessor(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
securityWhileInitializingClassExtractionMethod(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
securityWhileInitializingCopyPolicy(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
securityWhileInitializingInstantiationPolicy(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
select(Accessor, AbstractSession, String, Integer) - Method in class org.eclipse.persistence.sequencing.QuerySequence
INTERNAL:
SELECT - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
SELECT_ID_PREFIX - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
SELECT_ID_SUFFIX - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
selectAllObjects(ReadAllQuery) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Select all objects for a concrete descriptor.
selectAllObjects(ReadAllQuery) - Method in class org.eclipse.persistence.descriptors.TablePerClassPolicy
INTERNAL: Select all objects for a concrete descriptor.
selectAllObjectsUsingMultipleTableSubclassRead(ReadAllQuery) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Select all objects for an interface descriptor.
selectAllReportQueryRows() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
INTERNAL: Read all rows from the database.
selectAllReportQueryRows() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Read all rows from the database.
selectAllReportQueryRows() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
INTERNAL Read all rows from the database.
selectAllRows() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Read and return rows from the database.
selectAllRows() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Read all rows from the database.
selectAllRows() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Read all rows from the database.
selectAllRowsFromConcreteTable() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Read all rows from the database.
selectAllRowsFromTable() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Read all rows from the database.
selectAllRowUsingCustomMultipleTableSubclassRead(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Select all rows from a abstract table descriptor.
selectAllRowUsingDefaultMultipleTableSubclassRead(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Select all rows from a abstract table descriptor.
selectAllRowUsingMultipleTableSubclassRead(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Select all rows from a abstract table descriptor.
selectCall - Variable in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
selectCall - Variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
selectCallForExist - Variable in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
selectCallForExist - Variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
selectCallForNotExist - Variable in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
selectClause - Variable in class org.eclipse.persistence.tools.schemaframework.ViewDefinition
 
SELECTED_COLUMNS - org.eclipse.persistence.annotations.OptimisticLockingType
Using this type of locking compares selected fields in the WHERE clause when doing an update or a delete.
selectedColumns() - Method in annotation type org.eclipse.persistence.annotations.OptimisticLocking
(Optional) For an optimistic locking policy of type SELECTED_COLUMNS, this annotation member becomes a (Required) field.
SelectedFieldsLockingPolicy - Class in org.eclipse.persistence.descriptors
Purpose: An implementation of the OptimisticLockingPolicy interface.
SelectedFieldsLockingPolicy() - Constructor for class org.eclipse.persistence.descriptors.SelectedFieldsLockingPolicy
PUBLIC: Create a new selected fields locking policy.
selectElementNodes(Node, XPathFragment, XMLNamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.UnmarshalXPathEngine
 
selectIfOrderedBy - Variable in class org.eclipse.persistence.expressions.Expression
 
selectIfOrderedBy() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return whether this expression should be included in the SELECT clause if it is used in an ORDER BY clause
selectIfOrderedBy() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
SELECTION_OBJECT_CANNOT_BE_NULL - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
SELECTION_QUERY_FOR_ATTRIBUTE_COULD_NOT_BE_FOUND_FOR_ENTITY - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
selectionCriteria - Variable in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
selectionCriteriaClone - Variable in class org.eclipse.persistence.queries.Cursor
SelectionCriteria & translation row ready for incremental conforming.
selectionFields - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
selectionId - Variable in class org.eclipse.persistence.queries.ReadObjectQuery
Key that can be used in place of a selection criteria.
selectionObject - Variable in class org.eclipse.persistence.queries.ReadObjectQuery
Object that can be used in place of a selection criteria.
selectionObjectCannotBeNull(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
selectionQuery - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
This query is used to read referenced objects for this mapping.
selectNodes(Node, List<XML_FIELD>, XMLNamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.UnmarshalXPathEngine
 
selectNodes(Node, XML_FIELD, XMLNamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.UnmarshalXPathEngine
Execute the XPath statement relative to the context node.
selectNodes(Node, XML_FIELD, XMLNamespaceResolver, AbstractNullPolicy) - Method in class org.eclipse.persistence.internal.oxm.UnmarshalXPathEngine
 
selectNodes(Node, XML_FIELD, XMLNamespaceResolver, AbstractNullPolicy, boolean) - Method in class org.eclipse.persistence.internal.oxm.UnmarshalXPathEngine
 
selectNodes(Node, XML_FIELD, XMLNamespaceResolver, AbstractNullPolicy, boolean, boolean) - Method in class org.eclipse.persistence.internal.oxm.UnmarshalXPathEngine
 
selectNodesAdvanced(Node, String, XMLNamespaceResolver) - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
Execute advanced XPath statements that are required for TopLink EIS.
selectOneObject(ReadObjectQuery) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Select one object of any concrete subclass.
selectOneObject(ReadObjectQuery) - Method in class org.eclipse.persistence.descriptors.TablePerClassPolicy
INTERNAL: Select one object of any concrete subclass.
selectOneObjectUsingMultipleTableSubclassRead(ReadObjectQuery) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Select one object of any concrete subclass.
selectOneRow() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Read and return a row from the database.
selectOneRow() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Read a single row from the database.
selectOneRow() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Read a single row from the database.
selectOneRowFromConcreteTable() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Read a single row from the database.
selectOneRowFromTable() - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Read a single row from the database.
selectOneRowUsingCustomMultipleTableSubclassRead(ReadObjectQuery) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Select one rows from a abstract table descriptor.
selectOneRowUsingDefaultMultipleTableSubclassRead(ReadObjectQuery) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Select one row of any concrete subclass, This must use two selects, the first retrieves the type field only.
selectOneRowUsingMultipleTableSubclassRead(ReadObjectQuery) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Select one row of any concrete subclass, This must use two selects, the first retrieves the type field only.
selector - Variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
selectQuery - Variable in class org.eclipse.persistence.sequencing.QuerySequence
 
selectResultSet() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Read all rows from the database, return ResultSet
selectRowForDoesExist(DatabaseField) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Read and return a row from the database for an existence check.
selectRowForDoesExist(DatabaseField) - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Perform a does exist check
selectSingleNode(Node, XML_FIELD, XMLNamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.UnmarshalXPathEngine
 
selectSingleNode(Node, XML_FIELD, XMLNamespaceResolver, boolean) - Method in class org.eclipse.persistence.internal.oxm.UnmarshalXPathEngine
Execute the XPath statement relative to the context node.
selectSingleNodeAdvanced(Node, String, XMLNamespaceResolver) - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
Execute advanced XPath statements that are required for TopLink EIS.
selectString1 - Variable in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
selectString2 - Variable in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
selectStringBufferSize - Variable in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
selectValue1() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by only returning a single value.
SELF_FRAGMENT - Static variable in class org.eclipse.persistence.internal.oxm.XPathFragment
 
SELF_XPATH - Static variable in class org.eclipse.persistence.internal.oxm.XPathFragment
 
selfValidationAfterInitialization(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Validate that the descriptor was defined correctly.
selfValidationBeforeInitialization(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Validate that the descriptor's non-mapping attribute are defined correctly.
SEND_MODE_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
SEND_NEW_OBJECTS_WITH_CHANGES - org.eclipse.persistence.annotations.CacheCoordinationType
Same as SEND_OBJECT_CHANGES except it also includes any newly created objects from the transaction.
SEND_NEW_OBJECTS_WITH_CHANGES - Static variable in class org.eclipse.persistence.descriptors.CachePolicy
 
SEND_NEW_OBJECTS_WITH_CHANGES - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
SEND_OBJECT_CHANGES - org.eclipse.persistence.annotations.CacheCoordinationType
Sends a list of changed objects including data about the changes.
SEND_OBJECT_CHANGES - Static variable in class org.eclipse.persistence.descriptors.CachePolicy
 
SEND_OBJECT_CHANGES - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
SEPARATOR - Static variable in class org.eclipse.persistence.internal.helper.JavaVersion
JavaEE platform version elements separator character.
SEPARATOR - Static variable in class org.eclipse.persistence.internal.mappings.converters.AttributeNameTokenizer
INTERNAL: Attribute name dot notation separator.
separators - Variable in class org.eclipse.persistence.expressions.ListExpressionOperator
 
sequence - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
Store the Sequence used for the descriptor.
sequence - Variable in class org.eclipse.persistence.tools.schemaframework.SequenceDefinition
 
Sequence - Class in org.eclipse.persistence.internal.oxm.schema.model
Purpose: Class to represent a Sequence in a Schema
Sequence - Class in org.eclipse.persistence.sequencing
Purpose: Abstract class to define sequencing.
Sequence() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
Sequence() - Constructor for class org.eclipse.persistence.sequencing.Sequence
 
Sequence(String) - Constructor for class org.eclipse.persistence.sequencing.Sequence
Create a new sequence with the name.
Sequence(String, int) - Constructor for class org.eclipse.persistence.sequencing.Sequence
Create a new sequence with the name and sequence pre-allocation size.
Sequence(String, int, int) - Constructor for class org.eclipse.persistence.sequencing.Sequence
 
SEQUENCE_CANNOT_BE_CONNECTED_TO_TWO_PLATFORMS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
SEQUENCE_COUNTER_FIELD_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
SEQUENCE_DUPLICATE_ADD_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
SEQUENCE_ERROR_DATAOBJECT_IS_NULL - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
SEQUENCE_ERROR_NO_PATH_FOUND - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
SEQUENCE_ERROR_PROPERTY_IS_ATTRIBUTE - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
SEQUENCE_GENERATOR_RESERVED_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
SEQUENCE_NAME_ALREADY_USED_BY_DEFAULT_SEQUENCE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
SEQUENCE_NAME_FIELD_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
SEQUENCE_NOT_SUPPORTED_FOR_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
SEQUENCE_NULL_ON_SEQUENCED_DATAOBJECT - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
SEQUENCE_NUMBER_PROPERTY_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
SEQUENCE_PREALLOCATION_SIZE_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
SEQUENCE_SETUP_INCORRECTLY - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
SEQUENCE_TABLE_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
SEQUENCE_TABLE_INFORMATION_NOT_COMPLETE - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
sequenceAttributePropertyNotSupported(String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Error when we attempt to add an attribute property to a sequence
sequenceCannotBeConnectedToTwoPlatforms(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
SequenceConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.sequencing
INTERNAL:
SequenceConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequenceConfig
 
sequenceDataObjectInstanceFieldIsNull() - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Error passing in a null dataObject into the sequence constructor
SequenceDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Allow a generic way of creating sequences on the different platforms, and allow optional parameters to be specified.
SequenceDefinition(String) - Constructor for class org.eclipse.persistence.tools.schemaframework.SequenceDefinition
 
SequenceDefinition(Sequence) - Constructor for class org.eclipse.persistence.tools.schemaframework.SequenceDefinition
 
SequencedMarshalContext - Class in org.eclipse.persistence.internal.oxm.record
An implementation of MarshalContext for handling sequenced objects that are mapped to XML.
SequencedMarshalContext(Object) - Constructor for class org.eclipse.persistence.internal.oxm.record.SequencedMarshalContext
 
SequencedMarshalContext(List<Setting>) - Constructor for class org.eclipse.persistence.internal.oxm.record.SequencedMarshalContext
 
SequencedObject - Interface in org.eclipse.persistence.oxm.sequenced
In order to mark a domain object as being a Sequenced Object it must implement this interface.
SequencedUnmarshalContext - Class in org.eclipse.persistence.internal.oxm.record
 
SequencedUnmarshalContext() - Constructor for class org.eclipse.persistence.internal.oxm.record.SequencedUnmarshalContext
 
sequenceDuplicateSettingNotSupportedForComplexSingleObject(int, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Return an exception when attempting to add a setting to a sequene that already has an existing entry.
sequenceGeneratorUsingAReservedName(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
sequenceMapping - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Cache sequence mappings.
sequenceNameAlreadyUsedByDefaultSequence(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
sequenceNotFoundForPath(String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Error when we attempt find a sequence by path
sequenceNotSupportedForProperty(String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Error passing in a null dataObject into the sequence constructor
sequenceNullOnSequencedDataObject() - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when sequence is null on a dataObject with sequenced set to true
sequenceNumberField - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
sequenceNumberName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
sequenceNumberPropertyNotSpecified(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
SequenceObjectDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Sequence definition Native Sequence object.
SequenceObjectDefinition(Sequence) - Constructor for class org.eclipse.persistence.tools.schemaframework.SequenceObjectDefinition
INTERNAL: Should be a sequence defining sequence object in the db: either NativeSequence with shouldAcquireValueAfterInsert() returning false; or DefaultSequence (only if case platform.getDefaultSequence() is a NativeSequence with shouldAcquireValueAfterInsert() returning false).
sequences - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Store map of sequence names to sequences
sequencesAfterCloneCleanup() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
sequenceSetupIncorrectly(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
sequencesLock - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Ensures that only one thread at a time can add/remove sequences
sequenceTableInformationNotComplete() - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
sequencing - Variable in class org.eclipse.persistence.sessions.broker.SessionBroker
 
sequencing - Variable in class org.eclipse.persistence.sessions.remote.RemoteSession
 
sequencing - Variable in class org.eclipse.persistence.sessions.server.ClientSession
 
Sequencing - Interface in org.eclipse.persistence.internal.sequencing
Purpose: Define interface to use sequencing.
SEQUENCING - org.eclipse.persistence.logging.LogCategory
 
SEQUENCING - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
SEQUENCING_MULTITHREAD_THRU_CONNECTION - Static variable in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
SEQUENCING_SEQUENCE_DEFAULT - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.sequencing.default-sequence-to-table" property determines the default behavior when a GeneratedValue of type SEQUENCE is used on a database platform that does not support SEQUENCE generation.
SEQUENCING_START_AT_NEXTVAL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
By default, EclipseLink generates sequence values at (NEXTVAL - allocationSize).
sequencingCallback - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
During (not external) transaction, SequencingManager may set SequencingCallback on the accessor, The callback's only method is called when transaction commits, after transaction is completed the callback is discarded.
sequencingCallback - Variable in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
sequencingCallback used in case listener has a single callback.
SequencingCallback - Interface in org.eclipse.persistence.internal.sequencing
Purpose: Define interface for sequencing callback.
SequencingCallbackFactory - Interface in org.eclipse.persistence.internal.sequencing
Purpose: Define interface for sequencing callback factory.
sequencingCallbackMap - Variable in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
sequencingCallbackMap used in case listener has more than one callback: SessionBroker with at least two members requiring callbacks.
SequencingConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.sequencing
INTERNAL:
SequencingConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
SequencingControl - Interface in org.eclipse.persistence.sequencing
Purpose: Define an interface to control sequencing functionality.
SequencingFactory - Class in org.eclipse.persistence.internal.sequencing
SequencingFactory is private to EclipseLink.
SequencingFunctionCall - Class in org.eclipse.persistence.internal.sessions.remote
Purpose: This class declares sequencing remote function calls classes
SequencingFunctionCall() - Constructor for class org.eclipse.persistence.internal.sessions.remote.SequencingFunctionCall
 
SequencingFunctionCall.DoesExist - Class in org.eclipse.persistence.internal.sessions.remote
 
SequencingFunctionCall.GetNextValue - Class in org.eclipse.persistence.internal.sessions.remote
 
SequencingFunctionCall.WhenShouldAcquireValueForAll - Class in org.eclipse.persistence.internal.sessions.remote
 
sequencingHome - Variable in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: sequencingHome for this session.
SequencingHome - Interface in org.eclipse.persistence.internal.sequencing
Purpose: Define interface for getting all sequencing interfaces.
sequencingListeners - Variable in class org.eclipse.persistence.transaction.AbstractTransactionController
Non-null only in case sequencing callbacks are used: numSessionsRequiringSequencingCallback > 0
sequencingMultithreadThruConnection(String) - Static method in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
SequencingServer - Interface in org.eclipse.persistence.internal.sequencing
Purpose: Define interface for sequencing server.
SerializableDescriptorEventHolder - Interface in org.eclipse.persistence.descriptors
INTERNAL: Interface to hold onto a DescriptorEvents within a project so they can be rebuilt after serialization.
SerializationHelper - Class in org.eclipse.persistence.internal.helper
Provide common functionalities for serialization of object.
SerializationHelper() - Constructor for class org.eclipse.persistence.internal.helper.SerializationHelper
 
serialize(Serializable) - Static method in class org.eclipse.persistence.internal.helper.SerializationHelper
Serialize the object to a byte array
serialize(Serializable, OutputStream) - Static method in class org.eclipse.persistence.internal.helper.SerializationHelper
Serialize the object to an OutputStream
serialize(Object, Session) - Method in class org.eclipse.persistence.sessions.serializers.JavaSerializer
 
serialize(Object, Session) - Method in class org.eclipse.persistence.sessions.serializers.JSONSerializer
 
serialize(Object, Session) - Method in interface org.eclipse.persistence.sessions.serializers.Serializer
 
serialize(Object, Session) - Method in class org.eclipse.persistence.sessions.serializers.XMLSerializer
 
SERIALIZED - Static variable in annotation type org.eclipse.persistence.annotations.Convert
Constant name for the reserved Java serialization converter.
SERIALIZED_OBJECT - Static variable in class org.eclipse.persistence.config.QueryHints
"eclipselink.serialized-object"
SERIALIZED_OBJECT_POLICY_FIELD_NOT_SET - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
SerializedConverter - Annotation Type in org.eclipse.persistence.annotations
A SerializedConverter is used to serialize an object's value into a database binary, character, or XML field.
SerializedConverters - Annotation Type in org.eclipse.persistence.annotations
A TypeConverters annotation allows the definition of multiple SerializedConverter.
SerializedObject - Annotation Type in org.eclipse.persistence.annotations
SerializedObject annotation is used to set an org.eclipse.persistence.descriptors.SerializedObjectPolicy on an Entity or MappedSuperClass.
SerializedObjectConverter - Class in org.eclipse.persistence.mappings.converters
Purpose: The serialized object converter can be used to store an arbitrary object or set of objects into a database binary or character field.
SerializedObjectConverter() - Constructor for class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
PUBLIC: Default constructor.
SerializedObjectConverter(DatabaseMapping) - Constructor for class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
PUBLIC: Default constructor.
SerializedObjectConverter(DatabaseMapping, String) - Constructor for class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
PUBLIC: Default constructor.
SerializedObjectConverter(DatabaseMapping, Serializer) - Constructor for class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
PUBLIC: Default constructor.
serializedObjectPolicy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
SerializedObjectPolicy - Interface in org.eclipse.persistence.descriptors
SerializedObjectPolicy (SOP) could be set on a non-aggregate descriptor.
serializedObjectPolicyClassName - Variable in class org.eclipse.persistence.internal.descriptors.SerializedObjectPolicyWrapper
 
serializedObjectPolicyFieldNotSet(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
SerializedObjectPolicyWrapper - Class in org.eclipse.persistence.internal.descriptors
It's a transition class that holds SerializedObjectPolicy class name and field obtained from matadata before it can be instantiated.
SerializedObjectPolicyWrapper(String) - Constructor for class org.eclipse.persistence.internal.descriptors.SerializedObjectPolicyWrapper
 
serializer - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Set the Serializer to use by default for serialization.
serializer - Variable in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
 
serializer - Variable in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
Set the Serializer to use for serialization of commands.
Serializer - Interface in org.eclipse.persistence.sessions.serializers
Generic serializer interface.
SERIALIZER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.serializer" property specifies class name for session serializer (must implement Serializer)
serializerClass() - Method in annotation type org.eclipse.persistence.annotations.SerializedConverter
The serializer class to be used.
serializerClassName - Variable in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
 
serializerPackage - Variable in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
 
serializerPackage() - Method in annotation type org.eclipse.persistence.annotations.SerializedConverter
Allows a package name to be passed to the serializer.
Server - Interface in org.eclipse.persistence.sessions.server
Purpose: A single session that supports multiple user/clients connection at the same time.
SERVER - org.eclipse.persistence.logging.LogCategory
 
SERVER - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
SERVER_LOG_CLASS - Static variable in class org.eclipse.persistence.platform.server.was.WebSphere_7_Platform
 
SERVER_PLATFORM_CLASS_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.ServerPlatformException
 
SERVER_PLATFORM_IS_READ_ONLY_AFTER_LOGIN - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
SERVER_PLATFORM_NO_LONGER_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
SERVER_SPECIFIC_APPLICATIONNAME_PROPERTY - Static variable in class org.eclipse.persistence.platform.server.wls.WebLogic_10_Platform
This persistence.xml or sessions.xml property is used to override the applicationName
SERVER_SPECIFIC_MODULENAME_PROPERTY - Static variable in class org.eclipse.persistence.platform.server.wls.WebLogic_10_Platform
This persistence.xml or sessions.xml property is used to override the moduleName
SERVER_TIME - Static variable in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
 
serverIndirectionObject - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
 
ServerLog - Class in org.eclipse.persistence.platform.server
Basic logging class that provides framework for integration with the application server log.
ServerLog() - Constructor for class org.eclipse.persistence.platform.server.ServerLog
PUBLIC:
ServerLogConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.log
INTERNAL:
ServerLogConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.log.ServerLogConfig
 
ServerLogger - Static variable in class org.eclipse.persistence.config.LoggerType
 
serverNameAndVersion - Variable in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: Server name and version.
serverPlatform - Variable in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
Used to store the server platform that handles server-specific functionality for Oc4j, WLS, etc.
serverPlatform - Variable in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
Uniquely identifies ServerPlatform in the cluster
ServerPlatform - Interface in org.eclipse.persistence.platform.server
PUBLIC: This is the interface describing the behavior for ServerPlatformBase, and any other class that wants to provide behavior for a server.
ServerPlatformBase - Class in org.eclipse.persistence.platform.server
PUBLIC: Implementation of org.eclipse.persistence.platform.server.ServerPlatform
ServerPlatformBase(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: Default Constructor: Initialize so that runtime services and JTA are enabled.
serverPlatformClassNotFound(String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.ServerPlatformException
 
ServerPlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
ServerPlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.ServerPlatformConfig
 
ServerPlatformConfig(String) - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.ServerPlatformConfig
 
ServerPlatformDetector - Interface in org.eclipse.persistence.platform.server
A generic interface that allows implementors to try to detect which platform is currently being executed on.
ServerPlatformException - Exception in org.eclipse.persistence.exceptions
 
ServerPlatformException() - Constructor for exception org.eclipse.persistence.exceptions.ServerPlatformException
 
ServerPlatformException(String) - Constructor for exception org.eclipse.persistence.exceptions.ServerPlatformException
 
ServerPlatformException(String, Throwable) - Constructor for exception org.eclipse.persistence.exceptions.ServerPlatformException
 
ServerPlatformExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
 
ServerPlatformExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.ServerPlatformExceptionResource
Default constructor.
serverPlatformIsReadOnlyAfterLogin(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: An attempt was made to modify the ServerPlatform after login.
serverPlatformNoLongerSupported(String) - Static method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
ServerPlatformUtils - Class in org.eclipse.persistence.platform.server
A utility class to interact with ServerPlatforms.
ServerSession - Class in org.eclipse.persistence.sessions.server
Implementation of Server INTERNAL: The public interface should be used.
ServerSession() - Constructor for class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Create and return a new default server session.
ServerSession(Login) - Constructor for class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Create and return a new server session.
ServerSession(Login, int, int) - Constructor for class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Create and return a new server session.
ServerSession(Login, ConnectionPolicy) - Constructor for class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Create and return a new default server session.
ServerSession(Project) - Constructor for class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Create and return a new server session.
ServerSession(Project, int, int) - Constructor for class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Create and return a new server session.
ServerSession(Project, int, int, int) - Constructor for class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Create and return a new server session.
ServerSession(Project, int, int, Login) - Constructor for class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Create and return a new server session.
ServerSession(Project, int, int, Login, Login) - Constructor for class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Create and return a new server session.
ServerSession(Project, ConnectionPolicy) - Constructor for class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Create and return a new server session.
ServerSession(Project, ConnectionPolicy, int, int, int, Login, Login) - Constructor for class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Create and return a new server session.
ServerSession(Project, ConnectionPolicy, Login) - Constructor for class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Create and return a new server session.
ServerSession(Project, ConnectionPolicy, Login, Login) - Constructor for class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Create and return a new server session.
ServerSession_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
ServerSessionConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.session
INTERNAL:
ServerSessionConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.session.ServerSessionConfig
 
serverSpecificRegisterMBean() - Method in class org.eclipse.persistence.platform.server.glassfish.GlassfishPlatform
INTERNAL: serverSpecificRegisterMBean(): Server specific implementation of the creation and deployment of the JMX MBean to provide runtime services for my databaseSession.
serverSpecificRegisterMBean() - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
INTERNAL: serverSpecificRegisterMBean(): Server specific implementation of the creation and deployment of the JMX MBean to provide runtime services for my databaseSession.
serverSpecificRegisterMBean() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: serverSpecificRegisterMBean(): Server specific implementation of the creation and deployment of the JMX MBean to provide runtime services for my databaseSession.
serverSpecificRegisterMBean() - Method in class org.eclipse.persistence.platform.server.was.WebSphere_7_Platform
INTERNAL: serverSpecificRegisterMBean(): Server specific implementation of the creation and deployment of the JMX MBean to provide runtime services for my databaseSession.
serverSpecificRegisterMBean() - Method in class org.eclipse.persistence.platform.server.wls.WebLogic_10_Platform
INTERNAL: serverSpecificRegisterMBean(): Server specific implementation of the creation and deployment of the JMX MBean to provide runtime services for my databaseSession.
serverSpecificUnregisterMBean() - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
INTERNAL: serverSpecificUnregisterMBean(): Server specific implementation of the de-registration of the JMX MBean from its server during session logout.
serverSpecificUnregisterMBean() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: serverSpecificUnregisterMBean(): Server specific implementation of the unregistration of the JMX MBean from its server.
serverTimestampString() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Return the current date and time from the server.
ServiceAnnouncement - Class in org.eclipse.persistence.internal.sessions.coordination
Purpose: A structured message object to announce a new RCM service instance becoming available
ServiceAnnouncement(byte[]) - Constructor for class org.eclipse.persistence.internal.sessions.coordination.ServiceAnnouncement
INTERNAL: Constructor to initialize a new instance when receiving a message
ServiceAnnouncement(ServiceId) - Constructor for class org.eclipse.persistence.internal.sessions.coordination.ServiceAnnouncement
INTERNAL: Constructor to initialize a new instance when creating a message
serviceId - Variable in class org.eclipse.persistence.internal.sessions.coordination.RemoteConnection
The service on the receiving end of this connection
serviceId - Variable in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
Uniquely identifies this service in the cluster
ServiceId - Class in org.eclipse.persistence.sessions.coordination
Purpose: Encapsulate the information that uniquely identifies a specific remote command service instance.
ServiceId() - Constructor for class org.eclipse.persistence.sessions.coordination.ServiceId
 
ServiceId(String, String, String) - Constructor for class org.eclipse.persistence.sessions.coordination.ServiceId
 
serviceName - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
This attribute is used to provide a globally unique identifier for this connection.
session - Variable in class org.eclipse.persistence.descriptors.DescriptorEvent
The session in which the event is raised.
session - Variable in class org.eclipse.persistence.dynamic.DynamicHelper
 
session - Variable in exception org.eclipse.persistence.exceptions.EclipseLinkException
 
session - Variable in class org.eclipse.persistence.expressions.ExpressionBuilder
 
session - Variable in class org.eclipse.persistence.internal.databaseaccess.ConnectionCustomizer
 
session - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
session - Variable in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
The session being normalized in.
session - Variable in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
Stores the current session.
session - Variable in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Session that the map is on
session - Variable in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
A reference to the session owning this manager.
session - Variable in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Stores the session for the database that contains the object.
session - Variable in class org.eclipse.persistence.internal.oxm.Context.ContextState
 
session - Variable in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
session - Variable in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
session - Variable in class org.eclipse.persistence.internal.sessions.CommitManager
 
session - Variable in class org.eclipse.persistence.internal.sessions.CommitOrderCalculator
 
session - Variable in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
session - Variable in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
 
session - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
The unit of work merging for.
session - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
Back reference to owning session.
session - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
This is a either a database session or a client session depending upon the setup.
session - Variable in class org.eclipse.persistence.internal.sessions.ResultSetRecord
 
session - Variable in class org.eclipse.persistence.internal.sessions.SessionFinalizer
 
session - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
Stores unit of work before it is serialized.
session - Variable in class org.eclipse.persistence.logging.AbstractSessionLog
Represents the session that owns this SessionLog
session - Variable in class org.eclipse.persistence.logging.SessionLogEntry
 
session - Variable in class org.eclipse.persistence.mappings.converters.ConverterClass
 
session - Variable in class org.eclipse.persistence.oxm.record.XMLRecord
 
session - Variable in class org.eclipse.persistence.queries.Cursor
The session that executed the query for the stream.
session - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Only used after the query is cloned for execution to store the session under which the query was executed.
session - Variable in class org.eclipse.persistence.services.DevelopmentServices
stores access to the session object that we are controlling
session - Variable in class org.eclipse.persistence.services.RuntimeServices
stores access to the session object that we are controlling
session - Variable in class org.eclipse.persistence.sessions.CopyGroup
 
session - Variable in class org.eclipse.persistence.sessions.remote.rmi.RMIServerSessionManagerDispatcher
 
session - Variable in class org.eclipse.persistence.sessions.SessionEvent
The session or unit of work raising the event.
session - Variable in class org.eclipse.persistence.sessions.SessionEventManager
 
session - Variable in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
session - Variable in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
session - Variable in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
session - Variable in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
The parent of the uow.
session - Variable in class org.eclipse.persistence.transaction.AbstractTransactionController
The session this controller is responsible for controlling
Session - Interface in org.eclipse.persistence.sessions
Purpose: Define the EclipseLink session public interface.
SESSION_AMENDMENT_EXCEPTION_OCCURED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
SESSION_BEAN_COULD_NOT_BE_FOUND - Static variable in class org.eclipse.persistence.exceptions.JPARSErrorCodes
 
SESSION_CUSTOMIZER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.session.customizer" property configures a SessionCustomizer used to alter the runtime configuration through API.
SESSION_EVENT_LISTENER_CLASS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.session-event-listener" property configures a session event listener class.
SESSION_LOADED_FROM_SESSIONSXML_MUST_BE_SERVER_SESSION - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
SESSION_NAME - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.session-name" property configures a specific name to use when storing the singleton server session within the SessionManager.
SESSION_NAME_ALREADY_IN_USE - Static variable in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
SESSION_REMOVED_DURING_DEPLOYMENT - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
SESSION_TOPLINK_NAMESPACE - Static variable in class org.eclipse.persistence.logging.JavaLog
 
sessionAmendmentExceptionOccured(Exception, String, String, Class<?>[]) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: An amendment method was called but can not be found.
SessionBroker - Class in org.eclipse.persistence.sessions.broker
Purpose: Provide a single view to a TopLink session that transparently accesses multple databases.
SessionBroker() - Constructor for class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Create and return a session broker.
SessionBroker(Map) - Constructor for class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Create and return a session broker.
SessionBrokerConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.session
INTERNAL:
SessionBrokerConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.session.SessionBrokerConfig
 
SessionBrokerIdentityMapAccessor - Class in org.eclipse.persistence.internal.sessions
INTERNAL: Subclass of IdentityMapAccessor for Session brokers Overrides some identiy map initialization code
SessionBrokerIdentityMapAccessor(AbstractSession, IdentityMapManager) - Constructor for class org.eclipse.persistence.internal.sessions.SessionBrokerIdentityMapAccessor
 
SessionBrokerPlaceHolder - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL:
SessionBrokerPlaceHolder() - Constructor for class org.eclipse.persistence.internal.sessions.factories.SessionBrokerPlaceHolder
 
SessionConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.session
INTERNAL:
SessionConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
SessionConfigs - Class in org.eclipse.persistence.internal.sessions.factories.model
INTERNAL:
SessionConfigs() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.SessionConfigs
 
SessionCustomizer - Interface in org.eclipse.persistence.config
PUBLIC: This interface is to allow extra customization on an EclipseLink Session
SessionCustomizer() - Constructor for class org.eclipse.persistence.dynamic.DynamicHelper.SessionCustomizer
Default constructor.
SessionEvent - Class in org.eclipse.persistence.sessions
Purpose: Encapsulate the information provided with session events.
SessionEvent - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
SessionEvent(int, Session) - Constructor for class org.eclipse.persistence.sessions.SessionEvent
INTERNAL: Create the event.
SessionEventAdapter - Class in org.eclipse.persistence.sessions
Purpose: To provide a trivial implemetation of SessionEventListener.
SessionEventAdapter() - Constructor for class org.eclipse.persistence.sessions.SessionEventAdapter
 
SessionEventListener - Interface in org.eclipse.persistence.sessions
Purpose: Used to support session events.
SessionEventManager - Class in org.eclipse.persistence.sessions
Purpose: Used to support session events.
SessionEventManager() - Constructor for class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Default constructor.
SessionEventManager(Session) - Constructor for class org.eclipse.persistence.sessions.SessionEventManager
PUBLIC: Create a new session event manager for a session
SessionEventManagerConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.event
INTERNAL:
SessionEventManagerConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.event.SessionEventManagerConfig
 
SessionFactory - Class in org.eclipse.persistence.sessions.factories
Helper class to simplify the development and generation of code that accesses TopLink through the SessionManager (sessions config XML).
SessionFactory(String) - Constructor for class org.eclipse.persistence.sessions.factories.SessionFactory
 
SessionFactory(String, String) - Constructor for class org.eclipse.persistence.sessions.factories.SessionFactory
Constructor for creating a new EclipseLinkSessionHelper instance.
SessionFinalizer - Class in org.eclipse.persistence.internal.sessions
This is a finalizer for a session.
SessionFinalizer(Session) - Constructor for class org.eclipse.persistence.internal.sessions.SessionFinalizer
 
sessionLoadedFromSessionsXMLMustBeServerSession(String, String, Object) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
SessionLoaderException - Exception in org.eclipse.persistence.exceptions
 
SessionLoaderException() - Constructor for exception org.eclipse.persistence.exceptions.SessionLoaderException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
SessionLoaderException(String) - Constructor for exception org.eclipse.persistence.exceptions.SessionLoaderException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
SessionLoaderException(String, Throwable) - Constructor for exception org.eclipse.persistence.exceptions.SessionLoaderException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
SessionLoaderExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for SessionLoaderExceptionResource messages.
SessionLoaderExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.SessionLoaderExceptionResource
Default constructor.
sessionLog - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Destination for logged messages and SQL.
SessionLog - Interface in org.eclipse.persistence.logging
SessionLog is the ever-so-simple interface used by EclipseLink to log generated messages and SQL.
SessionLogEntry - Class in org.eclipse.persistence.logging
SessionLogEntry is a simple container object that holds all the information pertinent to an EclipseLink logging event.
SessionLogEntry(int, String, AbstractSession, String, Object[], Accessor, boolean) - Constructor for class org.eclipse.persistence.logging.SessionLogEntry
Create a new session log entry for a request level, a category, a session, a message, parameters and an accessor.
SessionLogEntry(int, AbstractSession, String, Object[], Accessor, boolean) - Constructor for class org.eclipse.persistence.logging.SessionLogEntry
Create a new session log entry for a request level, a session, a message, parameters and an accessor.
SessionLogEntry(AbstractSession) - Constructor for class org.eclipse.persistence.logging.SessionLogEntry
Create a new session log entry for a session.
SessionLogEntry(AbstractSession, int, String, Throwable) - Constructor for class org.eclipse.persistence.logging.SessionLogEntry
Create a new session log entry for a session, a level, a category and an exception.
SessionLogEntry(AbstractSession, String) - Constructor for class org.eclipse.persistence.logging.SessionLogEntry
Create a new session log entry for a session and a message.
SessionLogEntry(AbstractSession, String, Accessor) - Constructor for class org.eclipse.persistence.logging.SessionLogEntry
Create a new session log entry for a session, a message and an accessor.
SessionLogEntry(AbstractSession, Throwable) - Constructor for class org.eclipse.persistence.logging.SessionLogEntry
Create a new session log entry for a session and a throwable.
SessionManager - Class in org.eclipse.persistence.sessions.factories
Purpose: Global session location.
SessionManager() - Constructor for class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: The default constructor to create a new session manager.
sessionName - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
sessionName - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Used to override the default session in the session broker.
sessionName - Variable in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
Stores the name of the Session in the sessions XML file desired to be loaded.
SessionName - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
sessionNameAlreadyInUse(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
sessionNameNeedBeSpecified(String, String) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
sessionNamesByClass - Variable in class org.eclipse.persistence.sessions.broker.SessionBroker
 
sessionNamesRequired - Variable in class org.eclipse.persistence.internal.sessions.factories.SessionBrokerPlaceHolder
This member variable stores the sessions that need to be retreived
SessionProfiler - Interface in org.eclipse.persistence.sessions
Purpose: This interface defines the link between the Session and the PerformanceProfiler tool.
SessionProfilerAdapter - Class in org.eclipse.persistence.sessions
Adapter class for SessionProfiler interface.
SessionProfilerAdapter() - Constructor for class org.eclipse.persistence.sessions.SessionProfilerAdapter
 
sessionRemovedDuringDeployment(String) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
sessions - Variable in class org.eclipse.persistence.sessions.factories.SessionManager
 
SESSIONS_XML - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.sessions-xml" property configures the use of the specified native sessions.xml configuration file.
SESSIONS_XML_VALIDATION_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
sessionsByName - Variable in class org.eclipse.persistence.sessions.broker.SessionBroker
 
sessionsCompleted - Variable in class org.eclipse.persistence.internal.sessions.factories.SessionBrokerPlaceHolder
This member variable stores the sessions that have been retreived
SessionsFactory - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: Builds EclipseLink Sessions from the XML Session Config model.
SessionsFactory() - Constructor for class org.eclipse.persistence.internal.sessions.factories.SessionsFactory
INTERNAL:
SessionsSession_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
SessionTuner - Interface in org.eclipse.persistence.tools.tuning
Generic tuning interface.
sessionXMLValidationException(String, String, ValidationException) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
set() - Method in annotation type org.eclipse.persistence.annotations.VirtualAccessMethods
(Optional) The name of the setter method to use for the virtual property This method must take a java.lang.String parameter and a java.lang.Object parameter.
set(int, E) - Method in class org.eclipse.persistence.indirection.IndirectList
 
set(int, E) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
set(int, E) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
set(int, E) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
If index is missing wait until reached or complete.
set(int, Object) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
set(int, Object) - Method in class org.eclipse.persistence.internal.identitymaps.CacheId
Set the value in the primary key values.
set(Object) - Method in class org.eclipse.persistence.queries.ScrollableCursor
PUBLIC: Set is not supported for scrollable cursors.
set(Object, String, String) - Static method in class org.eclipse.persistence.config.PropertiesUtils
Attempts to parse and then set the provided kvs String into the appropriate set method on the provided instance.
set(String, Object) - Method in interface org.eclipse.persistence.dynamic.DynamicEntity
Set the persistence value for the given property to the specified value
set(String, Object) - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
set(String, Object, boolean) - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
Sets the.
set(DatabasePlatform, CallableStatement, String, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.BindCallCustomParameter
Sets this bound parameter, on the given statement, for the given parameterName.
set(DatabasePlatform, CallableStatement, String, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.InOutputParameterForCallableStatement
 
set(DatabasePlatform, CallableStatement, String, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.InParameterForCallableStatement
 
set(DatabasePlatform, CallableStatement, String, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
set(DatabasePlatform, PreparedStatement, int, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.BindCallCustomParameter
Sets this bound parameter, on the given statement, at the given parameterIndex.
set(DatabasePlatform, PreparedStatement, int, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.InOutputParameterForCallableStatement
 
set(DatabasePlatform, PreparedStatement, int, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.InParameterForCallableStatement
 
set(DatabasePlatform, PreparedStatement, int, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
Set_Class - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
SET_EXISTENCE_CHECKING_NOT_UNDERSTOOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
SET_IS_PROPERTY_METHOD_PREFIX - Static variable in class org.eclipse.persistence.internal.helper.Helper
 
SET_LISTENER_CLASSES_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
SET_METHOD_PARAMETER_TYPE_NOT_VALID - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
SET_PROPERTY_METHOD_PREFIX - Static variable in class org.eclipse.persistence.internal.helper.Helper
 
setAboutToDeleteSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called when an object's row it about to be inserted.
setAboutToInsertSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called when an object's row it about to be inserted.
setAboutToUpdateSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called when an object's row it about to be updated.
setAbstractValue(boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setAbstractValue(boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setAccessLevel(AccessLevel) - Method in class org.eclipse.persistence.internal.codegen.CodeDefinition
 
setAccessor(EISAccessor) - Method in class org.eclipse.persistence.eis.EISMappedRecord
Set the accessor.
setAccessor(Accessor) - Method in exception org.eclipse.persistence.exceptions.DatabaseException
INTERNAL: Set the Accessor.
setAccessor(Accessor) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Set the accessor.
setAccessor(Accessor) - Method in class org.eclipse.persistence.internal.sessions.ExclusiveIsolatedClientSession
INTERNAL: Provided for consistency.
setAccessor(Accessor) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the accessor, the query must always use the same accessor for database access.
setAccessor(DatabaseAccessor, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
INTERNAL: Sets the accessor that this mechanism will use
setAccessors(Collection<Accessor>) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the list of connection accessors to execute the query on.
setAccessorTree(List<AttributeAccessor>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
 
setAcquireWaitTime(long) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setActiveBatchWritingMechanism(BatchWritingMechanism) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
INTERNAL: This method is used to set the active Batch Mechanism on the accessor.
setActiveBatchWritingMechanismToDynamicSQL() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
INTERNAL: This method is used to set the active Batch Mechanism on the accessor.
setActiveBatchWritingMechanismToParameterizedSQL() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
INTERNAL: This method is used to set the active Batch Mechanism on the accessor.
setActiveCacheKey(CacheKey) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: PERF: Set the session cache-key, cached during the merge.
setActiveLocks(Vector<ConcurrencyManager>) - Method in class org.eclipse.persistence.internal.helper.DeferredLockManager
set a set of the active locks to the DLM
setActiveThread(Thread) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Set the active thread.
setAddAdditionalExpressionsWithinCurrrentExpressionContext(boolean) - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
INTERNAL: Allows keeping track when the normalizer is within a logical OR statement, where additionalExpressions might need to be added to the local expression instead of at the end of the where clause.
setAdditional(String) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Set any additional information about this field to be given when the table is created.
setAdditional(String) - Method in class org.eclipse.persistence.tools.schemaframework.TypeTableDefinition
PUBLIC: The name of the type that this table is of.
setAdditionalCriteria(String) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the additional join criteria that will be used to form the additional join expression.
setAdditionalExpression(Expression) - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
 
setAdditionalFieldExpressions_(List<Expression>) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Set the list of additional field expressions.
setAdditionalFields(List<Object>) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Additional fields can be added to a query.
setAdditionalJoinExpression(Expression) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the additional join expression.
setAdditionalProjects(Vector<ProjectConfig>) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.DatabaseSessionConfig
 
setAdditionalTablePrimaryKeyFields(Map<DatabaseTable, Map<DatabaseField, DatabaseField>>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: This is used to map the primary key field names in a multiple table descriptor.
setAdditionalTablePrimaryKeyFields(DatabaseTable, DatabaseField, DatabaseField) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: This is used to map the primary key field names in a multiple table descriptor.
setAddObjectList(Map<ObjectChangeSet, ObjectChangeSet>) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Sets the Added objects list.
setAddObjects(HashMap) - Method in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
Sets the added items list.
setAddTargetSQLString(String) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
PUBLIC:
setAggregateChangeListener(Object, Object, UnitOfWorkImpl, ClassDescriptor, String) - Method in class org.eclipse.persistence.descriptors.changetracking.AttributeChangeTrackingPolicy
INTERNAL: Assign ChangeListener to an aggregate object
setAggregateChangeListener(Object, Object, UnitOfWorkImpl, ClassDescriptor, String) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: Assign ChangeListener to an aggregate object
setAggregateChangeListener(Object, Object, UnitOfWorkImpl, ClassDescriptor, String) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: Assign Changelistener to an aggregate object
setAggregateChangeListener(Object, Object, UnitOfWorkImpl, ClassDescriptor, String) - Method in class org.eclipse.persistence.descriptors.changetracking.ObjectChangeTrackingPolicy
INTERNAL: Assign ChangeListener to an aggregate object
setAggregateQuery(DatabaseMapping, ObjectLevelReadQuery) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Set the aggregate query clone for the mapping.
setAggregateToSourceFieldAssociations(Vector<Association>) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Set a collection of the aggregate to source field name associations.
setAggregateToSourceFields(Map<String, DatabaseField>) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Set the hashtable that stores target field name to the source field name.
setAlias(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the alias
setAliasDescriptors(Map<String, ClassDescriptor>) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set the alias descriptors hashtable.
setAliasedFieldsForJoin(Vector) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
setAll(All) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setAll(All) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
setAll(All) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
setAll(All) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setAllChangeSets(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Sets the collection of ObjectChanges in the change Set.
setAllChildClassIndicators(Vector) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL:
setAllClonesCollection(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Used to set the collections of all objects in the UnitOfWork.
setAllFields(Collection) - Method in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
setAllFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set all the fields.
setAllNonPrimaryKeyFields(List<DatabaseField>) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Set method for all the primary keys
setAllowConcurrencyExceptionToBeFiredUp(boolean) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setAllowExtendedCacheLogging(boolean) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set whether extended logging of JPA L2 cache usage is allowed on this project.
setAllowExtendedThreadLogging(boolean) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set whether extended thread logging is allowed on this project.
setAllowExtendedThreadLoggingThreadDump(boolean) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set if thread dumps will be added to extended thread logging.
setAllowInterruptedExceptionFired(boolean) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setAllowNativeSQLQueries(boolean) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set whether native sql is allowed on this project.
setAllowNativeSQLQuery(Boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set to true if this individual query should be marked to bypass a persistence unit level disallow SQL queries flag.
setAllowSQLDeferral(boolean) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set whether sql deferral is allowed on this project
setAllowTablePerMultitenantDDLGeneration(boolean) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set whether ddl generation should allowed for table per tenant multitenant descriptors.
setAllowTakingStackTraceDuringReadLockAcquisition(boolean) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setAllQueries(Vector) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Set pre-defined queries for the descriptor.
setAllSubclasses(Map<Object, CoreAttributeGroup>) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
INTERNAL:
setAlwaysUseOuterJoinForClassType(boolean) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Sets the inheritance policy to always use an outer join when querying across a relationship of class.
setAmendmentClass(Class<?>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the amendment class.
setAmendmentClassName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return the amendment class name, used by the MW.
setAmendmentMethodName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the amendment method.
setAnnotation(Annotation) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setAnnotation(Annotation) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
setAnnotation(Annotation) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
setAnnotation(Annotation) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
setAnnouncementDelay(int) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.discovery.DiscoveryConfig
 
setAnnouncementDelay(int) - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
PUBLIC: Set the amount of time in millis that the service should wait between the time that this Remote Service is available and a session announcement is sent out to other discovery managers.
setAnyAttribute(AnyAttribute) - Method in class org.eclipse.persistence.internal.oxm.schema.model.AttributeGroup
 
setAnyAttribute(AnyAttribute) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setAnyAttribute(AnyAttribute) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
setAnyAttribute(AnyAttribute) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setAnyAttributeNodeValue(MappingNodeValue) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
setAnyNode(XPathNode) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
setAnys(List<Any>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
setAnys(List<Any>) - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
setAnys(List<Any>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
setAppInfo(List<Element>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Annotation
 
setApplicationName(String) - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
INTERNAL:
setArgumentIndices(int[]) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Set the array of indexes to use when building the SQL function.
setArgumentName(String) - Method in class org.eclipse.persistence.internal.descriptors.InteractionArgument
 
setArgumentNames(Vector<String>) - Method in class org.eclipse.persistence.eis.interactions.MappedInteraction
INTERNAL: The argument names for the input record.
setArguments(List<String>) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the arguments for use with the pre-defined query option.
setArguments(List<PLSQLargument>) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
Set the PLSQL arguments.
setArguments(List<FieldDefinition>) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The arguments are the field defs of the parameters names and types to the procedure.
setArguments(Vector) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
INTERNAL: The argument fields or values to the interaction that map into the input record.
setArguments(Vector) - Method in class org.eclipse.persistence.eis.interactions.IndexedInteraction
The arguments are the values in order of occurance in the record.
setArgumentTypeNames(List<String>) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the argumentTypes for use with the pre-defined query option
setArgumentTypes(List<Class<?>>) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the argumentTypes for use with the pre-defined query option
setArgumentValues(List<Object>) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the argumentValues for use with argumented queries.
setAsOfClause(AsOfClause) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
ADVANCED: Sets the query to execute as of the past time.
setAssignedFields(Collection) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForTempTable
 
setAttachmentMarshaller(XMLAttachmentMarshaller) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
setAttachmentUnmarshaller(XMLAttachmentUnmarshaller) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
setAttribute(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.VariableXPathObjectMapping
 
setAttribute(boolean) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setAttribute(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
setAttribute(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
setAttribute(String) - Method in class org.eclipse.persistence.internal.sessions.ChangeRecord
Sets the name of the attribute that this Record represents.
setAttributeAccessor(ATTRIBUTE_ACCESSOR) - Method in class org.eclipse.persistence.core.mappings.CoreMapping
ADVANCED: Set the attributeAccessor.
setAttributeAccessor(ATTRIBUTE_ACCESSOR) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
ADVANCED: Set the attributeAccessor.
setAttributeAccessor(AttributeAccessor) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: Set the attributeAccessor.
setAttributeClassification(Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
Some databases do not properly support all of the base data types.
setAttributeClassification(Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
Some databases do not properly support all of the base data types.
setAttributeClassification(Class<?>) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Some databases do not properly support all of the base data types.
setAttributeClassification(Class<?>) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
PUBLIC: Some databases do not properly support all of the base data types.
setAttributeClassificationName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
INTERNAL: Set the name of the class for MW usage.
setAttributeClassificationName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
INTERNAL: Set the name of the class for MW usage.
setAttributeClassificationName(String) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Set the name of the class for MW usage.
setAttributeClassificationName(String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Set the name of the class for MW usage.
setAttributeElementClass(Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
Set the class each element in the object's collection should be converted to, before the collection is inserted into the object.
setAttributeElementClass(Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
Set the class each element in the object's collection should be converted to, before the collection is inserted into the object.
setAttributeElementClass(Class<?>) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
PUBLIC: Set the class each element in the object's collection should be converted to, before the collection is inserted into the object.
setAttributeElementClass(Class<?>) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
PUBLIC: Set the class each element in the object's collection should be converted to, before the collection is inserted into the object.
setAttributeElementClassName(String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
PUBLIC: Set the class each element in the object's collection should be converted to, before the collection is inserted into the object.
setAttributeExpression(Expression) - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
setAttributeExpressions(List<Expression>) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
 
setAttributeField(Field) - Method in class org.eclipse.persistence.internal.descriptors.InstanceVariableAttributeAccessor
Sets the value of the attributeField.
setAttributeFormDefault(boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setAttributeGroups(Map<String, AttributeGroup>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setAttributeName(String) - Method in class org.eclipse.persistence.core.mappings.CoreMapping
PUBLIC: Sets the name of the attribute in the mapping.
setAttributeName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
Sets the name of the attribute in the mapping.
setAttributeName(String) - Method in class org.eclipse.persistence.mappings.AttributeAccessor
INTERNAL: Set the attribute name.
setAttributeName(String) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: Sets the name of the attribute in the mapping.
setAttributeNames(Set) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
setAttributePrefix(String) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Value that will be used to prefix attributes.
setAttributePrefix(String) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Value that will be used to prefix attributes.
setAttributes(List<String>) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: PERF: Set the cached local (only) batch read attribute names.
setAttributes(List<Attribute>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.AttributeGroup
 
setAttributes(List<Attribute>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setAttributes(Attributes) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setAttributes(Attributes) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setAttributes(Attributes) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setAttributesMap(Map<QName, String>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setAttributesMap(Map<QName, String>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setAttributesMap(Map<QName, String>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
setAttributesMap(Map<QName, String>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
setAttributesToAlwaysInclude(Map) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
INTERNAL: It is possible to generate a Hashtable (keys are the Class, and values the attribute names) of the attributes to be included at all times (even if the value is null, or the value belongs to the values to be excluced automatically).
setAttributeToFieldValues(Map) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Set the attribute to field mapping.
setAttributeTransformation(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.TransformationMapping
To set the attribute method name.
setAttributeTransformation(String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: To set the attribute method name.
setAttributeTransformationMethod(Method) - Method in class org.eclipse.persistence.mappings.transformers.MethodBasedAttributeTransformer
 
setAttributeTransformer(AttributeTransformer) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Set the AttributeTransformer, this transformer will be used to extract the value for the object's attribute from the database row.
setAttributeTransformerClass(Class<?>) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Set the attribute transformer's class.
setAttributeTransformerClassName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.TransformationMapping
INTERNAL: Set the Attribute Transformer Class Name
setAttributeTransformerClassName(String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Set the Attribute Transformer Class Name
setAttributeValue(Object, Mapping) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setAttributeValue(Object, Mapping) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
INTERNAL
setAttributeValue(Object, Mapping) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setAttributeValue(UnmarshalRecord, Object, Mapping) - Method in class org.eclipse.persistence.internal.oxm.ChoiceUnmarshalContext
 
setAttributeValue(UnmarshalRecord, Object, Mapping) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectUnmarshalContext
 
setAttributeValue(UnmarshalRecord, Object, Mapping) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedUnmarshalContext
 
setAttributeValue(UnmarshalRecord, Object, Mapping) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalContext
The UnmarshalContext is responsible for assigning values to the object being built.
setAttributeValueInObject(Object, Object) - Method in interface org.eclipse.persistence.core.mappings.CoreAttributeAccessor
Set the attribute value into the object.
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Set the value of the attribute mapped by this mapping.
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.descriptors.InstanceVariableAttributeAccessor
Sets the value of the instance variable in the object to the value.
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Sets the value of the instance variable in the object to the value.
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.descriptors.MultitenantPrimaryKeyAccessor
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.descriptors.PersistenceObjectAttributeAccessor
Sets the value of the instance variable in the object to the value.
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeAccessor
Sets the value of the instance variable in the object to the value.
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.dynamic.ValuesAccessor
 
setAttributeValueInObject(Object, Object) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.IsSetNullPolicyIsSetParametersAttributeAccessor
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.IsSetNullPolicyIsSetParameterTypesAttributeAccessor
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.NullPolicyAttributeAccessor
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.mappings.AttributeAccessor
Set the attribute value into the object.
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Set the value of the attribute mapped by this mapping.
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: Set the value of the attribute mapped by this mapping.
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Check for write-only, one-way transformations.
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLAbstractAnyMapping
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
 
setAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
 
setAttributeValueInObject(Object, Object, Object[]) - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Sets the value of the instance variable in the object to the value.
setAttributeValueNull(ContainerValue) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setAttributeValueNull(ContainerValue) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setAttributeValueNull(ContainerValue) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setAutoDetectMediaType(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Set if this XMLUnmarshaller should try to automatically determine the MediaType of the document (instead of using the MediaType set by setMediaType)
setBackupClone(Object) - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
INTERNAL: Set the backup clone of the object from the unit of work.
setBackupValueHolder(ValueHolderInterface<T>) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
setBaseExpression(Expression) - Method in class org.eclipse.persistence.internal.expressions.BaseExpression
The base expression is what the parameter was derived from.
setBaseExpressionBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
This method is called from within this package, it is used when initializing a ReportItem
setBaseQuery(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
This method is called from within this package it is used when initializing a report Item
setBaseType(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
setBaseType(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setBatchedMappings(List<DatabaseMapping>) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Set any mappings that are always batched.
setBatchExecutionSupported(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Set if this query is compatible with batch writing.
setBatchFetchPolicy(BatchFetchPolicy) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Set the batch fetch policy for configuring batch fetching.
setBatchFetchSize(int) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Set the batch fetch size for the query.
setBatchFetchType(BatchFetchType) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Set the type of batch fetching to use for all queries for this class.
setBatchFetchType(BatchFetchType) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Set the batch fetch type for the query.
setBatchObjects(Map<Object, Object>) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Set temporary map of batched objects.
setBatchObjects(Map<Object, Object>) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set temporary map of batched objects.
setBatchObjects(Map<Object, Object>) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Set temporary map of batched objects.
setBatchQueries(Map<ReadQuery, ReadQuery>) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: When in transaction batch read objects must use query local to the unit of work.
setBatchReadAttributeExpressions(List<Expression>) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Set all attributes specified for batch reading.
setBatchWriting(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setBatchWritingMechanism(BatchWritingMechanism) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Set the custom batch writing mechanism.
setBidirectionalTargetAccessor(AttributeAccessor) - Method in class org.eclipse.persistence.oxm.mappings.BidirectionalPolicy
Sets the AttributeAccessor that is used to get and set the value of the container on the target object.
setBidirectionalTargetAttributeName(String) - Method in class org.eclipse.persistence.oxm.mappings.BidirectionalPolicy
Sets the name of the backpointer attribute on the target object.
setBidirectionalTargetContainerClass(Class<?>) - Method in class org.eclipse.persistence.oxm.mappings.BidirectionalPolicy
 
setBidirectionalTargetContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.oxm.mappings.BidirectionalPolicy
 
setBidirectionalTargetGetMethodName(String) - Method in class org.eclipse.persistence.oxm.mappings.BidirectionalPolicy
Sets the method name to be used when accessing the value of the back pointer on the target object of this mapping.
setBidirectionalTargetSetMethodName(String) - Method in class org.eclipse.persistence.oxm.mappings.BidirectionalPolicy
Sets the name of the method to be used when setting the value of the back pointer on the target object of this mapping.
setBindAllParameters(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setBroker(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Allow the session to be used from a session broker.
setBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
setBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.internal.expressions.SQLStatement
 
setBuildObjectCompleteWaitTime(long) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setByteArrayBinding(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setCacheable(Boolean) - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Set entity @Cacheable annotation value.
setCacheable(Boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set entity @Cacheable annotation value in cache configuration object.
setCacheAllStatements(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setCacheCoordinationType(CacheCoordinationType) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Set the type of cache coordination that will be used on objects of this type.
setCachedConnection(Accessor) - Method in class org.eclipse.persistence.sessions.server.ExternalConnectionPool
Set the currently cached connection to the external connection pool.
setCacheIndexes(Map<List<DatabaseField>, CacheIndex>) - Method in class org.eclipse.persistence.descriptors.CachePolicy
 
setCacheInterceptorClass(Class<? extends CacheInterceptor>) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: A CacheInterceptor is an adaptor that when overridden and assigned to a Descriptor all interaction between EclipseLink and the internal cache for that class will pass through the Interceptor.
setCacheInterceptorClass(Class<? extends CacheInterceptor>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: A CacheInterceptor is an adaptor that when overridden and assigned to a Descriptor all interaction between EclipseLink and the internal cache for that class will pass through the Interceptor.
setCacheInterceptorClassName(String) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: A CacheInterceptor is an adaptor that when overridden and assigned to a Descriptor all interaction between EclipseLink and the internal cache for that class will pass through the Interceptor.
setCacheInterceptorClassName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: A CacheInterceptor is an adaptor that when overridden and assigned to a Descriptor all interaction between EclipseLink and the internal cache for that class will pass through the Interceptor.
setCacheInvalidationPolicy(CacheInvalidationPolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the Cache Invalidation Policy for this descriptor.
setCacheInvalidationPolicy(CacheInvalidationPolicy) - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Set the query cache invalidation policy.
setCacheIsolation(CacheIsolationType) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Controls how the Entity instances and data will be cached.
setCacheIsolation(CacheIsolationType) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Controls how the Entity instances and data will be cached.
setCacheKeys(Map<Object, CacheKey>) - Method in class org.eclipse.persistence.internal.identitymaps.FullIdentityMap
 
setCacheKeyThreadWantsToAcquireButCannotGet(ConcurrencyManager) - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
setCacheKeyType(CacheKeyType) - Method in class org.eclipse.persistence.descriptors.CachePolicy
ADVANCED: Set what cache key type to use to store the object in the cache.
setCacheKeyType(CacheKeyType) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Set what cache key type to use to store the object in the cache.
setCacheMutex(ConcurrencyManager) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Set the cache mutex.
setCachePolicy(CachePolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Set cache policy for the descriptor.
setCacheSize(int) - Method in class org.eclipse.persistence.descriptors.CacheIndex
ADVANCED: Set the cache size.
setCacheSync(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.rcm.command.CommandsConfig
 
setCacheSynchronizationType(int) - Method in class org.eclipse.persistence.descriptors.CachePolicy
OBSOLETE: Set the type of cache coordination that will be used on objects of this type.
setCacheSynchronizationType(int) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the type of cache synchronization that will be used on objects of this type.
setCacheSynchronizationType(int) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
setCacheTransactionIsolation(int) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
ADVANCED: By default concurrency is optimized and the cache is not locked more than required during reads or writes, This allows for virtual concurrent reading and writing and should never cause any problems.
setCacheType(Class<? extends IdentityMap>) - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Set the type of the cache used for the query results.
setCacheType(Class<? extends WeakIdentityMap>) - Method in class org.eclipse.persistence.descriptors.CacheIndex
ADVANCED: Set the type of the cache used for the index.
setCacheType(String) - Method in class org.eclipse.persistence.services.ClassSummaryDetailBase
 
setCacheUsage(int) - Method in class org.eclipse.persistence.queries.ModifyAllQuery
PUBLIC: Set the level of cache support for this query, either NONE or INVALIDATE.
setCacheUsage(int) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Set the cache usage.
setCall(DatasourceCall) - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Set the call.
setCall(Call) - Method in exception org.eclipse.persistence.exceptions.DatabaseException
INTERNAL: Set the call that caused the exception.
setCall(Call) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Used to define a store procedure or SQL query.
setCall(Call) - Method in class org.eclipse.persistence.sessions.SessionEvent
INTERNAL: Some events may have a call associated with them (pre/postExecuteCall).
setCall(SQLCall) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
setCallbackName(String) - Method in class org.eclipse.persistence.oxm.JSONWithPadding
The callback name that should me marshalled with the object
setCallbackName(String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
setCallCount(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Used for load balancing and external pooling.
setCallFromStatement() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Pre-build the SQL call from the statement.
setCallHasCustomSQLArguments() - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
INTERNAL: Configure the call to be a dynamic custom SQL call, so that it ignores the # token.
setCalls(Vector) - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Normally only a single call is used, however multiple table may require multiple calls on write.
setCanBind(Boolean) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: Set to true if this expression can bind parameters Set to false if this expression cannot bind parameters Set to null to indicate no specific preference
setCanBind(Boolean) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Set to true if this expression can bind parameters Set to false if this expression cannot bind parameters Set to null to indicate no specific preference
setCascadeAll(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Sets the cascading for all JPA operations.
setCascadeCondition(DescriptorIterator.CascadeCondition) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setCascadeDeleteObjects(Set<Object>) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Set any objects have been deleted through database cascade delete constraints.
setCascadeDepth(int) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setCascadeDetach(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Sets the cascading for the JPA detach operation.
setCascadeMerge(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Sets the cascading for the JPA MERGE operation.
setCascadePersist(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Sets the cascading for the JPA CREATE operation.
setCascadePolicy(int) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
setCascadePolicy(int) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the cascade policy.
setCascadeRefresh(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Sets the cascading for the JPA REFRESH operation.
setCascadeRemove(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Sets the cascading for the JPA REMOVE operation.
setCaseInsensitive(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Set true to make this Unmarshaller perform case insensitive unmarshalling.
setCastClass(Class<?>) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
setCastSizeForVarcharParameter(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
ADVANCED: Set the maximum length allowed by the database for a Varchar Parameter This is used by subclasses when writing SQL for parameters
setCaughtExceptions(Vector<Exception>) - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
INTERNAL:
setChangedIndexes(Map) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
setChangedObject(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.sessions.AggregateChangeRecord
INTERNAL: This method is used to set the changed value or values.
setChangedValues(List<ObjectChangeSet>) - Method in class org.eclipse.persistence.internal.sessions.AggregateCollectionChangeRecord
INTERNAL: Set the changed values.
setChangeListener(Object, PropertyChangeListener, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Set the change listener in the aggregate.
setChangeListener(Object, PropertyChangeListener, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Set the change listener in the collection.
setChangeListener(Object, PropertyChangeListener, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Set the change listener if required.
setChangeListener(Object, UnitOfWorkImpl, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.changetracking.AttributeChangeTrackingPolicy
INTERNAL: Assign AttributeChangeListener to PropertyChangeListener
setChangeListener(Object, UnitOfWorkImpl, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: Set ChangeListener for the clone
setChangeListener(Object, UnitOfWorkImpl, ClassDescriptor) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: Assign appropriate ChangeListener to PropertyChangeListener based on the policy.
setChangeListener(Object, UnitOfWorkImpl, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.changetracking.ObjectChangeTrackingPolicy
INTERNAL: Assign ObjectChangeListener to PropertyChangeListener
setChanges(List) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Set the changes.
setChangeSet(ObjectChangeSet) - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
INTERNAL: Sets the Change set in the event if the change Set is available
setChangeSet(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.sessions.OrderedChangeObject
INTERNAL: Set the ObjectChangeSet representing the change made to the collection
setChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.sessions.coordination.MergeChangeSetCommand
INTERNAL: Set the changes to be applied
setChangeSetOnListener(ObjectChangeSet, Object) - Method in class org.eclipse.persistence.descriptors.changetracking.AttributeChangeTrackingPolicy
INTERNAL: Set the ObjectChangeSet on the Listener, initially used for aggregate support
setChangeSetOnListener(ObjectChangeSet, Object) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: Set the ObjectChangeSet on the Listener, initially used for aggregate support
setChangeSetOnListener(ObjectChangeSet, Object) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: Set the ObjectChangeSet on the Listener, initially used for aggregate support
setChangeType(int) - Method in class org.eclipse.persistence.internal.sessions.OrderedChangeObject
INTERNAL: Set the type of collection change operation this object represents (CollectionChangeEvent.REMOVE or CollectionChangeEvent.ADD)
setChannel(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.rcm.RemoteCommandManagerConfig
 
setChannel(String) - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
ADVANCED: Set the service channel for this command manager.
setChannel(String) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
ADVANCED: Set the service channel for this command manager.
setChannel(String) - Method in class org.eclipse.persistence.sessions.coordination.ServiceId
INTERNAL: Set the logical channel that this service subscribes to
setCharacterEscapeHandler(CHARACTER_ESCAPE_HANDLER) - Method in class org.eclipse.persistence.internal.oxm.Marshaller
Set this Marshaller's CharacterEscapeHandler.
setCharacterEscapeHandler(CharacterEscapeHandler) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
Set this Marshaller's CharacterEscapeHandler.
setCheckCacheFirst(boolean) - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Sets checkCacheFirst flag.
setCheckConnections() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: This method is called to indicate that all available connections should be checked.
setCheckConnections() - Method in class org.eclipse.persistence.sessions.server.ExternalConnectionPool
INTERNAL: This method is called to indicate that all available connections should be checked.
setCheckDatabaseIfInvalid(boolean) - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Sets checkDatabaseIfInvalid flag.
setChildDescriptors(List<ClassDescriptor>) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL:
setChildRecord(UnmarshalRecord) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setChildRecord(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setChildRecord(UnmarshalRecord) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setChildrenLookupTableFilled(boolean) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
setChoice(Choice) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setChoice(Choice) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
setChoice(Choice) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
setChoice(Choice) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setChoiceElementMappingsByClass(Map<Class<?>, XMLMapping>) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
setChoiceElementMappingsByClass(Map<Class<?>, XMLMapping>) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
setChoiceFieldToClassAssociations(ArrayList) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
setChoiceFieldToClassAssociations(ArrayList) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
setChoices(List<Choice>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
setChoices(List<Choice>) - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
setChoices(List<Choice>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
setClassExtractionMethod(Method) - Method in class org.eclipse.persistence.descriptors.MethodClassExtractor
INTERNAL:
setClassExtractionMethodName(String) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: A class extraction method can be registered with the descriptor to override the default inheritance mechanism.
setClassExtractionMethodName(String) - Method in class org.eclipse.persistence.descriptors.MethodClassExtractor
PUBLIC: A class extraction method can be registered with the descriptor to override the default inheritance mechanism.
setClassExtractor(ClassExtractor) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: A class extractor can be registered with the descriptor to override the default inheritance mechanism.
setClassExtractorName(String) - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
ADVANCED: Set the class extractor class name.
setClassExtractorName(String) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: Set the class extractor class name.
setClassIndicatorAssociations(Vector) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Set the class indicator associations from reading the deployment XML.
setClassIndicatorAssociations(Vector) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
PUBLIC: Set the class indicator associations.
setClassIndicatorField(FIELD) - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
ADVANCED: To set the class indicator field.
setClassIndicatorField(DatabaseField) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: To set the class indicator field.
setClassIndicatorFieldName(String) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: To set the class indicator field name.
setClassIndicatorFieldName(String) - Method in class org.eclipse.persistence.internal.oxm.QNameInheritancePolicy
PUBLIC: To set the class indicator field name.
setClassIndicatorMapping(Map) - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
PUBLIC: Set the association of indicators and classes.
setClassIndicatorMapping(Map) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Set the association of indicators and classes.
setClassLoader(ClassLoader) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: Set the class loader that should be used to find the resource.
setClassName(String) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceFieldToClassAssociation
 
setClassName(String) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Set the class name.
setClassName(String) - Method in class org.eclipse.persistence.services.ClassSummaryDetailBase
 
setClassName(String) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Set the name of class to be generated.
setClassName(String) - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Set the name of class to be generated.
setClassNameIndicatorMapping(Map) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Set the class name indicator mapping, used by the MW.
setClassNamesForWeaving(Collection<String>) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Returns all classes in this project that are needed for weaving.
setClassToConvertTo(Class<?>) - Method in exception org.eclipse.persistence.exceptions.ConversionException
INTERNAL: Set the class to convert to.
setClassType(Class<?>) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Set the class type.
setClassTypes(Map<String, Class<?>>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setClonedExpressions(Map<Expression, Expression>) - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
 
setCloneMapping(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Set the clone mapping.
setCloneMethod(Method) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Set the Method that will return a clone of an instance of the containerClass.
setCloneToObjectChangeSet(Map<Object, ObjectChangeSet>) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: This method is used to set the map for cloneToObject reference.
setCMPPolicy(CMPPolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Set the cmp descriptor that holds cmp specific information.
setCollapsingStringValues(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
Indicates that this mapping should collapse all string values before adding them to the collection on unmarshal.
setCollapsingStringValues(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
Indicates that this mapping should collapse all string values before setting them in the object on unmarshal.
setCollapsingStringValues(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
PUBLIC: Indicates that this mapping should collapse all string values before adding them to the collection on unmarshal.
setCollapsingStringValues(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
PUBLIC: Indicates that this mapping should collapse all string values before setting them in the object on unmarshal.
setCollection(boolean) - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord.Level
 
setCollection(boolean) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
setCollection(boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
setCollectionContentType(Class<?>) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
setColumnDefinition(String) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Set the SQL fragment that is used when generating the DDL for the column.
setColumnResults(List<ColumnResult>) - Method in class org.eclipse.persistence.queries.ConstructorResult
Set columns result of this constructor result.
setCommandConverter(CommandConverter) - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
ADVANCED: Set the converter instance that will be invoked by this CommandProcessor to convert commands from their application command format into EclipseLink Command objects before being propagated to remote command manager services.
setCommandConverter(CommandConverter) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
ADVANCED: Set the converter instance that will be invoked by this CommandProcessor to convert commands from their application command format into EclipseLink Command objects before being propagated to remote command manager services.
setCommandManager(CommandManager) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Set the CommandManager that allows this session to act as a CommandProcessor and receive or propagate commands from/to the EclipseLink cluster.
setCommandManager(CommandManager) - Method in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
PUBLIC: Set the CommandManager that will invoke this CommandProcessor to process a command, and can be used to send remote commands out to other CommandProcessors in the cluster.
setCommandManager(CommandManager) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
ADVANCED: Set the CommandManager that allows this session to act as a CommandProcessor and receive or propagate commands from/to the EclipseLink cluster.
setCommandProcessor(CommandProcessor) - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
ADVANCED: Set the command processor that will be invoked to process commands.
setCommandProcessor(CommandProcessor) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
setCommandsConfig(CommandsConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.rcm.RemoteCommandManagerConfig
 
setComment(String) - Method in class org.eclipse.persistence.internal.codegen.CodeDefinition
 
setCommitAddition(Hashtable) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
This method takes a hashtable of primitives and adds them to the commit list.
setCommitManager(CommitManager) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: The commit manager is used to resolve referncial integrity on commits of multiple objects.
setCommitOrder(List) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Set the order in which objects should be committed to the database.
setCommitOrder(UnitOfWork.CommitOrderType) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Set the commit order.
setCommitOrder(UnitOfWork.CommitOrderType) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Set the commit order.
setCommunicationFailure(boolean) - Method in exception org.eclipse.persistence.exceptions.DatabaseException
 
setComparator(Comparator) - Method in class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
INTERNAL: Sets a comparator object for this policy to use when instantiating a new SortedSet object.
setComparatorClass(Class<?>) - Method in class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
INTERNAL: Sets a comparator class for this policy to use when instantiating a new SortedSet object.
setComparatorClassName(String) - Method in class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
INTERNAL: Sets a comparator class name for this policy to use when instantiating a new SortedSet object.
setCompatibleType(String) - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
setCompatibleType(String) - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
Oracle ARRAY types don't have a compatible type like PL/SQL types do, so we will use the type name
setCompatibleType(String) - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
Oracle STRUCT types don't have a compatible type like PL/SQL types do, so we will use the type name
setComplex(boolean) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
setComplex(JsonBuilderRecord.Level, boolean) - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord
 
setComplex(JsonRecord.Level, boolean) - Method in class org.eclipse.persistence.oxm.record.JsonGeneratorRecord
 
setComplex(T, boolean) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
setComplexContent(ComplexContent) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setComplexType(ComplexType) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setConcurrencySemaphoreLogTimeout(long) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setConcurrencySemaphoreMaxTimePermit(long) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setConfig(String) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
Generic API to allow config to be set.
setConfiguredSize(String) - Method in class org.eclipse.persistence.services.ClassSummaryDetailBase
 
setConnection(Accessor) - Method in class org.eclipse.persistence.logging.EclipseLinkLogRecord
 
setConnection(Accessor) - Method in class org.eclipse.persistence.logging.SessionLogEntry
Set the connection that generated the log entry.
setConnectionFactory(ConnectionFactory) - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Set the jakarta.resource.cci.ConnectionFactory.
setConnectionFactoryObject(Object) - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Set the jakarta.resource.cci.ConnectionFactory.
setConnectionFactoryURL(String) - Method in class org.eclipse.persistence.eis.EISLogin
PUBLIC: Set the JNDI URL for the managed connection factory for the JCA adapter connecting to.
setConnectionFactoryURL(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.EISLoginConfig
 
setConnectionHealthValidatedOnError(boolean) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: On an SQL Exception EclipseLink will ping the database to determine if the connection used can continue to be used for queries.
setConnectionHealthValidatedOnError(Boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setConnectionPolicy(ConnectionPolicy) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Set the connection policy.
setConnectionPolicyConfig(ConnectionPolicyConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.ServerSessionConfig
 
setConnectionPool(String) - Method in class org.eclipse.persistence.descriptors.partitioning.PinnedPartitioningPolicy
PUBLIC: Set the connection pool to pin queries to.
setConnectionPool(String) - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartition
PUBLIC: Return the connection pool to use for this partition.
setConnectionPool(ConnectionPool) - Method in interface org.eclipse.persistence.sequencing.SequencingControl
ADVANCED: Set the connection pool to use for sequencing.
setConnectionPoolConfigs(Vector<ConnectionPoolConfig>) - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.PoolsConfig
 
setConnectionPools(List<String>) - Method in class org.eclipse.persistence.descriptors.partitioning.HashPartitioningPolicy
PUBLIC: Set the list of connection pool names to replicate queries to.
setConnectionPools(List<String>) - Method in class org.eclipse.persistence.descriptors.partitioning.ReplicationPartitioningPolicy
PUBLIC: Set the list of connection pool names to replicate queries to.
setConnectionPools(Map<String, ConnectionPool>) - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Connection are pooled to share and restrict the number of database connections.
setConnectionsAvailable(Vector) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: Set this list of connections available
setConnectionSpec(ConnectionSpec) - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Set the jakarta.resource.cci.ConnectionSpec.
setConnectionSpec(EISConnectionSpec) - Method in class org.eclipse.persistence.eis.EISLogin
PUBLIC: Set the EclipseLink connection spec.
setConnectionSpecClass(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.EISLoginConfig
 
setConnectionSpecObject(Object) - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Set the jakarta.resource.cci.ConnectionSpec.
setConnectionString(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the JDBC connection string.
setConnectionsUsed(Vector) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: Set the list of connections being used.
setConnectionURL(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setConnector(Connector) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Set the connector that will instantiate the connection.
setConstraint(String) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Set any constraint of this field.
setConstraintDependencies(Vector) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: automatically orders database access through the foreign key information provided in 1:1 and 1:m mappings.
setConstructor(Constructor) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Set the size constructor if available.
setConstructor(Constructor) - Method in class org.eclipse.persistence.queries.ConstructorReportItem
INTERNAL: Set the constructor.
setConstructorArgTypes(Class<?>[]) - Method in class org.eclipse.persistence.queries.ConstructorReportItem
 
setConstructorMappings(List<DatabaseMapping>) - Method in class org.eclipse.persistence.queries.ConstructorReportItem
INTERNAL: Return the mappings for the items.
setContainerAccessor(AttributeAccessor) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
Deprecated.
Replaced by getInverseReferenceMapping().setAttributeAccessor()
setContainerAccessor(AttributeAccessor) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
Deprecated.
Replaced by getInverseReferenceMapping().setAttributeAccessor()
setContainerAttributeName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
Deprecated.
Replaced by getInverseReferenceMapping().setAttributeName()
setContainerAttributeName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
Deprecated.
Replaced by getInverseReferenceMapping().setAttributeName()
setContainerBeans(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This is only used for EJB entity beans to manage beans accessed in a transaction context.
setContainerClass(Class<?>) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Set the class used for the container.
setContainerClass(Class<?>) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
Sets the Container class which implements IndirectContainer
setContainerClass(Class<?>) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Set the class used for the container.
setContainerClass(Class<?>) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
INTERNAL: Set the class to use as the container.
setContainerClassName(String) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Used by the MW
setContainerClassName(String) - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
 
setContainerGetMethodName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
Deprecated.
Replaced by getInverseReferenceMapping().setGetMethodName()
setContainerGetMethodName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
Deprecated.
Replaced by getInverseReferenceMapping().setGetMethodName()
setContainerInstance(int, Object) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setContainerInstance(int, Object) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setContainerInstance(int, Object) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setContainerInstance(Object, Object) - Method in interface org.eclipse.persistence.internal.oxm.ContainerValue
 
setContainerInstance(Object, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
 
setContainerInstance(Object, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
setContainerInstance(Object, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
setContainerInstance(Object, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
setContainerInstance(Object, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
setContainerInstance(Object, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
 
setContainerInstance(Object, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
 
setContainerInstance(Object, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
setContainerInstance(Object, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
setContainerInstance(Object, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
 
setContainerInstance(Object, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
setContainerNodeValue(XMLChoiceCollectionMappingUnmarshalNodeValue) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
setContainerPolicy(CONTAINER_POLICY) - Method in interface org.eclipse.persistence.internal.oxm.mappings.InverseReferenceMapping
 
setContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.mappings.CollectionMapping
ADVANCED: Configure the mapping to use a container policy.
setContainerPolicy(ContainerPolicy) - Method in interface org.eclipse.persistence.mappings.ContainerMapping
PUBLIC: Set the mapping's container policy.
setContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
ADVANCED: Configure the mapping to use a container policy.
setContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
ADVANCED: Configure the mapping to use a container policy.
setContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
ADVANCED: Set the mapping's containerPolicy.
setContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
ADVANCED: Set the mapping's containerPolicy.
setContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
setContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
setContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
setContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
ADVANCED: Set the mapping's containerPolicy.
setContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
setContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.queries.DataReadQuery
PUBLIC: Set the container policy.
setContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Set the container policy.
setContainerSetMethodName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
Deprecated.
Replaced by getInverseReferenceMapping().setSetMethodName()
setContainerSetMethodName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
Deprecated.
Replaced by getInverseReferenceMapping().setSetMethodName()
setContainerUnitOfWork(UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This is only used for EJB entity beans to manage beans accessed in a transaction context.
setContainsIndex(boolean) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setContainterClassName(String) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
Set the container classname for the MW
setContentHandler(ContentHandler) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
setContentHandler(ContentHandler) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
setContentHandler(ContentHandler) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
setContentHandler(ContentHandler) - Method in class org.eclipse.persistence.internal.oxm.record.XMLStreamReaderReader
 
setContentHandler(ContentHandler) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
Set the ContentHandler that the object will be marshalled to.
setContents(Object) - Method in class org.eclipse.persistence.internal.helper.linkedlist.LinkedNode
 
setContext(Context) - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Set the JNDI Context that can supply the named ConnectionFactory.
setContext(Context) - Method in class org.eclipse.persistence.sessions.JNDIConnector
PUBLIC: Set the JNDI Context that can supply the named DataSource.
setContextProperty(String) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
PUBLIC: Set the context property used to define the table per tenant.
setContextProperty(String) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL: The context property that is used to write this mapping must be set.
setContexts(AbstractRecord) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Set the contexts (for LOB)
setContextTenant(String) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL:
setController(RemoteSessionController) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIRemoteSessionControllerDispatcher
Set the controller.
setConversionManager(ConversionManager) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
The platform hold its own instance of conversion manager to allow customization.
setConversionManager(ConversionManager) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
The platform hold its own instance of conversion manager to allow customization.
setConverter(CONVERTER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyCollectionMapping
 
setConverter(CONVERTER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyObjectMapping
 
setConverter(CONVERTER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
Set the converter on the mapping.
setConverter(CONVERTER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
Set the converter on the mapping.
setConverter(CONVERTER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
Set the converter on the mapping.
setConverter(CONVERTER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
 
setConverter(CONVERTER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
Set the converter on the mapping.
setConverter(CONVERTER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.VariableXPathObjectMapping
 
setConverter(CONVERTER) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceFieldToClassAssociation
 
setConverter(Converter) - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
PUBLIC: Set the converter on the mapping.
setConverter(Converter) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
PUBLIC: Set the converter on the mapping.
setConverter(Converter) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
PUBLIC: Set the converter on the mapping.
setConverter(Converter) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
Set the converter on the mapping.
setConverter(Converter) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
Set the converter on the mapping.
setConverter(XMLConverter) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
setConverter(XMLConverter) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
setConverterClassName(String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
PUBLIC: Set the converter class name on the mapping.
setConverterName(String) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Set from JPA processing where we deal with strings only to avoid class loader conflicts.
setCopies(Map) - Method in class org.eclipse.persistence.sessions.CopyGroup
INTERNAL: Set the copies.
setCopyPolicy(CopyPolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the copy policy.
setCopyPolicyClassName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Sets the name of a Class that implements CopyPolicy Will be instantiatied as a copy policy at initialization times using the no-args constructor
setCounterField(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.TableSequenceConfig
 
setCounterField(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.UnaryTableSequenceConfig
 
setCounterFieldName(String) - Method in class org.eclipse.persistence.sequencing.TableSequence
 
setCounterFieldName(String) - Method in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
setCreatable(boolean) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
setCreateDatabaseSchemas(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
INTERNAL: Set to true if database schemas should be built during the DDL generation.
setCreateSQLFiles(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
setCreateSQLFiles(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC:
setCreateVPDCalls(boolean, String) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC:
setCreationPrefix(String) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Set the beginning of the sql create statement - the part before the name.
setCreationSuffix(String) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
setCreationSuffix(String) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Set the end of the sql create statement - the part after the field list.
setCumulativeUOWChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Set the final UnitOfWorkChangeSet for merge into the shared cache.
setCurrentAliasNumber(int) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Sets a unique id that will be used to alias the next table.
setCurrentClass(ClassDefinition) - Method in class org.eclipse.persistence.internal.codegen.CodeGenerator
 
setCurrentDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setCurrentEclipseLinkLogLevel(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Set the EclipseLink log level to be used at runtime.
setCurrentEclipseLinkLogLevel(String) - Method in class org.eclipse.persistence.services.RuntimeServices
PUBLIC: Set the EclipseLink log level to be used at runtime.
setCurrentGroup(AttributeGroup) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setCurrentItem(AttributeItem) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setCurrentMapping(DatabaseMapping) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setCurrentObject(Object) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setCurrentObject(Object) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setCurrentObject(Object) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setCurrentObject(Object) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL:
setCurrentSize(String) - Method in class org.eclipse.persistence.services.ClassSummaryDetailBase
 
setCursorCode(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
ADVANCED: Set the code for preparing cursored output parameters in a stored procedure
setCursorCode(int) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
ADVANCED: Set the code for preparing cursored output parameters in a stored procedure
setCustomAddTargetQuery(DataModifyQuery) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
PUBLIC: The default add target query for mapping can be overridden by specifying the new query.
setCustomDeleteAllQuery(ModifyQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: The default delete all query for mapping can be overridden by specifying the new query.
setCustomDeleteAtIndexQuery(ModifyQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: The default delete by index query for this mapping can be overridden by specifying the new query.
setCustomDeleteQuery(DataModifyQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: The default delete query for mapping can be overridden by specifying the new query.
setCustomDeleteQuery(DataModifyQuery) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: The default delete query for mapping can be overridden by specifying the new query.
setCustomDeleteQuery(ModifyQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: The default delete query for this mapping can be overridden by specifying the new query.
setCustomInsertQuery(DataModifyQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: The default insert query for mapping can be overridden by specifying the new query.
setCustomInsertQuery(DataModifyQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: The default insert query for mapping can be overridden by specifying the new query.
setCustomInsertQuery(DataModifyQuery) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: The default insert query for mapping can be overridden by specifying the new query.
setCustomizer(ConnectionCustomizer) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Set customizer, customize the connection if it's available.
setCustomNamespaceMapper(boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
setCustomNamespaceMapper(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
setCustomNamespaceMapper(boolean) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
setCustomRemoveAllTargetsQuery(DataModifyQuery) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
PUBLIC: The default remove all targets query for mapping can be overridden by specifying the new query.
setCustomRemoveTargetQuery(DataModifyQuery) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
PUBLIC: The default remove target query for mapping can be overridden by specifying the new query.
setCustomSelectionQuery(ReadQuery) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Relationship mappings creates a read query to read reference objects.
setCustomSQLArgumentType(String, int) - Method in class org.eclipse.persistence.queries.SQLCall
PUBLIC: This method should only be used with custom SQL: it sets a type to IN, OUT or INOUT parameter (prefixed with #, ### or #### in custom SQL string).
setCustomSQLArgumentType(String, int, String) - Method in class org.eclipse.persistence.queries.SQLCall
PUBLIC: This method should only be used with custom SQL: it sets a type to IN, OUT or INOUT parameter (prefixed with #, ### or #### in custom SQL string).
setCustomSQLArgumentType(String, int, String, Class<?>) - Method in class org.eclipse.persistence.queries.SQLCall
PUBLIC: This method should only be used with custom SQL: it sets a type to IN, OUT or INOUT parameter (prefixed with #, ### or #### in custom SQL string).
setCustomSQLArgumentType(String, int, String, Class<?>, DatabaseField) - Method in class org.eclipse.persistence.queries.SQLCall
PUBLIC: This method should only be used with custom SQL: it sets a type to IN, OUT or INOUT parameter (prefixed with #, ### or #### in custom SQL string).
setCustomSQLArgumentType(String, int, String, DatabaseField) - Method in class org.eclipse.persistence.queries.SQLCall
PUBLIC: This method should only be used with custom SQL: it sets a type to IN, OUT or INOUT parameter (prefixed with #, ### or #### in custom SQL string).
setCustomSQLArgumentType(String, Class<?>) - Method in class org.eclipse.persistence.queries.SQLCall
PUBLIC: This method should only be used with custom SQL: it sets a type to IN, OUT or INOUT parameter (prefixed with #, ### or #### in custom SQL string).
setCustomUpdateAtIndexQuery(ModifyQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: The default delete by index query for this mapping can be overridden by specifying the new query.
setData(byte[]) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper.EncodedData
 
setData(Object) - Method in class org.eclipse.persistence.queries.ComplexQueryResult
INTERNAL: Set the database rows for the query result.
setDatabaseChangeNotificationType(DatabaseChangeNotificationType) - Method in class org.eclipse.persistence.descriptors.CachePolicy
Configures what type of database change notification an entity/descriptor should use.
setDatabaseEventListener(DatabaseEventListener) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Set the database event listener, this allows database events to invalidate the cache.
setDatabaseEventListener(DatabaseEventListener) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Set the database event listener, this allows database events to invalidate the cache.
setDatabaseField(DatabaseField) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
INTERNAL: Set the DatabaseField that is associated to this FieldDefinition object.
setDatabaseFieldsToTableAliases(HashMap) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
setDatabaseName(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The database name is required when connecting to databases that support multiple databases within a single server instance (e.g.
setDatabaseURL(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The database URL is the JDBC URL for the database server.
setDatabaseURL(String) - Method in class org.eclipse.persistence.sessions.DefaultConnector
PUBLIC: The database URL is the JDBC URL for the database server.
setDataClass(Class<?>) - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
PUBLIC: Set the class type of the data value.
setDataClassName(String) - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
INTERNAL: Set the name of the data type for the MW usage.
setDataFormat(String) - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Configure the data format that the descriptor maps to.
setDataModifications(Map<DatabaseMapping, List<Object[]>>) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Used to store data queries to be performed at the end of the commit.
setDataResults(List<AbstractRecord>) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Set the rows to the set of data results for each mapping.
setDataResults(List, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Set all of the rows fetched by the query, used for 1-m joining.
setDataResults(Map<Object, List<AbstractRecord>>) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Set temporary list of rows from parent batch query per batched mapping.
setDataResults(DatabaseMapping, List<AbstractRecord>) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: Set the remaining data results for the mapping.
setDataResultsByPrimaryKey(Map<Object, List<AbstractRecord>>) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Set all of the rows fetched by the query by cache-key, used for 1-m joining.
setDatasource(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setDataSource(DataSource) - Method in class org.eclipse.persistence.sessions.JNDIConnector
PUBLIC: Set the javax.sql.DataSource.
setDatasourceAndInitialize() - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Issue any pre connect and post connect without an actual connection to the database.
setDatasourceCall(Call) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Used to define a store procedure or SQL query.
setDatasourceConnection(Object) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
If client requires to manually set connection they can use the connection manager.
setDatasourceLogin(Login) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Set the login.
setDatasourceLogin(Login) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Set the login.
setDatasourceLogin(Login) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set the login to be used to connect to the database for this project.
setDatasourceLogin(Login) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Set the login.
setDatasourcePlatform(DatasourcePlatform) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Set the platform.
setDatasourcePlatform(DatasourcePlatform) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Set the platform.
setDatasourcePlatform(Platform) - Method in class org.eclipse.persistence.sequencing.Sequence
 
setDatasourcePlatform(Platform) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Set the database platform specific information.
setDatasourcePlatform(Platform) - Method in interface org.eclipse.persistence.sessions.Login
PUBLIC: Set the database platform specific information.
setDataTypeName(String) - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Specify the data type name for the class of objects the descriptor maps.
setDataTypeName(String) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Set from JPA processing where we deal with strings only to avoid class loader conflicts.
setDate(Date) - Method in class org.eclipse.persistence.logging.SessionLogEntry
Set the date of the log entry.
setDateFormat(DateFormat) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC: Set the date format to be used when printing a log entry date.
setDead() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: set UoW lifecycle state variable to DEATH
setDeadLockPotentiallyCausedByCacheKeyWithCorruptedActiveThread(boolean) - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
setDeadLockPotentiallyCausedByCacheKeyWithCorruptedNumberOfReaders(boolean) - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
setDeclaredType(Class<?>) - Method in class org.eclipse.persistence.internal.oxm.Root
Sets the declared type.
setDefaultAttributeValue(Object) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
PUBLIC: The default value can be used if the database can possibly store additional values then those that have been mapped.
setDefaultAttributeValueString(String) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Set from JPA processing where we deal with strings only to avoid class loader conflicts.
setDefaultCacheIsolation(CacheIsolationType) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set project level default value for class cache isolation.
setDefaultConnectionPolicy(ConnectionPolicy) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: The default connection policy is used by default by the acquireClientConnection() protocol.
setDefaultConnectionPolicy(ConnectionPolicy) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: The default connection policy is used by default by the acquireClientConnection() protocol.
setDefaultConnectionPool() - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Creates and adds "default" connection pool using default parameter values
setDefaultConnectionPool(String) - Method in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
PUBLIC: Set the default connection pool used for any unmapped values.
setDefaultConstructor(Constructor) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
setDefaultContainerClass(Class<? extends Collection>) - Static method in class org.eclipse.persistence.internal.queries.ContainerPolicy
ADVANCED: Allow the default collection class to be set.
setDefaultContainerSize(int) - Static method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
ADVANCED: Set the size to of container to create.
setDefaultDeleteObjectQueryRedirector(QueryRedirector) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default DeleteObjectQuery Redirector will be applied to any executing DeleteObjectQuery or DeleteAllQuery that does not have a redirector set directly on the query.
setDefaultDeleteObjectQueryRedirectorClassName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default DeleteObjectQuery Redirector will be applied to any executing DeleteObjectQuery or DeleteAllQuery that does not have a redirector set directly on the query.
setDefaultEmptyContainer(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.XMLContainerMapping
Indicate whether by default an empty container should be set on the field/property if the collection is not present in the XML document.
setDefaultEmptyContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL Indicate whether by default an empty container should be set on the field/property if the collection is not present in the XML document.
setDefaultEmptyContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
INTERNAL Indicate whether by default an empty container should be set on the field/property if the collection is not present in the XML document.
setDefaultEmptyContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
INTERNAL Indicate whether by default an empty container should be set on the field/property if the collection is not present in the XML document.
setDefaultEmptyContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
INTERNAL Indicate whether by default an empty container should be set on the field/property if the collection is not present in the XML document.
setDefaultEmptyContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
INTERNAL Indicate whether by default an empty container should be set on the field/property if the collection is not present in the XML document.
setDefaultEmptyContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
INTERNAL Indicate whether by default an empty container should be set on the field/property if the collection is not present in the XML document.
setDefaultEmptyContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
INTERNAL Indicate whether by default an empty container should be set on the field/property if the collection is not present in the XML document.
setDefaultEndDatabaseDelimiter(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
setDefaultFetchGroup(FetchGroup) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
Set the descriptor-level default fetch group.
setDefaultIdentityMapClass(Class<? extends IdentityMap>) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set default value for descriptor cache type.
setDefaultIdentityMapSize(int) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set default value descriptor cache size.
setDefaultIdValidation(IdValidation) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set default value for descriptor primary key validation.
setDefaultInsertObjectQueryRedirector(QueryRedirector) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default InsertObjectQuery Redirector will be applied to any executing InsertObjectQuery that does not have a redirector set directly on the query.
setDefaultInsertObjectQueryRedirectorClassName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default InsertObjectQuery Redirector will be applied to any executing InsertObjectQuery that does not have a redirector set directly on the query.
setDefaultLoader(ClassLoader) - Static method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Set the default class loader to use if no instance-level loader is set
setDefaultManager(ConversionManager) - Static method in class org.eclipse.persistence.internal.helper.ConversionManager
A singleton conversion manager is used to handle generic conversions.
setDefaultManager(PopulationManager) - Static method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Set the default instance.
setDefaultNamespace(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setDefaultNamespaceURI(String) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
 
setDefaultNativeSequenceToTable(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Set if the native sequence type is not supported, if table sequencing should be used.
setDefaultNullValue(Class<?>, Object) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Allow for the null values for classes to be defaulted in one place.
setDefaultNullValue(Class<?>, Object) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The default value to substitute for database NULLs can be configured on a per-class basis.
setDefaultNullValue(Class<?>, Object) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: The default value to substitute for database NULLs can be configured on a per-class basis.
setDefaultNullValues(Map<Class<?>, Object>) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL: Allow for the null values for classes to be defaulted in one place.
setDefaultOrAddSequenceString(Sequence, boolean) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
setDefaultQueryRedirector(QueryRedirector) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default Query Redirector will be applied to any executing object query that does not have a more precise default (like the default ReadObjectQuery Redirector) or a redirector set directly on the query.
setDefaultQueryRedirectorClassName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default Query Redirector will be applied to any executing object query that does not have a more precise default (like the default ReadObjectQuery Redirector) or a redirector set directly on the query.
setDefaultQueryResultsCachePolicy(QueryResultsCachePolicy) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set the default values for query caching options for all named queries.
setDefaultReadAllQueryRedirector(QueryRedirector) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default ReadAllQuery Redirector will be applied to any executing ReadAllQuery that does not have a redirector set directly on the query.
setDefaultReadAllQueryRedirectorClassName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default ReadAllQuery Redirector will be applied to any executing ReadAllQuery that does not have a redirector set directly on the query.
setDefaultReadObjectQueryRedirector(QueryRedirector) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default ReadObjectQuery Redirector will be applied to any executing ReadObjectQuery that does not have a redirector set directly on the query.
setDefaultReadObjectQueryRedirectorClassName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default ReadObjectQuery Redirector will be applied to any executing ReadObjectQuery that does not have a redirector set directly on the query.
setDefaultReadOnlyClasses(Collection) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set the read-only classes which apply to each UnitOfWork create by default.
setDefaultReferenceMode(ReferenceMode) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
Stores the default Session wide reference mode that a UnitOfWork will use when referencing managed objects.
setDefaultReferenceMode(ReferenceMode) - Method in interface org.eclipse.persistence.sessions.Session
Stores the default Session wide reference mode that a UnitOfWork will use when referencing managed objects.
setDefaultReportQueryRedirector(QueryRedirector) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default ReportQuery Redirector will be applied to any executing ReportQuery that does not have a redirector set directly on the query.
setDefaultReportQueryRedirectorClassName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default ReportQuery Redirector will be applied to any executing ReportQuery that does not have a redirector set directly on the query.
setDefaultRootElement(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Return the default root element name for the ClassDescriptor This value is stored in place of a table name This value is mandatory for all root objects
setDefaultRootElement(String) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: Return the default root element name for the ClassDescriptor This value is stored in place of a table name This value is mandatory for all root objects
setDefaultRootElementField(XMLField) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
setDefaultRootElementType(QName) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
The default root element type string will be stored until initialization - a QName will be created and stored on the default root element field during initialize.
setDefaultSeqenceAtNextValue(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Set if the sequence generation should start at next value.
setDefaultSequence(Sequence) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Set default sequence.
setDefaultSequence(Sequence) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Set default sequence.
setDefaultSequence(Sequence) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
Set default sequence
setDefaultSequenceConfig(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
setDefaultSequenceConfig(SequenceConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
setDefaultSession(Session) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Set the default session.
setDefaultSize(int) - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Set the default size for this type.
setDefaultSourceTable(DatabaseTable) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Set a default source table to use with the source fields of this mapping.
setDefaultStartDatabaseDelimiter(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
 
setDefaultSubSize(int) - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Set the default sub-size for this type.
setDefaultTable(DatabaseTable) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: The descriptors default table can be configured if the first table is not desired.
setDefaultTableName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: The descriptors default table can be configured if the first table is not desired.
setDefaultTableName(String) - Method in class org.eclipse.persistence.descriptors.RelationalDescriptor
PUBLIC: The descriptors default table can be configured if the first table is not desired.
setDefaultTemporalMutable(boolean) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set the default setting for configuring if dates and calendars are mutable.
setDefaultTransactionManager(TransactionManager) - Static method in class org.eclipse.persistence.transaction.JTATransactionController
PUBLIC: Set the JTA transaction manager to be used.
setDefaultTransactionSynchronizationRegistry(TransactionSynchronizationRegistry) - Static method in class org.eclipse.persistence.transaction.JTA11TransactionController
PUBLIC: Set the default JTA 1.1 synchronization objects registry to be used.
setDefaultUpdateObjectQueryRedirector(QueryRedirector) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default UpdateObjectQuery Redirector will be applied to any executing UpdateObjectQuery or UpdateAllQuery that does not have a redirector set directly on the query.
setDefaultUpdateObjectQueryRedirectorClassName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
A Default UpdateObjectQuery Redirector will be applied to any executing UpdateObjectQuery or UpdateAllQuery that does not have a redirector set directly on the query.
setDefaultUseDoPrivilegedValue(boolean) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
INTERNAL It will be used to set default value of property "eclipselink.security.usedoprivileged" if not passed as system property.
setDefaultValue(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
setDeferModificationsUntilCommit(int) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
ADVANCED: This can be set to control when changes to objects are submitted to the database This is only applicable to TopLink's CMP implementation and not available within the core.
setDeferModificationsUntilCommit(int) - Method in class org.eclipse.persistence.sessions.Project
ADVANCED: This method is a 'helper' method for updating all of the descriptors within this project to have a particular deferral level.
setDeferredLocks(Vector<ConcurrencyManager>) - Method in class org.eclipse.persistence.internal.helper.DeferredLockManager
set a set of the deferred locks to the DLM
setDefinedAsOneToManyMapping(boolean) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Set whether this mapping was originally defined as a OneToMany
setDelayBetweenConnectionAttempts(int) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Stores the number of milliseconds that EclipseLink will wait between attempts to reconnect a DatabaseConnection in the case EclipseLink is attempting to retry a query.
setDelayBetweenConnectionAttempts(Integer) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setDelegateSequence(QuerySequence) - Method in class org.eclipse.persistence.sequencing.NativeSequence
Set the sequence delegate.
setDeleteAllCall(Call) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
PUBLIC: The default delete all call for this mapping can be overridden by specifying the new call.
setDeleteAllCall(Call) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Set the receiver's delete all call.
setDeleteAllQuery(ModifyQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
 
setDeleteAllSQLString(String) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: This method is not supported in an EIS environment.
setDeleteAllSQLString(String) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Set the receiver's delete all SQL string.
setDeleteAllSQLString(String) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
PUBLIC: Set the SQL string used by the mapping to delete the target objects.
setDeleteCall(Call) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's delete call.
setDeleteCall(Call) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Set the receiver's delete Call.
setDeleteCall(Call) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Set the receiver's delete Call.
setDeletedObjects(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Sets the collection of deleted objects.
setDeletedObjects(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The deleted objects stores any objects removed during the unit of work.
setDeleteQuery(DataModifyQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
 
setDeleteQuery(DataModifyQuery) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
 
setDeleteQuery(DeleteObjectQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's delete query.
setDeleteQuery(ModifyQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
setDeleteSQLString(String) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's delete SQL string.
setDeleteSQLString(String) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Set the receiver's delete SQL string.
setDeleteSQLString(String) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Set the receiver's delete SQL string.
setDeleteSQLString(String) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Set the receiver's delete SQL string.
setDepth(int) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Set the current depth of the active thread.
setDepth(int) - Method in class org.eclipse.persistence.sessions.CopyGroup
INTERNAL: Set the cascade depth.
setDerivedIdMapping(DatabaseMapping) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: Used to indicate the mapping references a JPA ID or MapsId attribute for the CMP3Policy and JPA Id classes (as well as Embeddable Id classes).
setDerivesId(boolean) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: Used to indicate the mapping references a JPA ID or MapsId attribute for the CMP3Policy and JPA Id classes (as well as Embeddable Id classes).
setDescribesNonPersistentSubclasses(boolean) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: Determines whether the descriptors using this inheritance policy should be used as descriptors for subclasses of the classes they describe if those subclasses do not have their own descriptor e.g.
setDescriptor(DESCRIPTOR) - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL: Set the descriptor.
setDescriptor(DESCRIPTOR) - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Set the descriptor to which this mapping belongs
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL:
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.copying.AbstractCopyPolicy
Set the descriptor.
setDescriptor(ClassDescriptor) - Method in interface org.eclipse.persistence.descriptors.copying.CopyPolicy
Set the descriptor.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
INTERNAL: The source descriptor of the event.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: Set the descriptor.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Set the descriptor.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
Set the referenced descriptor.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Set method for the descriptor
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Set the descriptor.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Set the descriptor.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.MethodClassExtractor
INTERNAL: Set the descriptor.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
setDescriptor(ClassDescriptor) - Method in interface org.eclipse.persistence.descriptors.SerializedObjectPolicy
set owning descriptor
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL:
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL:
setDescriptor(ClassDescriptor) - Method in interface org.eclipse.persistence.descriptors.WrapperPolicy
PUBLIC: Required: Set the descriptor.
setDescriptor(ClassDescriptor) - Method in exception org.eclipse.persistence.exceptions.DescriptorException
INTERNAL: Set the mapping.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.history.HistoryPolicy
PUBLIC:
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.descriptors.AbstractSerializedObjectPolicy
 
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
INTERNAL: Set the descriptor associated with this listener
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Set the descriptor.
setDescriptor(ClassDescriptor) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: provide a way to set the descriptor for this policy
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Set the descriptor that this is the map for.
setDescriptor(ClassDescriptor) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Set the descriptor that this is the map for.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
Set the descriptor.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Called to set the descriptor on a Join Managerwith in a ReportItem, durring initialization, and durring DatabaseQuery.checkDescriptor.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Set the descriptor to which this mapping belongs
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
INTERNAL: Set the descriptor.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the descriptor for the query.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Set the descriptor for the query.
setDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Set the descriptor that this is the map for.
setDescriptorCustomizerClassName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Sets the JPA DescriptorCustomizer class name.
setDescriptorEventHolders(List<SerializableDescriptorEventHolder>) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: used by JPA project caching to store DescriptorEventListener representations that can build the underlying DescriptorEventListener and add it to the EventManager.
setDescriptorForKeyMapping(ClassDescriptor) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Used during initialization of DirectMapMapping.
setDescriptorMethodNames(Hashtable<ClassDescriptor, String>) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
 
setDescriptors(Map) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set the descriptors registered with this session.
setDescriptorType(int) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: set the descriptor type (NORMAL by default, others include INTERFACE, AGGREGATE, AGGREGATE COLLECTION)
setDescriptorTypeValue(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: This method is explicitly used by the XML reader.
setDirectField(DatabaseField) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Set the direct field in the reference table.
setDirectFieldClassification(Class<?>) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
ADVANCED: Set the class type of the field value.
setDirectFieldClassificationName(String) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
ADVANCED: Set the class type of the field value.
setDirectFieldName(String) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Set the direct field name in the reference table.
setDirectKeyField(DatabaseField) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL:
setDirectKeyFieldClassification(Class<?>) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
ADVANCED: Set the class type of the field value.
setDirectKeyFieldClassificationName(String) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
ADVANCED: Set the class type name of the field value.
setDirectKeyFieldName(String) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
PUBLIC: Set the direct key field name in the reference table.
setDisableForeignKey(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
setDisableSecureProcessing(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
setDisableSecureProcessing(boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
setDisableSecureProcessing(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
setDisableSecureProcessing(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
setDisableSecureProcessing(boolean) - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
 
setDiscoverUnregisteredNewObjectsWithoutPersist(boolean) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
 
setDiscoveryConfig(DiscoveryConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.RMITransportManagerConfig
 
setDiscoveryTime(int) - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
setDiscriminatorColumn(String) - Method in class org.eclipse.persistence.queries.EntityResult
Sets the column name for the column that will store the value used to determine the subclass type if applicable.
setDiscriminatorColumn(DatabaseField) - Method in class org.eclipse.persistence.queries.EntityResult
 
setDistinctState(short) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
ADVANCED: If a distinct has been set the DISTINCT clause will be printed.
setDistinctState(short) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
ADVANCED: If a distinct has been set the DISTINCT clause will be printed.
setDocPresPolicy(DocumentPreservationPolicy) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
setDocPresPolicy(DocumentPreservationPolicy) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
setDocumentation(List<String>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Annotation
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.internal.oxm.record.UnmappedContentHandlerWrapper
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.internal.oxm.unmapped.DefaultUnmappedContentHandler
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
setDocumentLocator(Locator) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
setDocumentPreservationPolicy(DocumentPreservationPolicyConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.XMLLoginConfig
 
setDocumentPreservationPolicy(DocumentPreservationPolicy) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Login
 
setDocumentPreservationPolicy(DocumentPreservationPolicy) - Method in class org.eclipse.persistence.oxm.XMLLogin
 
setDoesExistCall(Call) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's does exist call.
setDoesExistQuery(DoesExistQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's does exist query.
setDoesExistSQLString(String) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's does exist SQL string.
setDOM(Element) - Method in interface org.eclipse.persistence.eis.DOMRecord
 
setDOM(Element) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
setDOM(Node) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
 
setDOM(Node) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Sets the dom and updated document to be the owner document of the given element
setDOM(Node) - Method in class org.eclipse.persistence.oxm.record.NodeRecord
Set the Node that the object will be marshalled to.
setDomainClass(Class<?>) - Method in class org.eclipse.persistence.tools.profiler.Profile
 
setDomainObject(Object) - Method in class org.eclipse.persistence.internal.oxm.WeakObjectWrapper
 
setDOMInRecord(Element, Record, EISInteraction, EISAccessor) - Method in class org.eclipse.persistence.eis.EISPlatform
Stores the XML DOM value into the record.
setDoNotRedirect(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
This method is used in combination with redirected queries.
setDriverClass(Class<?>) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The driver class is the Java class for the JDBC driver to be used (e.g.
setDriverClass(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setDriverClassName(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The name of the JDBC driver class to be used (e.g.
setDriverClassName(String) - Method in class org.eclipse.persistence.sessions.DefaultConnector
PUBLIC: The driver class is the name of the Java class for the JDBC driver being used (e.g.
setDriverName(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
During auto-detect, the driver name is set on the platform.
setDriverSupportsNVarChar(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setDriverSupportsOffsetDateTime(boolean) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Allow user to turn off ODT support, in case they rely on the old behavior.
setDriverURLHeader(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The driver URL header is the string predetermined by the JDBC driver to be part of the URL connection string, (e.g.
setDriverURLHeader(String) - Method in class org.eclipse.persistence.sessions.DefaultConnector
PUBLIC: The driver URL header is the string predetermined by the JDBC driver to be part of the URL connection string, (e.g.
setDTDHandler(DTDHandler) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
setDTDHandler(DTDHandler) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
setDumpTime(long) - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
Set the number of milliseconds after which the monitor results should be logged.
setDynamicPropertiesManager(DynamicPropertiesManager) - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
setEjbqlString(String) - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: Set the EJBQL string for this call
setEJBQLString(String) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Set the EJBQL string of the query.
setEJBQLString(String) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
setElementAt(E, int) - Method in class org.eclipse.persistence.indirection.IndirectList
 
setElementAt(E, int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
setElementAt(E, int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
setElementAt(E, int) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
If index is missing wait until reached or complete.
setElementClass(Class<?>) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Sets the element class which defines the method.
setElementDataTypeName(String) - Method in class org.eclipse.persistence.mappings.structures.ArrayMapping
PUBLIC: Set the "data type" associated with each element in the nested collection.
setElementDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Used for wrapping and unwrapping with the wrapper policy.
setElementFormDefault(boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setElements(List<Element>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
setElements(List<Element>) - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
setElements(List<Element>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
setElements(List<Element>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.TypeDefParticle
 
setEmptyCollection(boolean) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
setEmptyCollection(boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
setEmptyCollectionGenerated(boolean) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
setEnableJTA(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.platform.ServerPlatformConfig
 
setEnableRuntimeServices(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.platform.ServerPlatformConfig
 
setEncoding(String) - Method in class org.eclipse.persistence.internal.oxm.Marshaller
Set the encoding on this Marshaller.
setEncoding(String) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.LocatorImpl
 
setEncoding(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
INTERNAL:
setEncoding(String) - Method in class org.eclipse.persistence.internal.oxm.Root
Sets the encoding.
setEncoding(String) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Set the encoding on this XMLMarshaller If the encoding is not set the default UTF-8 will be used
setEncoding(String) - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
setEncryptedPassword(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
This method should never be called from the Mapping Workbench.
setEncryptedPassword(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
This method should never be called from the Mapping Workbench.
setEncryptedPassword(String) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
ADVANCED: Set the encrypted password used as the value to the SECURITY_CREDENTIALS key in the cached context properties.
setEncryptedPassword(String) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
Set the encrypted password.
setEncryptionClass(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
setEncryptionClass(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
 
setEncryptionClassName(String) - Method in class org.eclipse.persistence.internal.security.SecurableObjectHolder
 
setEncryptionClassName(String) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL SECURITY: Set encryption class that will be loaded by the SecurableObjectHolder
setEncryptionClassName(String) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
Sets the encryption class name
setEndDelimiter(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Delimiter to use for fields and tables using spaces or other special values.
setEndFields(List<DatabaseField>) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
setEndFieldType(String, Class<?>) - Method in class org.eclipse.persistence.history.HistoryPolicy
ADVANCED:
setEndValue(Comparable) - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartition
PUBLIC: Set the range end value.
setEntityEventListener(DescriptorEventListener) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: EJB 3.0 support for lifecycle callback events defined on an entity class.
setEntityResolver(EntityResolver) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
setEntityResolver(EntityResolver) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
setEntityResolver(EntityResolver) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
setEntityResolver(EntityResolver) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
setEntityResolver(EntityResolver) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
setEntityResolver(EntityResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Set the EntityResolver on this XMLUnmarshaller
setEntityResolver(EntityResolver) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
setEnumerationFacets(List) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setEqualNamespaceResolvers(boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
setEqualNamespaceResolvers(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
setEqualNamespaceResolvers(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.XMLLoginConfig
 
setEqualNamespaceResolvers(boolean) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
setEqualNamespaceResolvers(boolean) - Method in class org.eclipse.persistence.oxm.XMLLogin
 
setEqualUsingIdenity(boolean) - Method in class org.eclipse.persistence.internal.oxm.Marshaller
INTERNAL
setErrorCode(int) - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL:
setErrorHandler(ErrorHandler) - Method in class org.eclipse.persistence.internal.oxm.Marshaller
 
setErrorHandler(ErrorHandler) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
setErrorHandler(ErrorHandler) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
setErrorHandler(ErrorHandler) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
setErrorHandler(ErrorHandler) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
setErrorHandler(ErrorHandler) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
setErrorHandler(ErrorHandler) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
setErrorHandler(ErrorHandler) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Set the ErrorHandler on this XMLUnmarshaller
setErrorHandler(ErrorHandler) - Method in class org.eclipse.persistence.oxm.XMLBinder
 
setErrorHandler(ErrorHandler) - Method in class org.eclipse.persistence.oxm.XMLValidator
Set the error handler to be used during validation
setErrorHandler(ErrorHandler) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
setEventCode(int) - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
INTERNAL: The code of the descriptor event being raised.
setEventCode(int) - Method in class org.eclipse.persistence.sessions.SessionEvent
INTERNAL: The code of the session event being raised.
setEventListeners(List<DescriptorEventListener>) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
setEventManager(DESCRIPTOR_EVENT_MANAGER) - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
INTERNAL: Set the event manager for the descriptor.
setEventManager(DescriptorEventManager) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the event manager for the descriptor.
setEventManager(SessionEventManager) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Set the event manager.
setEventMethods(AtomicReferenceArray<Method>) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
setEventSelectors(AtomicReferenceArray<String>) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
 
setExampleObject(Object) - Method in class org.eclipse.persistence.internal.queries.QueryByExampleMechanism
PUBLIC: Set the example object of the query to be the newExampleObject.
setExampleObject(Object) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Set the example object of the query to be the newExampleObject.
setException(RuntimeException) - Method in class org.eclipse.persistence.internal.sessions.remote.Transporter
Set the exception associated with this Transporter
setException(Throwable) - Method in class org.eclipse.persistence.logging.SessionLogEntry
Set the exception that caused the log entry.
setExceptionHandler(ExceptionHandler) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Set the exceptionHandler.
setExceptionHandler(ExceptionHandler) - Method in interface org.eclipse.persistence.sessions.ExternalTransactionController
Set an exception handler to handle or wrap exceptions thrown in before/after completion.
setExceptionHandler(ExceptionHandler) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Set the exceptionHandler.
setExceptionHandler(ExceptionHandler) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
Set an exception handler to handle or wrap exceptions thrown in before/after completion.
setExceptionHandlerClass(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
setExceptionList(Vector<Throwable>) - Method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
setExcludeDefaultListeners(boolean) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: EJB 3.0 support.
setExcludeSuperclassListeners(boolean) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: EJB 3.0 support.
setExclusive(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ReadConnectionPoolConfig
 
setExclusiveMode(ConnectionPolicy.ExclusiveMode) - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Sets exclusive mode, if null is passed sets the default value.
setExecuteReturnValue(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
An execute return value will be set here after the call.
setExecuteUpdate() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Indicates that this call will return a boolean value from an execute() call.
setExecutionSession(AbstractSession) - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Sets the session the underlying call was executed on.
setExecutionSession(AbstractSession) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the execution session.
setExecutionTime(long) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Set the the time this query went to the database.
setExistenceCheck(String) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: This method is explicitly used by the Builder only.
setExistenceChecking(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: OBSOLETE - old reader.
setExistenceCheckingNotUnderstood(String, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
setExistencePolicy(int) - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Set if the existence policy, this must be set to one of the constants.
setExpiryTime(int, int, int, int) - Method in class org.eclipse.persistence.descriptors.invalidation.DailyCacheInvalidationPolicy
PUBLIC: Set a new expiry time for this object Provide the hour, minute, second and millisecond.
setExpiryTime(Calendar) - Method in class org.eclipse.persistence.descriptors.invalidation.DailyCacheInvalidationPolicy
INTERNAL: Set the expiry time based on a Calendar.
setExpression(Expression) - Method in class org.eclipse.persistence.internal.helper.FunctionField
 
setExpressionBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.queries.ModifyAllQuery
INTERNAL Sets the default expression builder for this query.
setExpressionBuilder(ExpressionBuilder) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL Sets the default expression builder for this query.
setExpressionQueryCacheMaxSize(int) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the max size of the expression query cache for avoiding regenerated dynamic query SQL.
setExtension(Extension) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Content
 
setExternalConnectionPooling(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
setExternalTransactionController(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
setExternalTransactionController(ExternalTransactionController) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
Used for JTS integration internally by ServerPlatform.
setExternalTransactionController(ExternalTransactionController) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Used for JTS integration internally by ServerPlatform.
setExternalTransactionController(ExternalTransactionController) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Used for JTS integration.
setExternalTransactionController(ExternalTransactionController) - Method in interface org.eclipse.persistence.sessions.Session
OBSOLETE: Previously used for JTS integration.
setExternalTransactionControllerClass(Class<? extends ExternalTransactionController>) - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: setExternalTransactionControllerClass(Class newClass): Set the class of external transaction controller to use in the DatabaseSession.
setExternalTransactionControllerClass(Class<? extends ExternalTransactionController>) - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: setExternalTransactionControllerClass(Class newClass): Set the class of external transaction controller to use in the DatabaseSession.
setExternalTransactionControllerClass(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.platform.CustomServerPlatformConfig
 
setFactory(Object) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
setFactoryClass(Class<?>) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
setFactoryClassName(String) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
setFactoryMethodName(String) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
setFailoverConnectionPools(List<String>) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Set the list of connection pools to used if this pool database goes down.
setFeature(String, boolean) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
setFeature(String, boolean) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
setFetchGroup(FetchGroup) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Set a dynamic (use case) fetch group to the query.
setFetchGroupManager(FetchGroupManager) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the fetch group manager for the descriptor.
setFetchGroupName(String) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Set a descriptor-level pre-defined named fetch group to the query.
setFetchSize(int) - Method in class org.eclipse.persistence.queries.ReadQuery
PUBLIC: Set the fetchSize setting that this query will set on the JDBC Statement NB - a value of zero means that no call to statement.setFetchSize() will be made.
setField(FIELD) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyAttributeMapping
 
setField(FIELD) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyCollectionMapping
 
setField(FIELD) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyObjectMapping
 
setField(FIELD) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
ADVANCED: Set the field in the mapping.
setField(FIELD) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
ADVANCED: Set the field in the mapping.
setField(FIELD) - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
ADVANCED: Set the field in the mapping.
setField(FIELD) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
Set the field that holds the nested collection.
setField(FIELD) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
ADVANCED: Set the field in the mapping.
setField(DatabaseField) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
setField(DatabaseField) - Method in interface org.eclipse.persistence.descriptors.SerializedObjectPolicy
set the field that stores sopObject in the database (sopField)
setField(DatabaseField) - Method in class org.eclipse.persistence.internal.descriptors.AbstractSerializedObjectPolicy
 
setField(DatabaseField) - Method in class org.eclipse.persistence.internal.descriptors.FieldTransformation
 
setField(DatabaseField) - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: Set the field in the mapping.
setField(DatabaseField) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Used to set the internal field value.
setField(DatabaseField) - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
ADVANCED: Set the field in the mapping.
setField(DatabaseField) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
Set the field in the mapping.
setField(DatabaseField) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
Set the field that holds the nested collection.
setField(DatabaseField) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
The aggregate object is held in a single field.
setField(DatabaseField) - Method in class org.eclipse.persistence.mappings.querykeys.DirectQueryKey
INTERNAL: Set the field for the query key.
setField(DatabaseField) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
Set the field in the mapping.
setField(DatabaseField) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
Set the field in the mapping.
setField(DatabaseField) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
setField(DatabaseField) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
setField(DatabaseField) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
setField(DatabaseField) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
 
setField(DatabaseField) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
 
setFieldClassification(Class<?>) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Set the type of the field value to allow conversion from the database.
setFieldClassification(Class<?>) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
ADVANCED: Set the class type of the field value.
setFieldClassificationClassName(String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Set the name of the class that will be used for setFieldClassification and deploy time Used internally by JPA deployment.
setFieldClassificationName(String) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
 
setFieldElementClass(Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
PUBLIC: Set the class each element in the database row's collection should be converted to, before the collection is inserted into the database.
setFieldElementClass(Class<?>) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
PUBLIC: Set the class each element in the database row's collection should be converted to, before the collection is inserted into the database.
setFieldInfos(List<ReturningPolicy.Info>) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
setFieldName(String) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeCollectionMapping
PUBLIC: Set the name of the field mapped by the mapping.
setFieldName(String) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeDirectCollectionMapping
PUBLIC: Set the name of the field that holds the nested collection.
setFieldName(String) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeObjectMapping
PUBLIC: Set the name of the field mapped by the mapping.
setFieldName(String) - Method in class org.eclipse.persistence.eis.mappings.EISDirectMapping
PUBLIC: Set the field name in the mapping.
setFieldName(String) - Method in class org.eclipse.persistence.internal.descriptors.FieldTransformation
 
setFieldName(String) - Method in class org.eclipse.persistence.mappings.DirectToFieldMapping
PUBLIC: Set the field name in the mapping.
setFieldName(String) - Method in class org.eclipse.persistence.mappings.querykeys.DirectQueryKey
PUBLIC: Set the field name for the query key.
setFieldName(String) - Method in class org.eclipse.persistence.mappings.structures.ArrayMapping
PUBLIC: Set the name of the field that holds the nested collection.
setFieldName(String) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
PUBLIC: Set the field name in the mapping.
setFieldName(String) - Method in class org.eclipse.persistence.mappings.structures.ObjectArrayMapping
 
setFieldName(String) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
PUBLIC: Set the field name in the mapping.
setFieldName(String) - Method in class org.eclipse.persistence.mappings.structures.StructureMapping
 
setFieldNameToMethodNameAssociations(Vector) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: needed for backwards compatibility
setFields(List<String>) - Method in class org.eclipse.persistence.tools.schemaframework.IndexDefinition
 
setFields(List<DatabaseField>) - Method in class org.eclipse.persistence.descriptors.CacheIndex
 
setFields(List<FieldDefinition>) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC:
setFields(List<FieldDefinition>) - Method in class org.eclipse.persistence.tools.schemaframework.TypeDefinition
 
setFields(Map<String, DatabaseType>) - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
setFields(Vector) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: Set the fields, if any are aggregate selects then record this so that the distinct is not printed through anyOfs.
setFields(Vector) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
 
setFields(Vector) - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
 
setFields(Vector) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Setting fields vector will not update the document so this is not supported
setFields(Vector<FIELD>) - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: Set the mapping's field collection.
setFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the fields used by this descriptor.
setFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
The fields expected by the calls result set.
setFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Set the mapping's field collection.
setFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Set the fields for the stream.
setFieldsMap(Map) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Return the fields map.
setFieldToAttributeValueAssociations(Vector) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Set a collection of the field to attribute value associations.
setFieldToAttributeValues(Map) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Set the field to attribute mapping.
setFieldToNodeValues(Map<Field, NodeValue>) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
setFieldToNodeValues(Map<Field, NodeValue>) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
setFieldToRelationTable(DatabaseField, TableDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Build and add a field definition object to relation table
setFieldToTransformers(List<Object[]>) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
 
setFieldTransformations(List<FieldTransformation>) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Set the field to method name associations.
setFieldTransformer(CoreFieldTransformer) - Method in class org.eclipse.persistence.internal.oxm.FieldTransformerNodeValue
 
setFieldType(int) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
ADVANCED: Set the JDBC type of the field value.
setFieldTypes(Map<Class<?>, FieldTypeDefinition>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setFieldValue(CMPPolicy.KeyElementAccessor, Object, DatabaseMapping, AbstractSession, int[], Object...) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
INTERNAL: Recursive method to set a field value in the given key instance.
setFile(File) - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaFileReference
 
setFilename(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.DefaultSessionLogConfig
 
setFileName(String) - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaFileReference
 
setFinishingTime(int) - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
setFirst(boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
setFirstChild(Expression) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
setFirstRepeatingThreadThatExplainsDeadLock(boolean) - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
setFirstResult(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
The firstResult set on the result set
setFirstResult(int) - Method in class org.eclipse.persistence.queries.ReadQuery
PUBLIC: Used to set the first result in any result set that is returned for this query.
setFirstToAddAlreadyInCollection(boolean) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
setFirstToRemoveAlreadyOutCollection(boolean) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
setFixed(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
setFlushClearCache(String) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
Set the FlashClearCache mode to be used.
setFlushOnExecute(Boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: If executed against a RepeatableWriteUnitOfWork if this attribute is true EclipseLink will write changes to the database before executing the query.
setForceBatchStatementExecution(boolean) - Method in class org.eclipse.persistence.queries.ModifyQuery
PUBLIC: Allow setting this query to be the last statement added to a batch statement and ensure it is flushed on execution.
setForceCascade(boolean) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
setForceFieldNamesToUppercase(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setForceInitializationOfSelectionCriteria(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: A way of forcing the selection criteria to be rebuilt.
setForceUpdate(boolean) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
ADVANCED: Configure whether TopLink should always update all registered objects of this type.
setForDetach(boolean) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setForeignKeyDefinition(String) - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
setForeignKeyFieldName(String) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Define the foreign key relationship in the 1-1 mapping.
setForeignKeyFieldName(String) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
setForeignKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Return the foreign key field names associated with the mapping.
setForeignKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
PUBLIC: Return the foreign key field names associated with the mapping.
setForeignKeyFieldNamesForMultipleTable(List<Association>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: This method is used by the XML Deployment ClassDescriptor to read and write these mappings
setForeignKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Set the foreign key fields associated with the mapping.
setForeignKeyGroupingElement(String) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
Set the grouping element field on the mapping.
setForeignKeyGroupingElement(DatabaseField) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
Set if the grouping element field on the mapping.
setForeignKeyMap(Map<String, ForeignKeyConstraint>) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL:
setForeignKeys(List<ForeignKeyConstraint>) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Set the ForeignKeyConstraint list.
setForeignQueryKeyName(String, String) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
PUBLIC: A foreign key from the source table and abstract query key from the interface descriptor are added to the mapping.
setForm(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
setFormattedOutput(boolean) - Method in class org.eclipse.persistence.internal.oxm.Marshaller
Set if this XMLMarshaller should format the XML By default this is set to true and the XML marshalled will be formatted.
setFormattedOutput(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Set if this XMLMarshaller should format the XML By default this is set to true and the XML marshalled will be formatted.
setFormattedOutput(boolean) - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
setForRefresh(boolean) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
setForUpdateClause(ForUpdateClause) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
setFractionDigits(int) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setFractionDigits(int) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setFractionDigits(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setFragment(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
PUBLIC: Set if this should marshal to a fragment.
setFragment(boolean) - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
setFragmentBuilder(SAXFragmentBuilder) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setFragmentBuilder(SAXFragmentBuilder) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setFragmentBuilder(SAXFragmentBuilder) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setFullyMergeEntity(boolean) - Method in class org.eclipse.persistence.descriptors.CachePolicy
 
setFullyMergeEntity(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
 
setFunctionName(String) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: Set the function name of the interaction.
setGeneratedKeys(ResultSet) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
The result set that stores the generated keys from the Statement
setGeneratedPrefix(boolean) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setGetMethod(Method) - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Set the accessor method for the attribute accessor.
setGetMethodName(String) - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Set the name of the accessor method for the attribute accessor.
setGetMethodName(String) - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeMethodInfo
 
setGetMethodName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
This method is invoked reflectively on the reference object to return the value of the attribute in the object.
setGetMethodName(String) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: This method is invoked reflectively on the reference object to return the value of the attribute in the object.
setGetSettingsMethodName(String) - Method in class org.eclipse.persistence.internal.oxm.XMLSequencedDescriptor
INTERNAL: Set the name of the method to be invoked to obtain an ordered list of TopLinkSetting objects at runtime.
setGroup(AttributeGroup) - Method in class org.eclipse.persistence.internal.queries.AttributeItem
 
setGroupByExpressions(List<Expression>) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
setGroupByExpressions(List<Expression>) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Set the group bys.
setGroupingElement(ArrayList<XPathNode>) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
setGroupingElement(ArrayList<XPathNode>) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
INTERNAL: Sets the list of grouping elements to be marshalled on this record.
setGroups(Map<String, Group>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setHasAllocatedConnection(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL:
setHasAnyEventListeners(boolean) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
INTERNAL: Set if the event manager has any event listeners, or event methods.
setHasBeenLogged(boolean) - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL: Set this flag to avoid logging an exception more than once.
setHasBeenNormalized(boolean) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
setHasChanges(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Set whether the Unit Of Work change Set has changes
setHasCmpPolicyForcedUpdate(boolean) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL:
setHasCustomDeleteAllQuery(boolean) - Method in class org.eclipse.persistence.mappings.CollectionMapping
 
setHasCustomDeleteQuery(boolean) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
setHasCustomDeleteQuery(boolean) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
 
setHasCustomInsertQuery(boolean) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
setHasCustomInsertQuery(boolean) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
 
setHasCustomMultipleTableJoinExpression(boolean) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTENAL: Set if a custom join expression is used.
setHasCustomSelectionQuery(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
 
setHasCustomSQLArguments(boolean) - Method in class org.eclipse.persistence.queries.SQLCall
INTERNAL: Used to avoid misinterpreting the # in custom SQL.
setHasForcedChangesFromCascadeLocking(boolean) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Used by calculateChanges to mark this ObjectChangeSet as having to be flushed to the db stemming from a cascade optimistic locking policy.
setHasGenericHistorySupport(boolean) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set to true during descriptor initialize if any descriptor has history.
setHasInBatchFetchedAttribute(boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Set if any mappings are always batch fetched using IN.
setHasIsolatedClasses(boolean) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set to true during descriptor initialize if any descriptor is isolated.
setHasMappingsPostCalculateChangesOnDeleted(boolean) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Indicates whether there is at least one descriptor that has at least on mapping that require a call on deleted objects to update change sets.
setHasModifyRow(boolean) - Method in class org.eclipse.persistence.queries.DataModifyQuery
Set if a modify row has been set.
setHasMultipleResultSets(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Set if the call returns multiple result sets.
setHasMultipleResultSets(boolean) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Set if the call returns multiple result sets.
setHasMultipleTableConstraintDependecy(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Set if any mapping reference a field in a secondary table.
setHasNonIsolatedUOWClasses(boolean) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set if any descriptors are not isolated to the unit of work.
setHasOptimisticLock(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
This check is needed only when doing batch writing and we hit on optimistic locking.
setHasProxyIndirection(boolean) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set to true during descriptor initialize if any descriptor uses ProxyIndirection Determines if ProxyIndirectionPolicy.getValueFromProxy should be called.
setHasRelationships(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: set whether this descriptor has any relationships through its mappings, through inheritance, or through aggregates
setHasSimplePrimaryKey(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: PERF: Set if the primary key is simple (direct-mapped) to allow fast extraction.
setHasText(boolean) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setHasVersionChange(boolean) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
setHasWrapperPolicy(boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Set if the descriptor has a wrapper policy.
setHaveBeenAddedToStatement(boolean) - Method in class org.eclipse.persistence.internal.expressions.TableAliasLookup
INTERNAL: Called when aliases are added to a statement.
setHavingExpression(Expression) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
setHavingExpression(Expression) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Add the expression to the query to be used in the HAVING clause.
setHierarchicalQueryClause(Expression, Expression, List<Expression>) - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Set the Hierarchical Query Clause for the query
setHierarchicalQueryClause(Expression, Expression, List<Expression>, ReadAllQuery.Direction) - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Set the Hierarchical Query Clause for the query, specifying the hierarchy traversal direction
setHierarchicalQueryExpressions(Expression, Expression, List<Expression>) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: takes the hierarchical query expression which have been set on the query and sets them here used to generate the Hierarchical Query Clause in the SQL
setHierarchicalQueryExpressions(Expression, Expression, List<Expression>, ReadAllQuery.Direction) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: takes the hierarchical query expression which have been set on the query and sets them here used to generate the Hierarchical Query Clause in the SQL
setHintString(String) - Method in class org.eclipse.persistence.internal.expressions.SQLStatement
INTERNAL: Set the Hint String for the statement
setHintString(String) - Method in class org.eclipse.persistence.queries.DatabaseQuery
Used to set a database hint string on the query.
setHistoricalTables(List<DatabaseTable>) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
setHistoryPolicy(HistoryPolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the HistoryPolicy for this descriptor.
setHistoryPolicy(HistoryPolicy) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Support history on the reference table.
setHistoryPolicy(HistoryPolicy) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Enable history tracking on the m-m join table.
setId(Object) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Set the id of the object for this change set.
setId(Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult
INTERNAL: Set the Id for the result row's object.
setId(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Include
 
setId(String) - Method in class org.eclipse.persistence.sessions.coordination.ServiceId
INTERNAL: Set the unique identifier for the service
setID(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Set the unique id.
setIdentityMapClass(Class<? extends IdentityMap>) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Set the class of identity map to be used by this descriptor.
setIdentityMapClass(Class<? extends IdentityMap>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be used by this descriptor.
setIdentityMapForClass(String, String, int) - Method in class org.eclipse.persistence.services.DevelopmentServices
This method will be used to set a new type of identity map for a particular class type.
setIdentityMapForClass(String, String, int) - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method will be used to set a new type of identity map for a particular class type.
setIdentityMapManager(IdentityMapManager) - Method in class org.eclipse.persistence.internal.sessions.ClientSessionIdentityMapAccessor
INTERNAL: The identity map manager cannot be set on a client session since it looks at it's parent session's identity map manager.
setIdentityMapManager(IdentityMapManager) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Set the IdentityMapManager for this IdentityMapAccessor
setIdentityMapManager(IdentityMapManager) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Set the IdentityMapManager for this IdentityMapAccessor
setIdentityMaps(ConcurrentMap) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
 
setIdentityMapSize(int) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Set the size of the identity map to be used by this descriptor.
setIdentityMapSize(int) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the size of the identity map to be used by this descriptor.
setIDResolver(ID_RESOLVER) - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
 
setIDResolver(ID_RESOLVER) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Set this Unmarshaller's custom IDResolver.
setIDResolver(IDResolver) - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
Set this Unmarshaller's custom IDResolver.
setIdValidation(IdValidation) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Set what types are allowed as a primary key (id).
setIgnoreAttributesForNil(boolean) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
 
setIgnoreDatabaseException(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Set flag whether DatabaseException should be ignored.
setIgnoreFirstRowSetting(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Sets the ignoreFirstRowSetting flag.
setIgnoreMaxResultsSetting(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Sets the ignoreMaxResultsSetting flag.
setIgnoreOrder(boolean) - Method in class org.eclipse.persistence.platform.xml.XMLComparer
 
setImplementorDescriptor(Class<?>) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Sets the implementor descriptor class.
setImplementorDescriptorClassName(String) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Sets the implementor descriptor class name.
setImports(List<Import>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setIncludeRoot(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Determine if the @XMLRootElement should be marshalled when present.
setIncludeRoot(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Determine if the @XMLRootElement should be marshalled when present.
setIncludes(List<Include>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setIncludeTenantCriteria(boolean) - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
ADVANCED: Boolean used to indicate if the database requires the tenant criteria to be added to the SELECT, UPDATE, and DELETE queries.
setIndentationString(String) - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL: Used to print things nicely in the testing tool.
setIndentString(String) - Method in class org.eclipse.persistence.internal.oxm.Marshaller
Set the String that will be used to perform indenting in marshalled documents.
setIndex(int) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Set the expected index that this field will occur in the result set row.
setIndex(int) - Method in interface org.eclipse.persistence.internal.oxm.ContainerValue
INTERNAL: Set to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord Set during TreeObjectBuilder initialization
setIndex(int) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
INTERNAL: Used to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord
setIndex(int) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
INTERNAL: Used to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord
setIndex(int) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
INTERNAL: Used to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord
setIndex(int) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
INTERNAL: Used to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord
setIndex(int) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
INTERNAL: Used to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord
setIndex(int) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
INTERNAL: Used to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord
setIndex(int) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
INTERNAL: Used to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord
setIndex(int) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
INTERNAL: Used to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord
setIndex(int) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
INTERNAL: Used to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord
setIndex(int) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
INTERNAL: Used to track the index of the corresponding containerInstance in the containerInstances Object[] on UnmarshalRecord
setIndex(int) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
setIndex(Integer) - Method in class org.eclipse.persistence.descriptors.changetracking.CollectionChangeEvent
INTERNAL: Set the index of the change in the collection
setIndex(Integer) - Method in class org.eclipse.persistence.internal.helper.IndexedObject
 
setIndex(Integer) - Method in class org.eclipse.persistence.internal.sessions.OrderedChangeObject
INTERNAL: Set the index the change was made to the collection.
setIndexes(List<IndexDefinition>) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC:
setIndexValue(int) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setIndirectionPolicy(IndirectionPolicy) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
ADVANCED: Set the indirection policy.
setIndirectionPolicy(IndirectionPolicy) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
ADVANCED: Set the indirection policy.
setInheritanceExpression(Expression) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
setInheritancePolicy(INHERITANCE_POLICY) - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
INTERNAL: Sets the inheritance policy.
setInheritancePolicy(InheritancePolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Sets the inheritance policy.
setInitialContextFactoryName(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
 
setInitialContextFactoryName(String) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
ADVANCED: Set the context factory name used as the value to the INITIAL_CONTEXT_FACTORY key in the cached context properties.
setInitializationStage(int) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL:
setInitializatonPolicy(DynamicPropertiesInitializatonPolicy) - Method in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
 
setInitiallyConformingIndex(Map<Object, Object>) - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Conforming instances found in memory when building the result.
setInitialNumberOfConnections(int) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Set the initial number of connections allowed.
setInitialPoolSize(int) - Method in interface org.eclipse.persistence.sequencing.SequencingControl
PUBLIC: Sets a initial number of connections in sequencing connection pool The set value is ignored if shouldUseSeparateConnection() returns false.
setInitialReadSize(int) - Method in class org.eclipse.persistence.queries.CursoredStreamPolicy
Specifies the number of elements to be read initially into a cursored stream
setInitialValue(int) - Method in class org.eclipse.persistence.sequencing.Sequence
 
setInitialValue(int) - Method in class org.eclipse.persistence.sequencing.StandardSequence
 
setInitialValue(String) - Method in class org.eclipse.persistence.internal.codegen.AttributeDefinition
 
setInitialWriteLockValue(Object) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
ADVANCED: This method is used to set the initial writeLock value for an ObjectChangeSet.
setInjectionManager(InjectionManager<?>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
 
setInlineMapping(MAPPING) - Method in interface org.eclipse.persistence.internal.oxm.mappings.InverseReferenceMapping
 
setInlineMapping(DatabaseMapping) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
setInMemoryQueryIndirectionPolicy(InMemoryQueryIndirectionPolicy) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Set the InMemoryQueryIndirectionPolicy for this query.
setInMemoryQueryIndirectionPolicyState(int) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Set the InMemoryQueryIndirectionPolicy for this query.
setInputRecordName(String) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: Set the input record name.
setInputResultPath(String) - Method in class org.eclipse.persistence.eis.interactions.MappedInteraction
PUBLIC: The input result path defines the root key for the MappedRecord that the interaction argument is nested into.
setInputRootElementName(String) - Method in class org.eclipse.persistence.eis.interactions.XMLInteraction
PUBLIC: Set the root element name to use for the input DOM.
setInputRow(AbstractRecord) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: Set the input database row.
setInsertable(boolean) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Used to specify whether the column should be included in SQL UPDATE statements.
setInsertCall(Call) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's insert call.
setInsertCall(Call) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Set the receiver's insert Call.
setInsertCall(Call) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Set the receiver's insert Call.
setInsertQuery(DataModifyQuery) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
setInsertQuery(DataModifyQuery) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
 
setInsertQuery(DataModifyQuery) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
 
setInsertQuery(InsertObjectQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's insert query.
setInsertSQLString(String) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's insert SQL string.
setInsertSQLString(String) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Set the receiver's insert SQL string.
setInsertSQLString(String) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Set the receiver's insert SQL string.
setInsertSQLString(String) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Set the receiver's insert SQL string.
setInstantiated() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Set the instantiated flag to true.
setInstantiationPolicy(INSTANTIATION_POLICY) - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
INTERNAL: Sets the instantiation policy.
setInstantiationPolicy(INSTANTIATION_POLICY) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: Sets the instantiation policy.
setInstantiationPolicy(InstantiationPolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Sets the instantiation policy.
setIntegrityChecker(IntegrityChecker) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: set the integrityChecker.
setIntegrityChecker(IntegrityChecker) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: set the integrityChecker.
setIntegrityChecker(IntegrityChecker) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Set the integrityChecker, the integrityChecker holds all the ClassDescriptor Exceptions.
setInteractionSpec(InteractionSpec) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: Set the JCA InteractionSpec that defines this EIS interaction.
setInterfaceInitializationStage(int) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL:
setInterfacePolicy(InterfacePolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Sets the interface policy.
setInternalDefaultTable() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the default table if one if not already set.
setInternalDefaultTable(DatabaseTable) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the default table if one if not already set.
setInternalException(Throwable) - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL: Used to specify the internal exception.
setInternalExceptions(Collection) - Method in exception org.eclipse.persistence.exceptions.JPQLException
INTERNAL Store the exceptions related to this exception
setInternalMax(int) - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: sets the JPA max results that may have been set on a NamedQuery
setInternalMultipleTableJoinExpression(Expression) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: Used to set the multiple table join expression that was generated by EclipseLink as opposed to a custom one supplied by the user.
setInvalidateOnChange(boolean) - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Configure if any change to any object of the query class should cause the query results to be invalidated.
setInvalidationClasses(Set<Class<?>>) - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
ADVANCED: Set the set of classes that should trigger the query cached results to be invalidated.
setInvalidationState(int) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
INTERNAL: Set the value of the invalidationState Variable The possible values are from an enumeration of constants CHECK_INVALIDATION_POLICY - The invalidation policy is must be checked for this cache key's sate CACHE_KEY_INVALID - This cache key has been labelled invalid.
setInvalidationState(int) - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
setIsAbstract(boolean) - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
setIsAbstract(boolean) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
setIsActive(boolean) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Set if the commit manager is active.
setIsActive(boolean) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Set if the client session is active (has not been released).
setIsAggregate(boolean) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Set if this object change Set represents an aggregate
setIsAggregateSelect(boolean) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
setIsAny(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
setIsBatchExecutionSupported(boolean) - Method in class org.eclipse.persistence.queries.ModifyQuery
PUBLIC: Set if this query is compatible with batch writing.
setIsBindingSupported(boolean) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
PUBLIC: Set if binding is compatible with this operator.
setIsCacheable(boolean) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
Used to signal that this mapping references a protected/isolated entity and requires special merge/object building behaviour.
setIsCacheable(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Used to signal that this mapping references a protected/isolated entity and requires special merge/object building behaviour.
setIsCallableStatementRequired(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Callable statement is required if there is an output parameter.
setIsCascaded(boolean) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
PUBLIC: Set whether to use cascade locking on the policy.
setIsCascadeOnDeleteSetOnDatabase(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
ADVANCED: Set if delete cascading has been set on the database for the mapping's foreign key constraint.
setIsCascadeOnDeleteSetOnDatabaseOnSecondaryTables(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Set if delete cascading has been set on the database for the descriptor's multiple tables.
setIsCastRequired(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Set if casting is enabled for platforms that support it.
setIsCDATA(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
 
setIsCDATA(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
 
setIsCDATA(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
INTERNAL:
setIsCDATA(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
setIsCDATA(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
 
setIsCDATA(boolean) - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL:
setIsChangeSetFromOutsideUOW(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Set the internal flag that tells that this change set was built outside this UOW and the changes it contains cannot be calculated from the contents of this UOW
setIsCMP(boolean) - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: setIsCMP(boolean): Define whether or not we're in the context of CMP (i.e.
setIsComplete(boolean) - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
 
setIsComplete(boolean) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Set the list complete and notify any waiters.
setIsConcurrent(boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Set if the session enables concurrent processing.
setIsConcurrent(Boolean) - Method in class org.eclipse.persistence.queries.LoadGroup
ADVANCED: Set if the load group should load its relationships concurrently.
setIsConnected(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Set whether the accessor has a connection to the "data store".
setIsConnected(boolean) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: Set if this pool has been connected to the database.
setIsConstructor(boolean) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
setIsCoordinatedWithProperty(boolean) - Method in class org.eclipse.persistence.indirection.ValueHolder
Used as part of the implementation of WeavedAttributeValueHolderInterface Used to track whether a valueholder that has been weaved into a class is coordinated with the underlying property This method will be called internall when the state of Coordination between the weaved valueholder and the underlying value is known
setIsCoordinatedWithProperty(boolean) - Method in interface org.eclipse.persistence.indirection.WeavedAttributeValueHolderInterface
TopLink will call this method when the triggering of a weaved valueholder causes it's value to be coordinated with the underlying property
setIsCoordinatedWithProperty(boolean) - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
This method is used as part of the implementation of WeavedAttributeValueHolderInterface It is used internally by EclipseLink to set whether a valueholder that has been weaved into a class is coordinated with the underlying property
setIsCursor(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
setIsCursorOutputProcedure(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Used for Oracle result sets through procedures.
setIsCustomQueryUsed(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: PERF: Set if this query will use the descriptor custom query instead of executing itself.
setIsDead(boolean) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
ADVANCED: Set if the connection pool's database is down, and failover should be used.
setIsDeferred(boolean) - Method in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
Sets if this change should be calculated at commit time using the two collections.
setIsDOMRecordSupported(boolean) - Method in class org.eclipse.persistence.eis.EISPlatform
Set if this platform supports XML/DOM Records.
setIsDynamicStatementInUse(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Set if the cached statement for dynamic SQL execution is in use.
setIsExecuteCall(boolean) - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: Set to true if you the actual jdbc result set returned from query execution.
setIsExecutionClone(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: PERF: Set if the query is an execution clone.
setIsFieldMatchingRequired(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Field matching is required for custom SQL statements where the result set field order is not known.
setIsFinal(boolean) - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
setIsFinalizersEnabled(boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Set if this session's decendants should use finalizers.
setIsFinalizersEnabled(boolean) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Set if this session's descendants should use finalizers.
setIsFirstElementPrinted(boolean) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
INTERNAL: Used in figuring out when to print a comma in the select clause
setIsFlush(boolean) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
setIsForeignKeyRelationship(boolean) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Set if the 1-M mapping has a foreign key dependency to its target.
setIsForeignKeyRelationship(boolean) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Set if the 1-1 mapping has a foreign key dependency to its target.
setIsFullRowRequired(boolean) - Method in class org.eclipse.persistence.queries.DeleteObjectQuery
ADVANCED: Set if the full row is required by the delete query.
setIsIdentity(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Set whether the receiver is an identity field.
setIsInAndOutSopObject() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Set the mapping is both in and out of SerializedObjectPolicy's sopObject
setIsInBroker(boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Set if this session is contained in a SessionBroker.
setIsIndexedRecordSupported(boolean) - Method in class org.eclipse.persistence.eis.EISPlatform
Set if this platform supports JCA IndexedRecord.
setIsInMemoryOnly(boolean) - Method in class org.eclipse.persistence.queries.DeleteAllQuery
INTERNAL: Set if objects should be remove from the persistence context only (no database).
setIsInProfile(boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Allow for user deactive a profiler
setIsInsert(boolean) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
setIsInsertable(boolean) - Method in class org.eclipse.persistence.descriptors.CacheIndex
Set if the index field can be inserted.
setIsInsertModeReturnOnly(boolean) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
setIsInSopObject() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Set the mapping is in SerializedObjectPolicy's sopObject.
setIsInTransaction(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Set the transaction transaction status of the receiver.
setIsInTransaction(boolean) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
 
setIsInvalid(boolean) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
setIsInvalidationRandomized(boolean) - Method in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
PUBLIC: Allows the timeToLive to be randomized to avoid bottlenecks.
setIsJPAId() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Flags that this mapping is part of a JPA id mapping.
setIsLazy(boolean) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
Set if this mapping is lazy.
setIsLazy(boolean) - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Set if a lazy connection should be used, a lazy connection only acquire a physical connection when a transaction is started and releases the connection when the transaction completes.
setIsListOrderBrokenInDb(boolean) - Method in class org.eclipse.persistence.indirection.IndirectList
 
setIsListOrderFieldUpdatable(boolean) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: indicates whether listOrderField value could be updated in the db.
setIsLockedByMergeManager(boolean) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
INTERNAL: Used by the mergemanager to let the read know not to refresh this object as it is being loaded by the merge process.
setIsMapKeyMapping(boolean) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
 
setIsMappedRecordSupported(boolean) - Method in class org.eclipse.persistence.eis.EISPlatform
Set if this platform supports JCA MappedRecord.
setIsMetadataRemote(boolean) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
ADVANCED: Set if the descriptors and meta-data should be serialized from the server, or if they will be provided locally.
setIsMixedNodeValue(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
INTERNAL: Indicates that this is the choice mapping node value that represents the mixed content.
setIsMixedNodeValue(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
INTERNAL: Indicates that this is the choice mapping node value that represents the mixed content.
setIsMultipleCursorOutputProcedure(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Used for Oracle result sets through procedures.
setIsMutable(boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
PUBLIC: Return true if the attribute for this mapping is a simple atomic value that cannot be modified, only replaced.
setIsMutable(boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Set if the value of the attribute is atomic or a complex mutable object and can be modified without replacing the entire object.
setIsNative(boolean) - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
setIsNativeConnectionRequired(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Set if the descriptor requires usage of a native (unwrapped) JDBC connection.
setIsNativeConnectionRequired(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Set if the call requires usage of a native (unwrapped) JDBC connection.
setIsNativeConnectionRequired(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: Set if the descriptor requires usage of a native (unwrapped) JDBC connection.
setIsNestedTable(boolean) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCollection
Set boolean that indicates if the instance represents a Nested Table (as opposed to Varray)
setIsNew(boolean) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Set whether this ObjectChanges represents a new Object
setIsNewlyWeavedValueHolder(boolean) - Method in class org.eclipse.persistence.indirection.ValueHolder
Used as part of the implementation of WeavedAttributeValueHolderInterface Used to determine if this ValueHolder was added instantiated as part of the constructor of a weaved class This method will be called when a ValueHolder is instantiated in a weaved class
setIsNewlyWeavedValueHolder(boolean) - Method in interface org.eclipse.persistence.indirection.WeavedAttributeValueHolderInterface
TopLink weaving calls this method on any valueholder it weaves into a class to indicate that it is new and it's value should not be considered.
setIsNewlyWeavedValueHolder(boolean) - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
This method is used as part of the implementation of WeavedAttributeValueHolderInterface A DatabaseValueHolder is set up by EclipseLink and will never be a newly weaved valueholder As a result, this method is stubbed out.
setIsNonAssociativeCollection(boolean) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
Sets flag on this argument's database type indicating that it represents a non-associative collection, i.e.
setIsNullAllowed(boolean) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
PUBLIC: Configure if all the fields in the database row for the aggregate object are NULL, then, by default, the mapping will place a null in the appropriate source object (as opposed to an aggregate object filled with nulls).
setIsNullAllowed(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.ObjectVarrayDefinition
PUBLIC: Set if the varray collection is allowed NULL or not
setIsNullIgnored(boolean) - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Set if null results should be cached or ignored.
setIsolated(boolean) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
setIsOnClient(boolean) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
setIsOneToOnePrimaryKeyRelationship(boolean) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
Set if this mapping is defined using primary key join columns.
setIsOneToOneRelationship(boolean) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
Define if this mapping is really for a OneToOne relationship.
setIsOptional(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.TransformationMapping
Used to specify whether the value of this mapping may be null.
setIsOptional(boolean) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
Used to specify whether the value of this mapping may be null.
setIsOuterJoinedAttributeQuery(boolean) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
PERF: Set if the query uses any outer attribute joins, used to avoid null checks in building objects.
setIsOutSopObject() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Set the mapping is out of SerializedObjectPolicy's sopObject.
setIsParsed(boolean) - Method in class org.eclipse.persistence.internal.queries.QueryByExampleMechanism
INTERNAL: Set the isParsed state
setIsParsed(boolean) - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL Set the isParsed state
setIsPrepared(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Bound calls can have the SQL pre generated.
setIsPrepared(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: If changes are made to the query that affect the derived SQL or Call parameters the query needs to be prepared again.
setIsPrepared(boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Clear cached flags when un-preparing.
setIsPreparedKeepingSubclassData(boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Clear cached flags when un-preparing.
setIsPreparedUsingTempStorage(boolean) - Method in class org.eclipse.persistence.queries.ModifyAllQuery
INTERNAL:
setIsPrePrepared(boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: If changes are made to the query that affect the derived SQL or Call parameters the query needs to be prepared again.
setIsPrimaryKey(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Set whether the receiver is a primary key.
setIsPrimaryKeyMapping(boolean) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Set by the Object builder during initialization returns true if this mapping is used as a primary key mapping.
setIsPrivateOwned(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Set if the relationship is privately owned.
setIsProperty(boolean) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Set to true if this parameter expression maps to a property value.
setIsReadOnly(boolean) - Method in interface org.eclipse.persistence.core.mappings.CoreAttributeAccessor
INTERNAL
setIsReadOnly(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
Set this mapping to be read only.
setIsReadOnly(boolean) - Method in class org.eclipse.persistence.mappings.AttributeAccessor
INTERNAL
setIsReadOnly(boolean) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: Set this mapping to be read only.
setIsReadOnly(boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Set the query to be read-only.
setIsResultSetAccessOptimizedQuery(boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
ADVANCED: Set if the query should be optimized to build directly from the result set.
setIsResultSetOptimizedQuery(boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
ADVANCED: Set if the query should be optimized to build directly from the result set.
setIsResultSetScrollable(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
setIsSetMethodName(String) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
 
setIsSetParameters(Object[]) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
 
setIsSetParameterTypes(Class<?>[]) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
 
setIsSizeAllowed(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Set if this type can support a size specification.
setIsSizeRequired(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Set if this type must have a size specification.
setIsStatic(boolean) - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
setIsStoredInCache(boolean) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
PUBLIC: Set whether to store the lock in the cache or in the object.
setIsSynchronized(boolean) - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
setIsThreadComplete(boolean) - Method in class org.eclipse.persistence.internal.helper.DeferredLockManager
set if the thread is complete in the given DLM
setIsToManyJoinQuery(boolean) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Set if the query uses any -m joins, and thus return duplicate/multiple rows.
setIsTransient(boolean) - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
setIsTranslated(boolean) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Set the isTranslated flag.
setIsTypedTextField(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Set if the field is a typed text field True when we should base conversions on the "type" attribute on elements
setIsTypedTextField(boolean) - Method in class org.eclipse.persistence.oxm.XMLField
Set if the field is a typed text field True when we should base conversions on the "type" attribute on elements
setIsUnique(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.IndexDefinition
 
setIsUpdate(boolean) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
setIsUpdateable(boolean) - Method in class org.eclipse.persistence.descriptors.CacheIndex
Set if the index field can be updated.
setIsUserDefined(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set if the query is a custom user defined query.
setIsUserDefinedSQLCall(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set if the query is a custom user defined sql call query.
setIsValid(boolean) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
This should be set to false if a communication failure occurred durring a call execution.
setIsValid(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
This should be set to false if a communication failure occurred during a call execution.
setIsVolatile(boolean) - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
setIsWrapper(boolean) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
setIsWrapper(boolean) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.core.mappings.CoreAttributeAccessor
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyAttributeMapping
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyCollectionMapping
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyObjectMapping
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceObjectMapping
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ObjectReferenceMapping
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.VariableXPathObjectMapping
 
setIsWriteOnly(boolean) - Method in class org.eclipse.persistence.mappings.AttributeAccessor
INTERNAL:
setIsWriteOnly(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAbstractAnyMapping
 
setIsWriteOnly(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
setIsWriteOnly(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
setIsWriteOnly(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
setIsWriteOnly(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
setIsWriteOnly(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
setIsWriteOnly(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
setIsWriteOnly(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
 
setIsWriteOnly(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
 
setIsWriteOnly(boolean) - Method in interface org.eclipse.persistence.oxm.mappings.XMLMapping
 
setIsWriteOnly(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
 
setIsWriteOnly(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLTransformationMapping
 
setItems(List<ReportItem>) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Set the ReportQueryItems defining the attributes to be read.
setItemType(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.List
 
setJavaClass(Class<?>) - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
PUBLIC: Set the Java class that this descriptor maps.
setJavaClass(Class<?>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the Java class that this descriptor maps.
setJavaClass(Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Set the Java class that this descriptor maps.
setJavaClassName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return the java class name, used by the MW.
setJavaClassName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: Return the java class name, used by the MW.
setJavaInterface(Class<?>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Sets the descriptor to be for an interface.
setJavaInterfaceName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return the java interface name, used by the MW.
setJavaType(Class<?>) - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
Set the Java class that the complex type maps to.
setJavaType(String) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionPair
 
setJavaTypeName(String) - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
setJdbcBatchWriting(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setJNDINamingServiceConfig(JNDINamingServiceConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.JMSPublishingTransportManagerConfig
 
setJNDINamingServiceConfig(JNDINamingServiceConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.RMITransportManagerConfig
 
setJoinCriteria(Expression) - Method in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
PUBLIC: Set the join expression for the relationship defined by the query key.
setJoinedAttributeExpressions(List) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Convenience method for project mapping.
setJoinedAttributeExpressions_(List) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Set the list of expressions that represent elements that are joined because of their mapping for this query.
setJoinedAttributeManager(JoinedAttributeManager) - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
setJoinedAttributeManager(JoinedAttributeManager) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Set join manager responsible for managing all aspects of joining for the query.
setJoinedMappingExpressions_(List) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Set the list of expressions that represent elements that are joined because of their mapping for this query.
setJoinedMappingIndexes_(Map) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Set the joined mapping indexes, used to compute mapping row partitions.
setJoinedMappingQueries_(Map) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Set the joined mapping queries, used optimize joining, only compute the nested queries once.
setJoinedMappingQueryClones(Map) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
 
setJoinedStrategy() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Used to indicate a JOINED inheritance strategy.
setJoinFetch(int) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Indicates whether the referenced object(s) should always be joined on read queries.
setJoinSource(Expression) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
setJPAQueriesProcessed(boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: used to set if JPA Queries have been processed during initialization
setJPQLCall(JPQLCall) - Method in class org.eclipse.persistence.internal.queries.JPQLCallQueryMechanism
 
setJPQLParseCache(ConcurrentFixedCache) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set the JPQL parse cache.
setJPQLParseCacheMaxSize(int) - Method in class org.eclipse.persistence.sessions.Project
ADVANCED: Set the JPQL parse cache max size.
setJPQLString(String) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Set the JPQL string of the query.
setJPQLString(String) - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: Set the JPQL string for this call
setJsonArrayBuilder(JsonArrayBuilder) - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord.Level
 
setJsonDisableNestedArrayName(boolean) - Method in class org.eclipse.persistence.internal.oxm.JsonTypeConfiguration
Setter for JSON property to enable/disable generation of "item" name in nested arrays in JSON.
setJsonObjectBuilder(JsonObjectBuilder) - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord.Level
 
setJsonTypeAttributeName(String) - Method in class org.eclipse.persistence.internal.oxm.JsonTypeConfiguration
Override default type property name for JSON as MOXy type discriminator.
setJsonTypeCompatibility(boolean) - Method in class org.eclipse.persistence.internal.oxm.JsonTypeConfiguration
If we should treat unqualified type property in JSON as MOXy type discriminator.
setJustificationWhyMethodIsBuildingObjectCompleteReturnsFalse(String) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
setKeepAsElementPolicy(UnmarshalKeepAsElementPolicy) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
setKeepAsElementPolicy(UnmarshalKeepAsElementPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLAbstractAnyMapping
 
setKeepAsElementPolicy(UnmarshalKeepAsElementPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
setKeepAsElementPolicy(UnmarshalKeepAsElementPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
setKeepAsElementPolicy(UNMARSHAL_KEEP_AS_ELEMENT_POLICY) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyCollectionMapping
 
setKeepAsElementPolicy(UNMARSHAL_KEEP_AS_ELEMENT_POLICY) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyObjectMapping
 
setKeepAsElementPolicy(UNMARSHAL_KEEP_AS_ELEMENT_POLICY) - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
 
setKeepInRow(boolean) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
setKey(Object) - Method in class org.eclipse.persistence.descriptors.changetracking.MapChangeEvent
INTERNAL: Set the change type
setKey(Object) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
setKey(Object) - Method in class org.eclipse.persistence.internal.sessions.remote.ObjectDescriptor
Set primary key values of an associated object
setKey(Object) - Method in class org.eclipse.persistence.mappings.Association
PUBLIC: Set the key.
setKey(Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
setKeyClass(Class<?>) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
PUBLIC: This is a helper method to set the key converter to a TypeConversionConverter.
setKeyConverter(Converter) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
PUBLIC: Set the converter on the mapping.
setKeyConverter(Converter, DirectMapMapping) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Set a converter on the KeyField of a DirectCollectionMapping.
setKeyConverterClassName(String) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Set the converter class name on the mapping.
setKeyConverterClassName(String, DirectMapMapping) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Set the name of the class to be used as a converter for the key of a DirectMapMaping.
setKeyField(DatabaseField, ClassDescriptor) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Set the DatabaseField that will represent the key in a DirectMapMapping.
setKeyMapping(MapKeyMapping) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
 
setKeyMethod(String, Class<?>) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Sets the Method to be used to generate the key in a Map type container class.
setKeyMethod(String, String) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Sets the Method to be used to generate the key in a Map type container class.
setKeyMethodName(String) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Sets the Method to be used to generate the key in a Map type container class.
setKeyName(String) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Sets the key name to be used to generate the key in a Map type container class.
setKeyName(String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
setKeyName(String, Class<?>) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Sets the key name to be used to generate the key in a Map type container class.
setKeyName(String, Class<?>) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Sets the key name to be used to generate the key in a Map type container class.
setKeyName(String, String) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: It is illegal to send this message to this receiver.
setKeyName(String, String) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Sets the key name to be used to generate the key in a Map type container class.
setKeyQuery(DatabaseQuery) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Some map keys must be obtained from the database.
setKeyType(Class<?>) - Method in class org.eclipse.persistence.mappings.TypedAssociation
PUBLIC: Set the class of the key.
setLastCallAppended(DatabaseCall) - Method in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
 
setLastFieldIndex(int) - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleObjectType
 
setLastUpdatedQueryId(long) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
INTERNAL: This method sets the system time in millis seconds at which this object was last refreshed CR #4365 CR #2698903 ...
setLastUpdatedQueryId(long) - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
setLastXPathFragment(XPathFragment) - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL: Maintain a direct pointer to the last XPathFragment.
setLatestCollection(Object) - Method in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
Used for change tracking when user sets entire collection.
setLazilyInitialized(boolean) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
Specify in the descriptor may be lazily initialized.
setLazy(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPolicyConfig
 
setLeafElementType(QName) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
setLeafElementType(QName) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
setLeafElementType(QName) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
setLeafElementType(QName) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setLeafElementType(QName) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setLeafElementType(QName) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setLeafElementType(QName) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
setLeafElementType(QName) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL:
setLeafElementType(QName) - Method in class org.eclipse.persistence.oxm.XMLField
Assumes type is in the format prefix:localPart, or localPart.
setLeafElementType(XPathQName) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
setLeafElementType(XPathQName) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
setLeafElementType(XPathQName) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setLeafElementType(XPathQName) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL:
setLength(int) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Used to specify the column length when generating DDL.
setLength(int) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setLength(int) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setLength(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setLevel(int) - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
setLevel(int) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
setLevel(int) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Set the log level.
setLevel(int) - Method in class org.eclipse.persistence.logging.SessionLogEntry
Set the request level of the log entry.
setLevel(int, String) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
setLevel(int, String) - Method in class org.eclipse.persistence.logging.DefaultSessionLog
 
setLevel(int, String) - Method in class org.eclipse.persistence.logging.JavaLog
PUBLIC:
setLevel(int, String) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Set the log level.
setLexicalHandler(LexicalHandler) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
setLexicalHandler(LexicalHandler) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
setLexicalHandler(LexicalHandler) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
Set the LexicalHandler to receive CDATA related events
setLifecycle(int) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The life cycle tracks if the unit of work is active and is used for JTS.
setLimits() - Method in class org.eclipse.persistence.queries.CursoredStream
INTERNAL: Initialize the stream size and position
setLimits(int, int, int) - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Set the maximum precision and the minimum and maximum scale.
setList(List) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
setListenerFactory(SynchronizationListenerFactory) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Set the factory used to generate synchronization listeners.
setListeners(List<SessionEventListener>) - Method in class org.eclipse.persistence.sessions.SessionEventManager
The event listeners will receive all events raised by this session.
setListOrderField(DatabaseField) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
 
setListOrderField(DatabaseField) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Field holds the order of elements in the list in the db, requires collection of type List.
setListOrderFieldName(String) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Field holds the order of elements in the list in the db, requires collection of type List.
setLoader(ClassLoader) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
INTERNAL:
setLoadGroup(LoadGroup) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Set a load group to the query.
setLobValueLimits(int) - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
PUBLIC: Set the BLOB/CLOB value limits on thin driver.
setLocalBase(Expression) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Set the local base expression, ie the one on the other side of the operator Most types will ignore this, since they don't need it.
setLocalBase(Expression) - Method in class org.eclipse.persistence.internal.expressions.CollectionExpression
 
setLocalBase(Expression) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
 
setLocalBase(Expression) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
setLocalBase(Expression) - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
 
setLocalBase(Expression) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
The opposite side of the relation, this is used for conversion of the parameter using the others mapping.
setLocalContextProperties(Hashtable) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
ADVANCED: Set the properties that will be used to create the initial context for local JNDI access.
setLocalName(String) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setLocalName(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setLocalName(String) - Method in class org.eclipse.persistence.internal.oxm.Root
Set the element name.
setLocalName(String) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setLocalName(String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setLocalResources(Hashtable<String, String>) - Method in class org.eclipse.persistence.internal.sessions.factories.PersistenceEntityResolver
INTERNAL:
setLocalTime(long) - Method in class org.eclipse.persistence.tools.profiler.Profile
 
setLocationAccessor(ATTRIBUTE_ACCESSOR) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: Set this Descriptor's location accessor.
setLocationAccessor(AttributeAccessor) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Set this Descriptor's location accessor.
setLocator(Locator) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
INTERNAL: set the Locator object to associate with this reader
setLockableMappings(List<DatabaseMapping>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the list of lockable mappings for this project This method is provided for CMP use.
setLockedExpressions(List<Expression>) - Method in class org.eclipse.persistence.internal.expressions.ForUpdateOfClause
 
setLockFieldNames(List<String>) - Method in class org.eclipse.persistence.descriptors.SelectedFieldsLockingPolicy
PUBLIC: Set the field names to lock on.
setLockFields(List<DatabaseField>) - Method in class org.eclipse.persistence.descriptors.SelectedFieldsLockingPolicy
INTERNAL: Sets the lock fields
setLockFieldsByTable(Map<DatabaseTable, List<DatabaseField>>) - Method in class org.eclipse.persistence.descriptors.SelectedFieldsLockingPolicy
INTERNAL: Used to set the field names to be used in this policy.
setLockingClause(ForUpdateClause) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
setLockingClause(ForUpdateClause) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: The locking clause contains a list of expressions representing which objects are to be locked by the query.
setLockingMode(short) - Method in class org.eclipse.persistence.descriptors.PessimisticLockingPolicy
PUBLIC: Set locking mode.
setLockMode(short) - Method in class org.eclipse.persistence.internal.expressions.ForUpdateOfClause
 
setLockMode(short) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
PUBLIC: Sets whether this is a pessimistically locking query.
setLockMode(short) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Sets whether this is a pessimistically locking query.
setLockModeType(String, AbstractSession) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Sets a jakarta.persistence.LockModeType to used with this queries execution.
setLockModeType(String, AbstractSession) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Sets a jakarta.persistence.LockModeType to used with this queries execution.
setLockOnChangeMode(OptimisticLockingPolicy.LockOnChange) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
ADVANCED: Sets the LockOnChange mode for this policy.
setLockOnChangeMode(OptimisticLockingPolicy.LockOnChange) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
ADVANCED: Sets the LockOnChange mode for this policy.
setLockOnChangeMode(OptimisticLockingPolicy.LockOnChange) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
ADVANCED: Sets the LockOnChange mode for this policy.
setLockThread(Thread) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTERNAL: Save the currentThread for later comparison to the activeThread in case they don't match
setLog(Writer) - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Sets the attunity adapter message log.
setLog(Writer) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Set the writer to which an accessor writes logged messages and SQL.
setLog(Writer) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Set the message log.
setLog(Writer) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Set the writer to which an accessor writes logged messages and SQL.
setLog(SessionLog) - Static method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
setLogConfig(LogConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
setLoggingOff(boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: PERF: Used for quick turning logging ON/OFF entirely.
setLoggingOptions(LoggingOptionsConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.LogConfig
 
setLogin(LOGIN) - Method in class org.eclipse.persistence.core.sessions.CoreProject
PUBLIC: Set the login to be used to connect to the database for this project.
setLogin(DatabaseLogin) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Set the login.
setLogin(DatabaseLogin) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set the login to be used to connect to the database for this project.
setLogin(Login) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
SECURE: set the login
setLogin(Login) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Set the login.
setLogin(Login) - Method in interface org.eclipse.persistence.sequencing.SequencingControl
ADVANCED: Returns a DatabaseLogin to be used by separate sequencing connection(s) The set value is ignored if shouldUseSeparateConnection() returns false.
setLogin(Login) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Set the login.
setLogin(Login) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set the login to be used to connect to the database for this project.
setLogin(Login) - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Set the login to use for this connection.
setLogin(Login) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Set the login used to create connections.
setLoginConfig(LoginConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPoolConfig
 
setLoginConfig(LoginConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.DatabaseSessionConfig
 
setLogLevel(int) - Method in interface org.eclipse.persistence.core.sessions.CoreSession
PUBLIC: Set the log level.
setLogLevel(int) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
setLogLevel(int) - Method in class org.eclipse.persistence.services.RuntimeServices
Set the log level
setLogLevel(int) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Set the log level.
setLogLevel(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.DefaultSessionLogConfig
 
setLogPayload(Boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
setLogPayload(Boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
setLongestTime(long) - Method in class org.eclipse.persistence.tools.profiler.Profile
 
setLookupType(int) - Method in class org.eclipse.persistence.sessions.JNDIConnector
Deprecated.
As of 2.6.0, replaced by configuration provided by ServerPlatform.getJNDIConnectorLookupType()
setLookupType(Integer) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setManager(SessionManager) - Static method in class org.eclipse.persistence.sessions.factories.SessionManager
INTERNAL: Set the singleton session manager.
setMappedBy(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.InverseReferenceMapping
 
setMappedBy(String) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Called by JPA metadata processing to store the owning mapping for this mapping
setMappedBy(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
setMappedClass(Class<?>) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
PUBLIC: Define the mapped class.
setMapping(CoreMapping) - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
setMapping(DatabaseMapping) - Method in exception org.eclipse.persistence.exceptions.DescriptorException
INTERNAL: Set the mapping.
setMapping(DatabaseMapping) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
setMapping(DatabaseMapping) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: set the database mapping that uses the indirection policy.
setMapping(DatabaseMapping) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
setMapping(DatabaseMapping) - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
setMapping(DatabaseMapping) - Method in class org.eclipse.persistence.internal.sessions.ChangeRecord
Sets the mapping for the attribute that this Record represents
setMapping(DatabaseMapping) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Set mapping
setMapping(DatabaseMapping) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Set the mapping.
setMapping(ForeignReferenceMapping) - Method in class org.eclipse.persistence.internal.indirection.BatchValueHolder
 
setMappingQueries(Map<DatabaseMapping, ReadQuery>) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
INTERNAL: PERF: Set the internally stored prepared mapping queries.
setMappings(Vector<DatabaseMapping>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the mappings.
setMappingsByAttribute(Map<String, DatabaseMapping>) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
All the mappings and their respective attribute associations are cached for performance improvement.
setMappingsByField(Map<DatabaseField, DatabaseMapping>) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: All the mappings and their respective field associations are cached for performance improvement.
setMapsIdValue(String) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: Set the maps id value
setMarker(int) - Method in class org.eclipse.persistence.queries.CursoredStream
INTERNAL: Set the marker used for mark() & reset() operations
setMarshalAttributeGroup(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
setMarshalEmptyCollections(Boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Name of the property to determine if empty collections should be marshalled as [] Ignored marshalling XML.
setMarshaller(MARSHALLER) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
setMarshaller(MARSHALLER) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
setMarshaller(MARSHALLER) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
setMarshaller(Marshaller) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
setMarshaller(XMLMarshaller) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
INTERNAL:
setMarshaller(XMLMarshaller) - Method in interface org.eclipse.persistence.oxm.record.JSONWriterRecord.Output
 
setMarshaller(XMLMarshaller) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.OutputStreamOutput
 
setMarshaller(XMLMarshaller) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
setMarshaller(XMLMarshaller) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
 
setMarshaller(XMLMarshaller) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL:
setMarshaller(XMLMarshaller) - Method in class org.eclipse.persistence.oxm.XMLBinder
 
setMarshalListener(MARSHALLER_LISTENER) - Method in class org.eclipse.persistence.internal.oxm.Marshaller
 
setMarshalListener(XMLMarshalListener) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
 
setMarshalNodeValue(NodeValue) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
setMarshalNullRepresentation(XMLNullRepresentationType) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
Set the enum that determines what XML to write when a null value is encountered.
setMarshalRecord(MarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
setMaxAllowedFrequencyToProduceMassiveDumpLogMessage(long) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setMaxAllowedFrequencyToProduceTinyDumpLogMessage(long) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setMaxAllowedSleepTime(long) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setMaxBatchSize(int) - Method in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
 
setMaxBatchWritingSize(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
PUBLIC: Allow for the max batch writing size to be set.
setMaxBatchWritingSize(int) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Allow for the max batch writing size to be set.
setMaxBatchWritingSize(Integer) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setMaxConnections(Integer) - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPoolConfig
 
setMaxExclusive(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setMaxExclusive(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setMaximumCachedResults(int) - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Set the maximum cached results.
setMaxInclusive(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setMaxInclusive(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setMaxLength(int) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setMaxLength(int) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setMaxLength(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setMaxNumberOfConnections(int) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Set the maximum number of connections allowed.
setMaxNumberOfNonPooledConnections(int) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Set the number of non-pooled database connections allowed.
setMaxNumberOfNonPooledConnections(int) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Set the number of non-pooled database connections allowed.
setMaxOccurs(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Any
 
setMaxOccurs(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setMaxOccurs(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
setMaxOccurs(String) - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
setMaxOccurs(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.TypeDefParticle
 
setMaxPoolSize(int) - Method in interface org.eclipse.persistence.sequencing.SequencingControl
PUBLIC: Sets a maximum number of connections in sequencing connection pool The set value is ignored if shouldUseSeparateConnection() returns false.
setMaxPrecision(int) - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
setMaxRows(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
set query max returned row size to the JDBC Statement
setMaxRows(int) - Method in class org.eclipse.persistence.queries.ReadQuery
PUBLIC: Used to set the limit for the maximum number of rows that any ResultSet can contain to the given number.
setMaxScale(int) - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
setMaxSize(int) - Method in class org.eclipse.persistence.internal.helper.ConcurrentFixedCache
Set the fixed size of the parse cache.
setMaxSize(int) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Set the maximum size for the receiver.
setMediaType(MEDIA_TYPE) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Set the MediaType for this xmlMarshaller.
setMediaType(MEDIA_TYPE) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Set the MediaType for this xmlUnmarshaller.
setMediaType(MediaType) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
Set the MediaType for this xmlMarshaller.
setMediaType(MediaType) - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
Set the MediaType for this xmlUnmarshaller.
setMemberTypes(List<String>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Union
 
setMergeManager(MergeManager) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: A reference to the last used merge manager.
setMergePolicy(int) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
setMessage(String) - Method in class org.eclipse.persistence.logging.SessionLogEntry
Set the entry's message.
setMethod - Variable in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
 
setMethod - Variable in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
Lazily initialized set method based on the set method name.
setMethod() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlVirtualAccessMethods
(Optional) Defines the name of the method used to store virtual properties.
setMethod(Method) - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Set the clone method.
setMethod(Method) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
setMethod(Method) - Method in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
INTERNAL: Sets the static method.
setMethodClass(Class<?>) - Method in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
PUBLIC: Sets the class to execute the static method on.
setMethodClassName(String) - Method in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
INTERNAL: Sets the class to execute the static method on.
setMethodName - Variable in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
 
setMethodName - Variable in class org.eclipse.persistence.internal.descriptors.VirtualAttributeMethodInfo
 
setMethodName - Variable in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
Name of the initial set method.
setMethodName() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlAccessMethods
 
setMethodName(String) - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Set the clone method name.
setMethodName(String) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
setMethodName(String) - Method in class org.eclipse.persistence.internal.descriptors.MethodBasedFieldTransformation
 
setMethodName(String) - Method in class org.eclipse.persistence.mappings.transformers.MethodBasedAttributeTransformer
 
setMethodName(String) - Method in class org.eclipse.persistence.mappings.transformers.MethodBasedFieldTransformer
 
setMethodName(String) - Method in class org.eclipse.persistence.queries.MethodBaseQueryRedirector
PUBLIC: Sets the name of the static method.
setMethodParameterTypeNotValid(CollectionMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
setMimeType(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
Force mapping to set default FixedMimeTypePolicy using the MimeType string as argument
setMimeType(String) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper.EncodedData
 
setMimeType(String) - Method in class org.eclipse.persistence.oxm.mappings.FixedMimeTypePolicy
Set the default mime type for this policy.
setMimeType(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
Force mapping to set default FixedMimeTypePolicy using the MimeType string as argument
setMimeType(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
Force mapping to set default FixedMimeTypePolicy using the MimeType string as argument
setMimeTypePolicy(MIME_TYPE_POLICY) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
Allow implementer to set the MimeTypePolicy class FixedMimeTypePolicy or AttributeMimeTypePolicy (dynamic)
setMimeTypePolicy(MIME_TYPE_POLICY) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
Allow implementer to set the MimeTypePolicy class FixedMimeTypePolicy or AttributeMimeTypePolicy (dynamic)
setMimeTypePolicy(MimeTypePolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
Allow implementer to set the MimeTypePolicy class FixedMimeTypePolicy or AttributeMimeTypePolicy (dynamic)
setMimeTypePolicy(MimeTypePolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
Allow implementer to set the MimeTypePolicy class FixedMimeTypePolicy or AttributeMimeTypePolicy (dynamic)
setMinConnections(Integer) - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPoolConfig
 
setMinExclusive(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setMinExclusive(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setMinInclusive(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setMinInclusive(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setMinLength(int) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setMinLength(int) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setMinLength(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setMinNumberOfConnections(int) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Set the minimum number of connections.
setMinOccurs(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Any
 
setMinOccurs(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setMinOccurs(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
setMinOccurs(String) - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
setMinOccurs(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.TypeDefParticle
 
setMinPoolSize(int) - Method in interface org.eclipse.persistence.sequencing.SequencingControl
PUBLIC: Sets a minimum number of connections in sequencing connection pool The set value is ignored if shouldUseSeparateConnection() returns false.
setMinScale(int) - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
setMixed(boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexContent
 
setMixed(boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setMixedContent(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyCollectionMapping
 
setMixedContent(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyObjectMapping
 
setMixedContent(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
Allows the user to indicate that this mapping should also allow for mixed content in addition to any of the elements in the choice.
setMixedContent(boolean) - Method in class org.eclipse.persistence.internal.oxm.SAXFragmentBuilder
 
setMixedContent(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
setMixedContent(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
setMixedContent(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
PUBLIC: Allows the user to indicate that this mapping should also allow for mixed content in addition to any of the elements in the choice.
setMixedContent(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
Allows the user to indicate that this mapping should also allow for mixed content in addition to any of the elements in the choice.
setMixedContent(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
PUBLIC: Allows the user to indicate that this mapping should also allow for mixed content in addition to any of the elements in the choice.
setMode(int) - Method in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
setModifyRow(AbstractRecord) - Method in class org.eclipse.persistence.internal.expressions.SQLModifyStatement
 
setModifyRow(AbstractRecord) - Method in class org.eclipse.persistence.queries.ModifyQuery
INTERNAL: Set the modify row
setModuleName(String) - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
INTERNAL;
setMulticastGroupAddress(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.discovery.DiscoveryConfig
 
setMulticastGroupAddress(String) - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
PUBLIC: Set the host address of the multicast group.
setMulticastPort(int) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.discovery.DiscoveryConfig
 
setMulticastPort(int) - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
PUBLIC: Set the multicast port used for discovery.
setMultipleTableForeignKeys(Map<DatabaseTable, Set<DatabaseTable>>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL:
setMultipleTableInsertOrder(List<DatabaseTable>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Sets the List of DatabaseTables in the order which INSERTS should take place.
setMultipleTableJoinExpression(Expression) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: This is normally generated for descriptors that have multiple tables.
setMultitenantPolicy(MultitenantPolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set a multitenant policy on the descriptor.
setMultitenantPolicy(MultitenantPolicy) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set the multitenant policy.
setMustDeleteReferenceObjectsOneByOne(Boolean) - Method in class org.eclipse.persistence.mappings.CollectionMapping
ADVANCED:: Return whether the reference objects must be deleted one by one, as opposed to with a single DELETE statement.
setName(String) - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
setName(String) - Method in class org.eclipse.persistence.descriptors.partitioning.PartitioningPolicy
PUBLIC: Set the name of the policy.
setName(String) - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Set the name of the ConnectionFactory within the JNDI Context.
setName(String) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Set the name.
setName(String) - Method in class org.eclipse.persistence.internal.codegen.CodeDefinition
 
setName(String) - Method in interface org.eclipse.persistence.internal.core.helper.CoreField
Set the unqualified name of the field.
setName(String) - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Set the name.
setName(String) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Set the unqualified name of the field.
setName(String) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Set the table name.
setName(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.AttributeGroup
 
setName(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setName(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
setName(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setName(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
setName(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
setName(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Set the name of the session.
setName(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPoolConfig
 
setName(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.WriteConnectionPoolConfig
 
setName(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.property.PropertyConfig
 
setName(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequenceConfig
 
setName(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
setName(String) - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
PUBLIC: Set the name for the query key.
setName(String) - Method in class org.eclipse.persistence.oxm.sequenced.Setting
Specify the name of the setting.
setName(String) - Method in class org.eclipse.persistence.oxm.XMLField
This has the same effect as calling the setXPath method
setName(String) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Set the query's name.
setName(String) - Method in class org.eclipse.persistence.sequencing.Sequence
 
setName(String) - Method in class org.eclipse.persistence.sessions.JNDIConnector
PUBLIC: Set the name of the DataSource within the JNDI Context.
setName(String) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set the name of the project.
setName(String) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Set the name of this pool.
setName(String) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Set the name of the session.
setName(String) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
PUBLIC: Set the name of the object.
setName(String) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Set the name of the field.
setName(String) - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
setName(String) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Set the name.
setName(String) - Method in class org.eclipse.persistence.tools.schemaframework.UniqueKeyConstraint
PUBLIC:
setName(String, String, String) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Set the unqualified name of the field.
setName(String, String, String) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Set the table name.
setName(String, String, String) - Method in class org.eclipse.persistence.oxm.XMLField
Override setName in superclass
setName(String, DatasourcePlatform) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Set the unqualified name of the field.
setName(Name) - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Set the name of the ConnectionFactory within the JNDI Context.
setNameField(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.TableSequenceConfig
 
setNameFieldName(String) - Method in class org.eclipse.persistence.sequencing.TableSequence
 
setNameForComparisons(String) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
INTERNAL: sets the string to be used for equality checking and determining the hashcode of this field.
setNames(List<String>) - Method in class org.eclipse.persistence.queries.ReportQuery
INTERNAL: Set the item names.
setNames(List<String>) - Method in class org.eclipse.persistence.queries.ReportQueryResult
 
setNamespace(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.AnyAttribute
 
setNamespace(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Import
 
setNameSpace(String) - Method in class org.eclipse.persistence.logging.SessionLogEntry
Set the name space of the log entry.
setNamespaceAware(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
If set to true, the reader will be aware of namespaces during marshal/unmarsal operations.
setNamespaceAware(boolean) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setNamespaceAware(boolean) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
setNamespaceDeclarationIncluded(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyAttributeMapping
 
setNamespaceDeclarationIncluded(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
setNamespacePrefixMapper(NAMESPACE_PREFIX_MAPPER) - Method in class org.eclipse.persistence.internal.oxm.Marshaller
NamespacePrefixMapper that can be used during marshal (instead of those set in the project meta data)
setNamespacePrefixMapper(NamespacePrefixMapper) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
NamespacePrefixMapper that can be used during marshal (instead of those set in the project meta data)
setNamespaceResolver(NAMESPACE_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Set the NamespaceResolver to associate with this descriptor
setNamespaceResolver(NAMESPACE_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Set the NamespaceResolver associated with this XMLField
setNamespaceResolver(NAMESPACE_RESOLVER) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
setNamespaceResolver(NAMESPACE_RESOLVER) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
setNamespaceResolver(NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Get the NamespaceResolver to be used during unmarshal Ignored unmarshalling XML.
setNamespaceResolver(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
setNamespaceResolver(NamespaceResolver) - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Set the XML namespace resolver.
setNamespaceResolver(NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.QNameInheritancePolicy
 
setNamespaceResolver(NamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setNamespaceResolver(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
setNamespaceResolver(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: Set the NamespaceResolver to associate with this descriptor
setNamespaceResolver(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.XMLField
Set the NamespaceResolver associated with this XMLField
setNamespaceResolverOnDescriptors() - Method in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
setNamespaces(Vector<Namespace>) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolver
INTERNAL: Set the namespaces on the namespace resolver based on the specified Vector of Namespace objects Used for deployment XML
setNamespaces(Vector<Namespace>) - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
 
setNamespaceSeparator(char) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
Sets namespace separator.
setNamespaceSeparator(char) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Set the namespace separator used during marshal operations.
setNamespaceSeparator(char) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Set the namespace separator used during unmarshal operations.
setNamespaceSeparator(char) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setNamespaceURI(String) - Method in class org.eclipse.persistence.internal.oxm.Namespace
 
setNamespaceURI(String) - Method in class org.eclipse.persistence.internal.oxm.Root
Sets the namespace uri associated with the QName of this XMLRoot.
setNamespaceURI(String) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setNamespaceURI(String) - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
setNamingIntoIndexed(boolean) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set whether named stored procedure parameters is allowed to transform into positional/index based.
setNamingServiceType(int) - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
ADVANCED: This function is not supported for naming service other than JNDI or TransportManager.JNDI_NAMING_SERVICE.
setNamingServiceType(int) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
ADVANCED: Set the type of naming service used to look up remote connections to other service instances.
setNativeSequencing(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setNativeSequencing(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
setNativeSQL(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setNeedToCloseComplex(boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
setNeedToOpenComplex(boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
setNestedArray(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Set nested array flag.
setNestedArray(boolean) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.Level
 
setNestedArray(boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.Level
 
setNestedArray(boolean) - Method in class org.eclipse.persistence.oxm.XMLField
Set nested array flag.
setNestedFieldTranslations(Map<String, Object[]>) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Set the hashtable that stores a field in the source table to a field name in a nested aggregate descriptor.
setNestedParticles(List<? extends NestedParticle>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
setNestedParticles(List<NestedParticle>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
setNestedType(DatabaseType) - Method in class org.eclipse.persistence.platform.database.oracle.jdbc.OracleArrayType
Set the database type of the value contained in the collection type.
setNestedType(DatabaseType) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLCollection
Set the database type of the value contained in the collection type.
setNestedTypeField(DatabaseField) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDatabaseField
ADVANCED: For ARRAY fields, this field's type represents the type contained in the ARRAY.
setNestLevel(int) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
setNestTime(long) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
setNewKey(Object) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
This method is used to set the value that this object will be stored under in its respected map collection
setNewObjectsCache(List) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
Set a new object cache
setNewObjectsCloneToOriginal(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The new objects stores any objects newly created during the unit of work.
setNewObjectsOriginalToClone(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The new objects stores any objects newly created during the unit of work.
setNewSize(int) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
setNewValue(Object) - Method in class org.eclipse.persistence.internal.sessions.DirectToFieldChangeRecord
ADVANCED: Sets the new value assigned during the change.
setNewValue(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.sessions.ObjectReferenceChangeRecord
This method sets the value of the change to be made.
setNewValue(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.sessions.ObjectReferenceChangeRecord
This method sets the value of the change to be made.
setNewValueInChangeRecord(Object, ObjectReferenceChangeRecord, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Set the newValue in the change record
setNext(LinkedCacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.LinkedCacheKey
 
setNextFragment(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setNextObject(Object) - Method in class org.eclipse.persistence.queries.ScrollableCursor
 
setNextThreadPartOfDeadLock(DeadLockComponent) - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
setNil(boolean) - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
setNil(boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.ExtendedContentHandler
This method can be used to track that the current element is nil
setNil(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
setNil(boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setNil(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setNil(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
setNil(boolean) - Method in class org.eclipse.persistence.internal.oxm.Root
Sets that this XMLRoot object is nil.
setNil(boolean) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
setNil(boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
setNil(boolean) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
setNil(boolean) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setNil(boolean) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
setNil(boolean) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
setNillable(boolean) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setNode(Node) - Method in class org.eclipse.persistence.internal.oxm.record.DOMInputSource
 
setNodeClass(Class<?>) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Set the node class for this operator.
setNodeOrderingPolicy(NodeOrderingPolicyConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DocumentPreservationPolicyConfig
 
setNodeOrderingPolicy(NodeOrderingPolicy) - Method in class org.eclipse.persistence.oxm.documentpreservation.DocumentPreservationPolicy
PUBLIC: Sets the NodeOrderingPolicy to be used by this DocumentPreservationPolicy when adding new elements into a cached XML Document.
setNodeValue(NodeValue) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
setNoNamespaceSchemaLocation(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setNoNamespaceSchemaLocation(String) - Method in class org.eclipse.persistence.internal.oxm.Root
Sets the no namespace schema location.
setNoNamespaceSchemaLocation(String) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Set the no namespace schema location on this XMLMarshaller
setNonDeferredCreateTime(int) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
ADVANCED: This setting is only available for CMP beans that are not being deferred.
setNonFetchJoinAttributeExpressions(List<Expression>) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return the attributes that must be joined, but not fetched, that is, do not trigger the value holder.
setNonPrimaryKeyMappings(List<DatabaseMapping>) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
The non primary key mappings are cached to improve performance.
setNonSelectFields(List) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Set the non select fields.
setNoOfThreadsAllowedToDoWriteLockManagerAcquireRequiredLocksInParallel(int) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setNoOfThreadsAllowedToObjectBuildInParallel(int) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setNormalizedWhereClause(Expression) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Set the where clause expression.
setNormalizingStringValues(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
Indicates that this mapping should normalize all string values before adding them to the collection on unmarshal.
setNormalizingStringValues(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
Indicates that this mapping should normalize all string values before setting them in the object on unmarshal.
setNormalizingStringValues(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
PUBLIC: Indicates that this mapping should normalize all string values before adding them to the collection on unmarshal.
setNormalizingStringValues(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
PUBLIC: Indicates that this mapping should normalize all string values before setting them in the object on unmarshal.
setNullable(boolean) - Method in class org.eclipse.persistence.internal.descriptors.QueryArgument
 
setNullable(boolean) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Used for generating DDL.
setNullableArguments(List<DatabaseField>) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the list of arguments to check for null.
setNullCapableNodeValue(XMLChoiceObjectMappingNodeValue) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceObjectMappingNodeValue
 
setNullCapableValue(NullCapableValue) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
setNullFromDatabaseField(DatabaseField, CallableStatement, String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setNullFromDatabaseField(DatabaseField, CallableStatement, String) - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
 
setNullFromDatabaseField(DatabaseField, PreparedStatement, int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setNullFromDatabaseField(DatabaseField, PreparedStatement, int) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
 
setNullFromDatabaseField(DatabaseField, PreparedStatement, int) - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
 
setNullPolicy(AbstractNullPolicy) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
Set the AbstractNullPolicy on the mapping
The default policy is NullPolicy.
setNullPolicy(AbstractNullPolicy) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
Set the AbstractNullPolicy on the mapping
The default policy is NullPolicy.
setNullPolicy(AbstractNullPolicy) - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
Set the AbstractNullPolicy on the mapping
The default policy is NullPolicy.
setNullPolicy(AbstractNullPolicy) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
 
setNullPolicy(AbstractNullPolicy) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
Set the AbstractNullPolicy on the mapping
The default policy is NullPolicy.
setNullPolicy(AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
Set the AbstractNullPolicy on the mapping
The default policy is NullPolicy.
setNullPolicy(AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
setNullPolicy(AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
Set the AbstractNullPolicy on the mapping
The default policy is NullPolicy.
setNullPolicy(AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
Set the AbstractNullPolicy on the mapping
The default policy is NullPolicy.
setNullPolicy(AbstractNullPolicy) - Method in interface org.eclipse.persistence.oxm.mappings.XMLNillableMapping
Set the AbstractNullPolicy on the mapping
The default policy is NullPolicy.
setNullRepresentedByEmptyNode(boolean) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
 
setNullRepresentedByXsiNil(boolean) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
 
setNullValue(Object) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
 
setNullValue(Object) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
Allow for the value used for null to be specified.
setNullValue(Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
PUBLIC: Allow for the value used for null to be specified.
setNullValue(Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
PUBLIC: Allow for the value used for null to be specified.
setNullValue(Object, CoreSession) - Method in interface org.eclipse.persistence.internal.oxm.NullCapableValue
INTERNAL: Set the null representation of the (object).
setNullValue(Object, CoreSession) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
setNullValue(Object, CoreSession) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
setNullValue(Object, CoreSession) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
setNullValue(Object, CoreSession) - Method in class org.eclipse.persistence.internal.oxm.XMLDirectMappingNodeValue
 
setNullValue(Object, CoreSession) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentMappingNodeValue
 
setNullValueInFields(boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: Set the validForUpdateCallCacheCheck attribute to true if the row does not contain nulls, false otherwise
setNullValueMarshalled(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
Set whether this mapping's value should be marshalled, in the case that it is equal to the default null value.
setNullValueMarshalled(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
PUBLIC: Set whether this mapping's value should be marshalled, in the case that it is equal to the default null value.
setNumberOfActiveUnitsOfWork(int) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
 
setNumberOfInstancesEffected(long) - Method in class org.eclipse.persistence.tools.profiler.Profile
 
setNumberOfNonPooledConnectionsUsed(int) - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Set the current number of connections being used that are not from a connection pool.
setNumberOfReaders(int) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Track the number of readers.
setNumberOfWritersWaiting(int) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Number of writers that want the lock.
setObject - Static variable in class org.eclipse.persistence.mappings.OneToOneMapping
 
setObject(Object) - Method in class org.eclipse.persistence.internal.helper.IndexedObject
 
setObject(Object) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
setObject(Object) - Method in class org.eclipse.persistence.internal.identitymaps.QueueableWeakCacheKey
 
setObject(Object) - Method in class org.eclipse.persistence.internal.identitymaps.SoftCacheKey
 
setObject(Object) - Method in class org.eclipse.persistence.internal.identitymaps.WeakCacheKey
 
setObject(Object) - Method in class org.eclipse.persistence.internal.indirection.TransformerBasedValueHolder
Set the receiver.
setObject(Object) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
setObject(Object) - Method in class org.eclipse.persistence.internal.oxm.Root
Sets the object associated with this XMLRoot.
setObject(Object) - Method in class org.eclipse.persistence.internal.sessions.remote.ObjectDescriptor
Set an object
setObject(Object) - Method in class org.eclipse.persistence.internal.sessions.remote.Transporter
Set the read object(s) from the server side.
setObject(Object) - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
setObject(Object) - Method in class org.eclipse.persistence.queries.DeleteObjectQuery
PUBLIC: (REQUIRED) Set the object required for modification.
setObject(Object) - Method in class org.eclipse.persistence.queries.DoesExistQuery
PUBLIC: Set the object.
setObject(Object) - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
PUBLIC: (REQUIRED) Set the object required for modification.
setObject(Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
setObject(T) - Method in class org.eclipse.persistence.oxm.JSONWithPadding
The Object to be marshalled
setObjectBuilder(OBJECT_BUILDER) - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
INTERNAL: Set the ObjectBuilder.
setObjectBuilder(ObjectBuilder) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the ObjectBuilder.
setObjectChangePolicy(ObjectChangePolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the ObjectChangePolicy for this descriptor.
setObjectChanges(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Sets the collection of ObjectChanges in the change Set.
setObjectChangeSet(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
INTERNAL: Return the object change set associated with this listener
setObjectChangeSet(ObjectChangeSet) - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
INTERNAL: Set the ObjectChangeSet representing the object to be written
setObjectChangeSetToUOWClone(Map<ObjectChangeSet, Object>) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: This method is used to insert a new collection into the UOWChangeSet.
setObjectClass(Class<?>) - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
PUBLIC: Set the class type of the object value.
setObjectClass(Class<?>) - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLListConverter
Set the Class of the elements of this collection's "sub-collection".
setObjectClassName(String) - Method in class org.eclipse.persistence.mappings.converters.TypeConversionConverter
INTERNAL: Set the name of the object type for the MW usage.
setObjectClassName(String) - Method in class org.eclipse.persistence.oxm.mappings.converters.XMLListConverter
Set the Class name of the elements of this collection's "sub-collection".
setObjectCollection(List<Object>) - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Set the internal object collection
setObjectDescriptors(Map<Object, ObjectDescriptor>) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
setObjectDescriptors(Map<Object, ObjectDescriptor>) - Method in class org.eclipse.persistence.internal.sessions.remote.Transporter
Get object to object descriptor
setObjectFetchGroup(Object, FetchGroup, AbstractSession) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Set fetch group into the object.
setObjects(List<Object>) - Method in class org.eclipse.persistence.queries.DeleteAllQuery
PUBLIC (REQUIRED): Set the objects to be deleted.
setObjectsAlreadyMerged(Map<AbstractSession, Map<Object, Object>>) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
setObjectsDeletedDuringCommit(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Set the objects that have been deleted.
setObjectsToDelete(List) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Deletion are cached until the end.
setObjectTypeName(String) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL: Set from JPA processing where we deal with strings only to avoid class loader conflicts.
setObjID(ObjID) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoveServerSideRemoteValueHolderCommand
INTERNAL: Use this method to set the remote ValueHolder ID
setODBCDataSourceName(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The data source name is required if connecting through ODBC (JDBC-ODBC, etc.).
setOldKey(Object) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
This method is used to set the value that this object was stored under in its respected map collection
setOldSize(int) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
setOldValue(Object) - Method in class org.eclipse.persistence.internal.sessions.AggregateChangeRecord
INTERNAL: Set the old value of the attribute represented by this ChangeRecord.
setOldValue(Object) - Method in class org.eclipse.persistence.internal.sessions.DirectToFieldChangeRecord
INTERNAL: Set the old value of the attribute represented by this ChangeRecord.
setOldValue(Object) - Method in class org.eclipse.persistence.internal.sessions.ObjectReferenceChangeRecord
Set the old value of the object reference.
setOldValue(Object) - Method in class org.eclipse.persistence.internal.sessions.TransformationMappingChangeRecord
INTERNAL: Set the old value of the attribute represented by this ChangeRecord.
setOnClause(Expression) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
setOnConnectionError(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.TransportManagerConfig
 
setOnEntity(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.EntityFetchGroup
Set this EntityFetchGroup on an entity implementing FetchGroupTracker.
setOneToOneMappingSettingsIn(RemoteValueHolder) - Method in class org.eclipse.persistence.internal.sessions.remote.ReplaceValueHoldersIterator
Set one-to-one mapping information.
setOnlyInstancesExpression(Expression) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: Sets the expression used to select instance of the class only.
setOperationStartTimes(Map<String, Long>) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
setOperationStartTimesByThread(Map<Integer, Map<String, Long>>) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
setOperationTimings(Map<String, Long>) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
setOperationTimings(Map<String, Long>) - Method in class org.eclipse.persistence.tools.profiler.Profile
 
setOperationTimingsByThread(Map<Integer, Map<String, Long>>) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
setOperator(ExpressionOperator) - Method in class org.eclipse.persistence.internal.expressions.ArgumentListFunctionExpression
INTERNAL: Set the operator for this expression.
setOperator(ExpressionOperator) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
setOperator(ExpressionOperator) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
setOptimisticLockingPolicy(OptimisticLockingPolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the OptimisticLockingPolicy.
setOptimisticLockingPolicyAndInitialWriteLockValue(OptimisticLockingPolicy, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: This method should ONLY be used to set the initial writeLock value for an ObjectChangeSet when it is first built.
setOptimizeDataConversion(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setOptionalArguments(List<DatabaseField>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
INTERNAL: Set the list of optional arguments.
setOrAddAttributeValue(UnmarshalRecord, Object, XPathFragment, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
setOrAddAttributeValue(UnmarshalRecord, Object, XPathFragment, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyObjectMappingNodeValue
 
setOrAddAttributeValue(UnmarshalRecord, Object, XPathFragment, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
setOrAddAttributeValue(UnmarshalRecord, Object, XPathFragment, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
setOrAddAttributeValue(UnmarshalRecord, Object, XPathFragment, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLRelationshipMappingNodeValue
 
setOrAddAttributeValue(UnmarshalRecord, Object, XPathFragment, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
setOrAddAttributeValue(UnmarshalRecord, Object, XPathFragment, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathObjectMappingNodeValue
 
setOrAddAttributeValueForKeepAsElement(SAXFragmentBuilder, Mapping, XMLConverterMapping, UnmarshalRecord, boolean, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLRelationshipMappingNodeValue
 
setOrderByExpressions(List<Expression>) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
setOrderByExpressions(List<Expression>) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Set the order expressions for the query.
setOrderByExpressions_(List<Expression>) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Set the list of orderBy expressions.
setOrderCorrectionType(OrderCorrectionType) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
 
setOrderCorrectionType(OrderCorrectionType) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Specifies what should be done if the list of values read from listOrserField is invalid (there should be no nulls, no duplicates, no "holes").
setOrderedAddObjectIndices(Map<ObjectChangeSet, Integer>) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Sets collection of ChangeSets (and their respective index) that they were added to the collection.
setOrderedAddObjects(List<ObjectChangeSet>) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Sets collection of ChangeSets that they were added to the collection.
setOrderedAttributes(List<Attribute>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setOrderedAttributes(List<Attribute>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
setOrderedChangeObjectList(List<OrderedChangeObject>) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
 
setOrderedDescriptors(List<ClassDescriptor>) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set the descriptors order.
setOrderedElements(List) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
setOrderedElements(List) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
setOrderedFields(Vector) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
INTERNAL: Set the field order.
setOrderedPartitions(List<String>) - Method in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
 
setOrderedRemoveObjects(Map<Integer, ObjectChangeSet>) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Sets collection of ChangeSets that they were removed from the collection.
setOrderHasBeenRepaired(boolean) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
 
setOrderHasBeenRepaired(boolean) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
 
setOrDetectDatasource(boolean) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Will set the platform from specified schema generation properties or by detecting it through the connection (if one is available).
setOriginalCollection(Object) - Method in class org.eclipse.persistence.internal.sessions.DeferrableChangeRecord
Used for change tracking when user sets entire collection.
setOriginalFieldsForJoin(Vector) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
setOriginalObject(Object) - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
INTERNAL: The source object represents the object the event is being raised on, some events also require a second object, for example the original object in a postClone.
setOuterJoinExpIndex(Integer) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
setOutput(Writer) - Method in class org.eclipse.persistence.internal.codegen.CodeGenerator
 
setOutputArgumentNames(Vector<String>) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
Set the output argument names.
setOutputArguments(Vector<DatabaseField>) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
The output arguments.
setOutputArguments(Vector<DatabaseField>) - Method in class org.eclipse.persistence.eis.interactions.IndexedInteraction
The output arguments in order of occurance in the record.
setOutputFileName(String) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Set the file name that the generate .java file will be output to.
setOutputFileName(String) - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Set the file name that the generate .java file will be output to.
setOutputPath(String) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Set the path that the generate .java file will be output to.
setOutputPath(String) - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Set the path that the generate .java file will be output to.
setOutputResultPath(String) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: The output result path defines the root key for the MappedRecord that the desired interaction result is nested into.
setOutputRootElementName(String) - Method in class org.eclipse.persistence.eis.interactions.XMLInteraction
PUBLIC: Set the root element name to use for the output DOM.
setOutputStream(OutputStream) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
Set the OutputStream that the object will be marshalled to.
setOutputWriter(Writer) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Set the writer the output to.
setOutputWriter(Writer) - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Set the writer the output to.
setOwner(ComplexType) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Content
 
setOwner(Content) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
setOwner(Element) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setOwner(Restrictable) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setOwner(TypeDefParticleOwner) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
setOwner(TypeDefParticleOwner) - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
setOwner(TypeDefParticleOwner) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
setOwner(TypeDefParticleOwner) - Method in class org.eclipse.persistence.internal.oxm.schema.model.TypeDefParticle
 
setOwner(ObjectChangeSet) - Method in class org.eclipse.persistence.internal.sessions.ChangeRecord
INTERNAL: This method is used to set the ObjectChangeSet that uses this Record in that Record.
setOwner(ServerSession) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
Set the ServerSession that owns this connection pool
setOwningMap(AbstractIdentityMap) - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
setOwningMap(IdentityMap) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
setOwningObject(Object) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
setOwningObject(Object) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
setOwningObject(Object) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
setOwningObject(Object) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL:
setOwningRecord(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.SAXFragmentBuilder
 
setPackageName(String) - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
setPackageName(String) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Set the package name of class to be generated.
setPackageName(String) - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Set the package name of class to be generated.
setPacketTimeToLive(int) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.discovery.DiscoveryConfig
 
setPacketTimeToLive(int) - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
PUBLIC: Set the number of hops the data packets of the session announcement will take before expiring.
setPageSize(int) - Method in class org.eclipse.persistence.queries.CursorPolicy
Set the number of elements to be read into a cursored stream when more elements are needed from the database.
setParameterBindings(List<Boolean>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The parameter binding determines if the specific parameter should be bound.
setParameterDelimiter(String) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the String char used to delimit an SQL parameter.
setParameters(Object[]) - Method in class org.eclipse.persistence.logging.SessionLogEntry
Set the array of parameters to the message.
setParameters(List) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The parameters are the values in order of occurrence in the SQL statement.
setParameters(List<List>) - Method in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
 
setParameterTypes(List<DatasourceCall.ParameterType>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The parameter types determine if the parameter is a modify, translation or literal type.
setParameterValueInDatabaseCall(Object, CallableStatement, String, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL Set the parameter in the JDBC statement with the given name.
setParameterValueInDatabaseCall(Object, CallableStatement, String, AbstractSession) - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
 
setParameterValueInDatabaseCall(Object, CallableStatement, String, AbstractSession) - Method in class org.eclipse.persistence.platform.database.DBasePlatform
INTERNAL: DBase does not support Time/Timestamp so we must map to strings.
setParameterValueInDatabaseCall(Object, CallableStatement, String, AbstractSession) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL Set the parameter in the JDBC statement with the given name.
setParameterValueInDatabaseCall(Object, CallableStatement, String, AbstractSession) - Method in class org.eclipse.persistence.platform.database.PostgreSQL10Platform
INTERNAL Set the parameter in the JDBC statement at the given index.
setParameterValueInDatabaseCall(Object, CallableStatement, String, AbstractSession) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
 
setParameterValueInDatabaseCall(Object, PreparedStatement, int, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL Set the parameter in the JDBC statement at the given index.
setParameterValueInDatabaseCall(Object, PreparedStatement, int, AbstractSession) - Method in class org.eclipse.persistence.platform.database.DBasePlatform
INTERNAL: DBase does not support Time/Timestamp so we must map to strings.
setParameterValueInDatabaseCall(Object, PreparedStatement, int, AbstractSession) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL Set the parameter in the JDBC statement at the given index.
setParameterValueInDatabaseCall(Object, PreparedStatement, int, AbstractSession) - Method in class org.eclipse.persistence.platform.database.PostgreSQL10Platform
INTERNAL Set the parameter in the JDBC statement at the given index.
setParameterValueInDatabaseCall(Object, PreparedStatement, int, AbstractSession) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
 
setParent(HierarchyNode) - Method in class org.eclipse.persistence.internal.codegen.HierarchyNode
 
setParent(XPathNode) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
setParent(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Set the parent.
setParent(Setting) - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
setParent(ServerSession) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Set the parent.
setParentClass(Class<?>) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Set the parent class.
setParentClassName(String) - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL: Set the parent class name, used by MW to avoid referencing the real class for deployment XML generation.
setParentClassName(String) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Set the parent class name, used by MW to avoid referencing the real class for deployment XML generation.
setParentClassName(String) - Method in class org.eclipse.persistence.services.ClassSummaryDetailBase
 
setParentDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL:
setParentInterfaceNames(List<String>) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
 
setParentInterfaces(List<Class<?>>) - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
Set the Vector to store parent interfaces.
setParentListener(AttributeChangeListener) - Method in class org.eclipse.persistence.internal.descriptors.changetracking.AggregateAttributeChangeListener
Used to control the parent listener;
setParentRecord(UnmarshalRecord) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setParentRecord(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setParentRecord(UnmarshalRecord) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
INTERNAL
setParentResultIndex(int) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
 
setParentSessionController(RemoteSessionController) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
INTERNAL: Sets the parent RemoteSessionController for this Remote UnitOfWork Used to retrieve Valueholders that were used on the client
setParentStatement(SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Set the parent statement if using subselects.
setPartialAttributeExpressions(List<Expression>) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Set the partial attributes to select.
setPartitionField(String) - Method in class org.eclipse.persistence.descriptors.partitioning.FieldPartitioningPolicy
PUBLIC: Set the database column or query parameter to partition queries by.
setPartitionField(DatabaseField) - Method in class org.eclipse.persistence.descriptors.partitioning.FieldPartitioningPolicy
PUBLIC: Set the database column or query parameter to partition queries by.
setPartitionId(int) - Method in interface org.eclipse.persistence.platform.database.partitioning.DataPartitioningCallback
 
setPartitioningCallback(DataPartitioningCallback) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Set callback.
setPartitioningCallback(DataPartitioningCallback) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set callback.
setPartitioningClasName(String) - Method in class org.eclipse.persistence.descriptors.partitioning.CustomPartitioningPolicy
 
setPartitioningPolicies(Map<String, PartitioningPolicy>) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set the map of partitioning policies, keyed by name.
setPartitioningPolicy(PartitioningPolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the descriptor's partitioning policy.
setPartitioningPolicy(PartitioningPolicy) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Set the session's partitioning policy.
setPartitioningPolicy(PartitioningPolicy) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Set the mapping's partitioning policy.
setPartitioningPolicy(PartitioningPolicy) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Set the query's partitioning policy.
setPartitioningPolicy(PartitioningPolicy) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Set the session's partitioning policy.
setPartitioningPolicyName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the name of the descriptor's partitioning policy.
setPartitioningPolicyName(String) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Set the name of the mapping's partitioning policy.
setPartitions(List<RangePartition>) - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartitioningPolicy
PUBLIC: Set the range partitions.
setPartitions(Map<Object, String>) - Method in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
PUBLIC: Set the value partitions.
setPartitionValueTypeName(String) - Method in class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
INTERNAL:
setPassword(String) - Method in class org.eclipse.persistence.eis.EISLogin
PUBLIC: Set the password.
setPassword(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
This method will always encrypt the password regardless.
setPassword(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
This method will always encrypt the password regardless.
setPassword(String) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
ADVANCED: Set the password used as the value to the SECURITY_CREDENTIALS key in the cached context properties.
setPassword(String) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
Set the password.
setPassword(String) - Method in interface org.eclipse.persistence.sessions.Login
PUBLIC: All logins must take a user name and password.
setPattern(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setPatterns(List<String>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setPendingMerge() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: set UoW lifecycle state variable to PENDING_MERGE
setPessimisticLockingPolicy(PessimisticLockingPolicy) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
PUBLIC: Configure bean pessimistic locking
setPessimisticLockTimeoutDefault(Integer) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Set the default pessimistic lock timeout value.
setPessimisticLockTimeoutUnitDefault(TimeUnit) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
 
setPingSQL(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for determining if an SQL exception was communication based.
setPingSQL(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setPingSQL(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink will attempt to test a connection if it encounters an exception on the connection when executing SQL.
setPlatform(Platform) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Set the database platform specific information.
setPlatform(Platform) - Method in interface org.eclipse.persistence.sessions.Login
INTERNAL: Set the database platform specific information.
setPlatformClass(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
setPlatformClassName(String) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Set the name of the Platform to be used.
setPlatformClassName(String, ClassLoader) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Set the name of the Platform to be created using the passed in class loader.
setPolicy(int) - Method in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
setPolicy(PartitioningPolicy) - Method in class org.eclipse.persistence.descriptors.partitioning.CustomPartitioningPolicy
 
setPolicy(CursorPolicy) - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Set the cursor policy.
setPool(ConnectionPool) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Set the associated connection pool this connection was obtained from.
setPool(ConnectionPool) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Set the associated connection pool this connection was obtained from.
setPoolName(String) - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Set the pool name or null if not part of a pool.
setPoolsConfig(PoolsConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.ServerSessionConfig
 
setPosition(int) - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Set the current position of the stream
setPossibleFailure(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
 
setPossiblyQualifiedName(String) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
Used to map the project xml.
setPossiblyQualifiedName(String, String, String) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
setPostBuildSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object that has just been built from the database.
setPostCloneSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object that has just been cloned into a unit of work.
setPostDeleteSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object that has just been deleted from the database.
setPostInsertSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object that has just been inserted into the database.
setPostMergeSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object that has just been merge from a unit of work.
setPostRefreshSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object that has just been refreshed from the database.
setPostUpdateSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object that has just been updated into the database.
setPostWriteSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object that has just been written to the database.
setPreallocationSize(int) - Method in class org.eclipse.persistence.sequencing.Sequence
 
setPreallocationSize(Integer) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequenceConfig
 
setPrecision(int) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Used to specify the precision for a decimal column when generating DDL.
setPredecessor(CommitOrderDependencyNode) - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
setPreDeleteComplete(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
setPreDeleteSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object that is going to be deleted from the database.
setPredicate(XPathPredicate) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setPrefetchCacheKeys(boolean) - Method in class org.eclipse.persistence.descriptors.CachePolicy
 
setPrefetchedCacheKeys(Map<Object, CacheKey>) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
 
setPrefix(String) - Method in class org.eclipse.persistence.internal.oxm.Namespace
 
setPrefix(String) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setPrefix(String) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
 
setPreInsertSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object that is going to be inserted into the database.
setPrePersistSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object when that object has the create operation applied to it.
setPreRemoveSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object when that object has the remove operation applied to it.
setPreserveWhitespaceForMixedContent(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyCollectionMapping
 
setPreserveWhitespaceForMixedContent(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
setPreUpdateSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object that is going to be updated into the database.
setPrevCustomizer(ConnectionCustomizer) - Method in class org.eclipse.persistence.internal.databaseaccess.ConnectionCustomizer
INTERNAL:
setPrevious(LinkedCacheKey) - Method in class org.eclipse.persistence.internal.identitymaps.LinkedCacheKey
 
setPreviousCall(DatabaseCall) - Method in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
 
setPreviousObject(Object) - Method in class org.eclipse.persistence.queries.ScrollableCursor
 
setPreWriteSelector(String) - Method in class org.eclipse.persistence.descriptors.DescriptorEventManager
PUBLIC: A method can be registered to be called on a object that is going to be written to the database.
setPrimaryKey(boolean) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Used to specify whether the column should be included in primary key on the database table.
setPrimaryKey(Object) - Method in class org.eclipse.persistence.internal.oxm.Reference
Set the primary key value required to lookup the reference class in the cache.
setPrimaryKey(Object) - Method in class org.eclipse.persistence.queries.DoesExistQuery
INTERNAL: Set the primaryKey.
setPrimaryKey(Object) - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
INTERNAL: Set the primary key for the query.
setPrimaryKey(Object[]) - Method in class org.eclipse.persistence.internal.identitymaps.CacheId
 
setPrimaryKeyClassifications(List<Class<?>>) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Set primary key classifications.
setPrimaryKeyExpression(Expression) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
The primary key expression is cached to improve performance.
setPrimaryKeyFieldName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Specify the primary key field of the descriptors table.
setPrimaryKeyFieldNames(Vector) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: User can specify a vector of all the primary key field names if primary key is composite.
setPrimaryKeyFieldNames(LIST) - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
PUBLIC: User can specify a vector of all the primary key field names if primary key is composite.
setPrimaryKeyFields(String...) - Method in class org.eclipse.persistence.dynamic.DynamicTypeBuilder
Set the PK field names on the underlying descriptor ensuring no duplicate names are added.
setPrimaryKeyFields(List<FIELD>) - Method in class org.eclipse.persistence.core.descriptors.CoreDescriptor
PUBLIC: User can specify a vector of all the primary key field names if primary key is composite.
setPrimaryKeyFields(List<DatabaseField>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the primary key fields
setPrimaryKeyFields(List<DatabaseField>) - Method in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
setPrimaryKeyFields(List<DatabaseField>) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
setPrimaryKeyFieldsForAutoJoin(Collection) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
setPrimaryKeyFieldsForAutoJoin(Collection) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
setPrimaryKeyIdValidations(List<IdValidation>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Return what types are allowed in each primary key field (id).
setPrimaryKeyMappings(List<DatabaseMapping>) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
The primary key mappings are cached to improve performance.
setPrimaryProject(ProjectConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.DatabaseSessionConfig
 
setPrintInnerJoinInWhereClause(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
PUBLIC: Changes the way that inner joins are printed in generated SQL for the database.
setPrintInnerJoinInWhereClause(boolean) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Set a flag that indicates whether the query will change the way that inner joins are printed in generated SQL for the database.
setPrintOuterJoinInWhereClause(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
PUBLIC: Changes the way that OuterJoins are done on the database.
setPrivateOwnedCriteria(Expression) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: Private owned criteria is used to verify the deletion of the target.
setPrivateOwnedCriteria(Expression) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Private owned criteria is used to verify the deletion of the target.
setProcedureArgumentNames(List<String>) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
INTERNAL: The if the names are provide the order is not required to match the call def.
setProcedureName(String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: (REQUIRED) Set the name of the store procedure on the database.
setProcedures(List<StoredProcedureDefinition>) - Method in class org.eclipse.persistence.tools.schemaframework.PackageDefinition
Packages can contain sets of procedures.
setProcessContents(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.AnyAttribute
 
setProduct(String) - Static method in class org.eclipse.persistence.Version
 
setProfiler(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
setProfiler(SessionProfiler) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Set the profiler for the session.
setProfiler(SessionProfiler) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Set the profiler for the session.
setProfiler(SessionProfiler) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Set the profiler for the session.
setProfiles(Vector<Profile>) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
setProfileTime(long) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
setProfileTime(long) - Method in class org.eclipse.persistence.tools.profiler.Profile
 
setProfileWeight(int) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Set the DMS sensor weight
setProfileWeight(int) - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to change DMS sensor weight.
setProfileWeight(int) - Method in interface org.eclipse.persistence.sessions.SessionProfiler
INTERNAL: Set DMS sensor weight(DMS)
setProfileWeight(int) - Method in class org.eclipse.persistence.sessions.SessionProfilerAdapter
INTERNAL: Set DMS sensor weight(DMS)
setProfileWeight(int) - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
Set the level of profiling.
setProfilingType(String) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to select the type of profiling.
setProfilingType(String) - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to select the type of profiling.
setProject(Project) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Set the project, the project holds configuration information including the descriptors.
setProject(Project) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Set the project to generate from.
setProjectString(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.project.ProjectConfig
 
setProperties(Hashtable) - Method in class org.eclipse.persistence.sessions.SessionEvent
INTERNAL: Additional properties may be added to the event.
setProperties(Map) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the user defined properties.
setProperties(Map) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: Set the user defined properties.
setProperties(Map) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
INTERNAL: Allow user defined properties.
setProperties(Map) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Allow user defined properties.
setProperties(Map<Object, Object>) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Property support used by mappings.
setProperties(Map<String, Object>) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
Set the adapter specific properties.
setProperties(Map<String, Object>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Set the user defined properties by shallow copying the propertiesMap.
setProperties(Properties) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: The properties are additional, driver-specific, connection information to be passed to the JDBC driver.
setProperties(Properties) - Method in interface org.eclipse.persistence.sessions.Login
PUBLIC: The properties are additional, driver-specific, connection information to be passed to the JDBC driver.
setProperty(Object, Object) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: Allow user defined properties.
setProperty(Object, Object) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Property support used by mappings to store temporary stuff.
setProperty(Object, Object) - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: Use this method to set custom properties on the Connection Policy.
setProperty(String, Object) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the user defined property.
setProperty(String, Object) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
PUBLIC: Set the adapter specific property.
setProperty(String, Object) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
setProperty(String, Object) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
setProperty(String, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Allow for user defined properties.
setProperty(String, Object) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Some JDBC drivers require additional, driver-specific, properties.
setProperty(String, Object) - Method in interface org.eclipse.persistence.sessions.Login
PUBLIC: Some JDBC drivers require additional, driver-specific, properties.
setProperty(String, Object) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Allow for user defined properties.
setProperty(String, Object) - Method in class org.eclipse.persistence.sessions.SessionEvent
INTERNAL: Additional properties may be added to the event.
setProperty(String, String) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
setPropertyConfigs(Vector<PropertyConfig>) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
setPropertyConfigs(Vector<PropertyConfig>) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
 
setProtectedForeignKeys(AbstractRecord) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
setProtectedForeignKeys(AbstractRecord) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
setPublisher(TopicPublisher) - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: set the TopicPublisher to be used when this RemoteConnection executes a command.
setQualifier(String) - Method in class org.eclipse.persistence.sequencing.DefaultSequence
INTERNAL: Ignored, getDefaultSequence().getQualifier() used instead.
setQualifier(String) - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL:
setQualifier(String) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
PUBLIC: Most major databases support a creator name scope.
setQueries(List<DatabaseQuery>) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL:
setQueries(Map) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: set the pre-defined queries for the descriptor.
setQueries(Map<String, List<DatabaseQuery>>) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Set the named queries.
setQuery(DatabaseQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
INTERNAL: The query causing the event.
setQuery(DatabaseQuery) - Method in exception org.eclipse.persistence.exceptions.DatabaseException
PUBLIC: This method set the databaseQuery.
setQuery(DatabaseQuery) - Method in exception org.eclipse.persistence.exceptions.QueryException
INTERNAL: Set the query in which the problem was detected.
setQuery(DatabaseQuery) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Back reference to query, unfortunately required for events.
setQuery(DatabaseQuery) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Set the query that uses this mechanism.
setQuery(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.remote.Transporter
Set the query associated with this transporter
setQuery(DatabaseQuery) - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: Back reference to query, unfortunately required for events.
setQuery(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.SessionEvent
INTERNAL: Some events may have a query associated with them (pre/postExecuteQuery).
setQuery(ObjectLevelModifyQuery) - Method in exception org.eclipse.persistence.exceptions.OptimisticLockException
INTERNAL: Set the query in which the problem was detected.
setQuery(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Set the query.
setQuery(ObjectLevelReadQuery) - Method in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
INTERNAL: Set the query.
setQuery(ReadQuery) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Query held as it may store properties needed to generate the SQL
setQuery(ReadQuery) - Method in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
Set the query.
setQuery(ReadQuery) - Method in class org.eclipse.persistence.queries.CursorPolicy
INTERNAL: Set the query.
setQueryArguments(AbstractRecord) - Method in exception org.eclipse.persistence.exceptions.DatabaseException
PUBLIC: Set the query arguments used in the original query when exception is thrown
setQueryArguments(AbstractRecord) - Method in exception org.eclipse.persistence.exceptions.QueryException
INTERNAL: Set the query argements used in the original query when exception is thrown
setQueryBuilder(JPAQueryBuilder) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL Set the query builder used to parser JPQL.
setQueryByExamplePolicy(QueryByExamplePolicy) - Method in class org.eclipse.persistence.internal.queries.QueryByExampleMechanism
PUBLIC: The QueryByExamplePolicy, is a useful to customize the query when Query By Example is used.
setQueryByExamplePolicy(QueryByExamplePolicy) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: The QueryByExamplePolicy, is a useful to customize the query when Query By Example is used.
setQueryCacheForceDeferredLocks(boolean) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Set property to Force all queries and relationships to use deferred lock strategy during object building and L2 cache population.
setQueryClass(Class<?>) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Set the class which this node represents.
setQueryClass(Class<?>) - Method in class org.eclipse.persistence.tools.profiler.Profile
 
setQueryClassAndDescriptor(Class<?>, ClassDescriptor) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Set the class and descriptor which this node represents.
setQueryId(long) - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: This method is used to set the current system time in millis that this query is being executed at.
setQuerykeyExpression(QueryKeyExpression) - Method in class org.eclipse.persistence.internal.expressions.NestedTable
 
setQueryKeyFields(Map<DatabaseField, DatabaseField>) - Method in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
INTERNAL:
setQueryKeyFields(Map<DatabaseField, DatabaseField>, boolean) - Method in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
INTERNAL:
setQueryKeys(Map<String, QueryKey>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the query keys.
setQueryManager(DescriptorQueryManager) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the query manager.
setQueryManager(DescriptorQueryManager) - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: Avoid SDK initialization.
setQueryMechanism(DatabaseQueryMechanism) - Method in class org.eclipse.persistence.queries.DatabaseQuery
Set the query mechanism for the query.
setQueryResults(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: Set the cached results of the query.
setQueryResultsCachePolicy(QueryResultsCachePolicy) - Method in class org.eclipse.persistence.queries.ReadQuery
Set the QueryResultsCachePolicy.
setQueryRetryAttemptCount(int) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the number of attempts EclipseLink should make to re-connect to a database and re-execute a query after a query has failed because of a communication issue.
setQueryRetryAttemptCount(Integer) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setQueryString(String) - Method in class org.eclipse.persistence.eis.interactions.QueryStringInteraction
PUBLIC: Set the query string.
setQueryString(String) - Method in class org.eclipse.persistence.eis.interactions.XQueryInteraction
INTERNAL: Set the query string.
setQueryString(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Set the query string (SQL) of the call.
setQueryString(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Set the query string of the call.
setQueryString(String) - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
Set the query string of the call.
setQueryTimeout(int) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
PUBLIC: Set the number of seconds that queries will wait for their Statement to execute.
setQueryTimeout(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
set query timeout limit to the JDBC Statement
setQueryTimeout(int) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Set the number of seconds the driver will wait for a Statement to execute to the given number of seconds.
setQueryTimeoutDefault(int) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Set the default query timeout for this session.
setQueryTimeoutDefault(int) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Set the default query timeout for this session.
setQueryTimeoutUnit(TimeUnit) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
setQueryTimeoutUnit(TimeUnit) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
set query timeout limit unit to the JDBC Statement
setQueryTimeoutUnit(TimeUnit) - Method in class org.eclipse.persistence.queries.DatabaseQuery
 
setQueryTimeoutUnitDefault(TimeUnit) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
 
setQueryTimeoutUnitDefault(TimeUnit) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Set the default query timeout units for this session.
setQueueNode(LinkedNode) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTENRAL: Used to set the node that this merge manager is stored in, within the WriteLocksManager write lockers queue
setReadAllCall(Call) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's read all call.
setReadAllQuery(ReadAllQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's read all query.
setReadAllSQLString(String) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's read SQL string.
setReadAllSubclassesView(DatabaseTable) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: The view can be used to optimize/customize the query for all subclasses where they have multiple tables.
setReadAllSubclassesViewName(String) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: The view can be used to optimize/customize the query for all subclasses where they have multiple tables.
setReadConnectionPool(Login) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Creates and sets the new read connection pool.
setReadConnectionPool(ConnectionPool) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Sets the read connection pool directly.
setReadConnectionPool(ConnectionPool) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Set the read connection pool.
setReadConnectionPoolConfig(ReadConnectionPoolConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.PoolsConfig
 
setReadObjectCall(Call) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's read object call.
setReadObjectQuery(ReadObjectQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's read query.
setReadObjectSQLString(String) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's read SQL string.
setReadOnly() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the descriptor to be read-only.
setReadOnlyClasses(List<Class<?>>) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Gives a new set of read-only classes to the receiver.
setReadOnlyMappingsByField(Map<DatabaseField, List<DatabaseMapping>>) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: All the read-only mappings and their respective field associations are cached for performance improvement.
setReadTime(long) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
INTERNAL: Set the read time of this cache key
setReadTime(long) - Method in class org.eclipse.persistence.internal.sessions.remote.ObjectDescriptor
Set the read time
setReadTime(long) - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
setRealAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Set the value of the appropriate attribute of target to attributeValue.
setRealAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Set the value of the appropriate attribute of target to attributeValue.
setRealAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Set the value of the appropriate attribute of target to attributeValue.
setRealAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Set the "real" value of the attribute to attributeValue.
setRealAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Set the value of the appropriate attribute of target to attributeValue.
setRealAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
Set the value of the appropriate attribute of target to attributeValue.
setRealAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Set the value of the attribute mapped by this mapping, placing it inside a value holder if necessary.
setRealAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Set the value of the attribute mapped by this mapping, placing it inside a value holder if necessary.
setRealAttributeValueInObject(Object, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Set the value of the attribute mapped by this mapping, placing it inside a value holder if necessary.
setRealAttributeValueInObject(Object, Object) - Method in interface org.eclipse.persistence.mappings.structures.ArrayCollectionMapping
Set the attribute value for the specified object, wrapping it in a value holder if necessary.
setRealAttributeValueInObject(Object, Object, boolean) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Same functionality as setRealAttributeValueInObject(Object target, Object attributeValue) but allows overridden behavior for IndirectionPolicies that track changes
setRealAttributeValueInObject(Object, Object, boolean) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
Set the value of the appropriate attribute of target to attributeValue.
setRealAttributeValueInObject(Object, Object, boolean) - Method in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
Set the value of the appropriate attribute of target to attributeValue.
setRecord(Record) - Method in class org.eclipse.persistence.eis.EISDOMRecord
Set the JCA adapter record.
setRecord(Map) - Method in class org.eclipse.persistence.eis.EISMappedRecord
Set the wrapped record.
setRecord(DataRecord) - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
INTERNAL: Optionally a database row may be provided on some events, (such as aboutToUpdate).
setRecord(DataRecord) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
setRecord(DataRecord) - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
setRecordConverter(RecordConverter) - Method in class org.eclipse.persistence.eis.EISPlatform
Set the record converter.
setRecordFactory(RecordFactory) - Method in class org.eclipse.persistence.eis.EISAccessor
Set the RecordFactory.
setRecordName(String) - Method in class org.eclipse.persistence.eis.EISDOMRecord
Forward to the record.
setRecordShortDescription(String) - Method in class org.eclipse.persistence.eis.EISDOMRecord
Forward to the record.
setRedirector(QueryRedirector) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Set the query redirector.
setReduceAnyArrays(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Property to determine if size 1 any collections should be treated as collections Ignored marshalling XML.
setRef(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.AttributeGroup
 
setRef(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
setRef(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
setRefContentHandler(ContentHandler) - Method in class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
setReferenceCacheNode(LinkedNode) - Method in class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap.ReferenceCacheKey
 
setReferenceClass(Class<?>) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
setReferenceClass(Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
This is a reference class whose instances this mapping will store in the domain objects.
setReferenceClass(Class<?>) - Method in class org.eclipse.persistence.mappings.AggregateMapping
PUBLIC: This is a reference class whose instances this mapping will store in the domain objects.
setReferenceClass(Class<?>) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: This cannot be used with direct collection mappings.
setReferenceClass(Class<?>) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Set the referenced class.
setReferenceClass(Class<?>) - Method in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
PUBLIC: Set the reference class of the relationship.
setReferenceClass(Class<?>) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
PUBLIC: This is a reference class whose instances this mapping will store in the domain objects.
setReferenceClass(Class<?>) - Method in class org.eclipse.persistence.queries.ModifyAllQuery
PUBLIC: Set the reference class this query.
setReferenceClass(Class<?>) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
REQUIRED: Set the reference class for the query.
setReferenceClass(Class<?>) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
REQUIRED: Set the reference class for the query.
setReferenceClassName(String) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy.Info
 
setReferenceClassName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
 
setReferenceClassName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.InverseReferenceMapping
 
setReferenceClassName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ObjectReferenceMapping
 
setReferenceClassName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.VariableXPathObjectMapping
 
setReferenceClassName(String) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Used by MW.
setReferenceClassName(String) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
setReferenceClassName(String) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Used by MW.
setReferenceClassName(String) - Method in class org.eclipse.persistence.mappings.querykeys.ForeignReferenceQueryKey
PUBLIC: Set the reference class name for this relationship This is used when projects are built without using classes
setReferenceClassName(String) - Method in class org.eclipse.persistence.queries.ModifyAllQuery
INTERNAL: Set the class name of the reference class of this query.
setReferenceClassName(String) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Set the reference class for the query.
setReferenceClassName(String) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Set the reference class for the query.
setReferenceDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Set the referenceDescriptor.
setReferenceDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Set the referenceDescriptor.
setReferenceDescriptor(ClassDescriptor) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Set the referenceDescriptor.
setReferenceKeyFieldName(String) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Set the name of the reference key field.
setReferenceKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Set the reference key field names associated with the mapping.
setReferenceKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Set the reference fields.
setReferenceResolver(ReferenceResolver) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setReferenceResolver(ReferenceResolver) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
INTERNAL: Set the ReferenceResolver that will be leveraged by key based mappings.
setReferenceResolver(ReferenceResolver) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Set the ReferenceResolver that will be leveraged by key based mappings.
setReferenceResolver(ReferenceResolver) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setReferenceTable(DatabaseTable) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Set the reference table.
setReferenceTableName(String) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Set the reference table name.
setRefreshCascadePolicy(Integer) - Method in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
INTERNAL:
setRefreshMetadataListener(MetadataRefreshListener) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
 
setRefreshOnFetchGroupToObject(Object, boolean) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Set if the tracked object is fetched from executing a query with or without refresh.
setRegisteredObjects(Map<Class<?>, Map<String, Object>>) - Method in class org.eclipse.persistence.tools.schemaframework.PopulationManager
Set the registered objects.
setRelationshipPartner(DatabaseMapping) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Sets the relationshipPartner mapping for this bi-directional mapping.
setRelationshipPartnerAttributeName(String) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Use this method to specify the relationship partner attribute name of a bidirectional Mapping.
setRelationshipSourceObject(Object) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
setRelationTable(DatabaseTable) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Set the relational table.
setRelationTable(DatabaseTable) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Set the relational table.
setRelationTable(DatabaseTable) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Set the relational table.
setRelationTableLockingClause(ObjectLevelReadQuery, ObjectBuildingQuery) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Return relation table locking clause.
setRelationTableMechanism(RelationTableMechanism) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Set RelationTableMechanism into the mapping, that allows to configure the mapping to use relation table (just like ManyToManyMapping).
setRelationTableName(String) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Set the name of the relational table.
setRelationTableName(String) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Set the name of the relational table.
setRemoteCommandManager(RemoteCommandManager) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
INTERNAL:
setRemoteCommandManagerConfig(RemoteCommandManagerConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
setRemoteConnection(RemoteConnection) - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
INTERNAL: Set the remote connection.
setRemoteContextProperties(Hashtable) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
ADVANCED: Set the cached properties that will be used to create the initial context when doing remote JNDI lookups.
setRemoteCursors(Map<ObjID, Cursor>) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
set the pre-remoted cursors
setRemoteIdentityMapClass(Class<? extends IdentityMap>) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Set the class of identity map to be used by this descriptor.
setRemoteIdentityMapClass(Class<? extends IdentityMap>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be used by this descriptor.
setRemoteIdentityMapSize(int) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Set the size of the identity map to be used by this descriptor.
setRemoteIdentityMapSize(int) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the size of the identity map to be used by this descriptor.
setRemoteSessionController(RMIRemoteSessionController) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIConnection
INTERNAL: Set remote session controller
setRemoteUnitOfWork(UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
setRemoteValueHolders(Map<ObjID, ValueHolderInterface>) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
set the pre-serialized remote value holders
setRemovedObjects(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: The removed objects stores any newly registered objects removed during the nested unit of work.
setRemoveObjectList(Map<ObjectChangeSet, ObjectChangeSet>) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
Sets the removed objects list.
setRemoveObjects(HashMap) - Method in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
Sets the removed items list.
setReplicateWrites(boolean) - Method in class org.eclipse.persistence.descriptors.partitioning.RoundRobinPartitioningPolicy
PUBLIC: Set if write queries should be replicated.
setReplicateWrites(boolean) - Method in class org.eclipse.persistence.descriptors.partitioning.UnionPartitioningPolicy
PUBLIC: Set if write queries should be replicated.
setReportItems(List<ReportItem>) - Method in class org.eclipse.persistence.queries.ConstructorReportItem
 
setRequired(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Set whether this XMLField represents a "required" XML element or attribute ([minOccurs="1"] for elements, [use="required"] for attributes).
setRequired(boolean) - Method in class org.eclipse.persistence.oxm.XMLField
Set whether this XMLField represents a "required" XML element or attribute ([minOccurs="1"] for elements, [use="required"] for attributes).
setRequiresAliases(boolean) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
setRequiresAutoCommit(boolean) - Method in class org.eclipse.persistence.eis.EISPlatform
Set if this platform requires auto commit of the local transaction for interactions outside of an interaction.
setRequiresDeferredLocks(boolean) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: When reading across relationships, queries may be set to acquire deferred locks This is used to ensure any Eagerly fetched object that is the target of a relationship with an object the acquires deferred locks behaves the same as its owner
setRequiresDistinct(boolean) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
If a distinct has been set the DISTINCT clause will be printed.
setRequiresTransientWeavedFields(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Set this flag if this mappings associated weaved field requires a transient setting to avoid metadata processing.
setResource(String) - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
 
setResourceName(String) - Method in exception org.eclipse.persistence.exceptions.PersistenceUnitLoadingException
 
setResourceName(String) - Method in exception org.eclipse.persistence.exceptions.StaticWeaveException
 
setResourceName(String) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: Set the resource name we are trying to load.
setRestriction(Restriction) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Content
 
setRestriction(Restriction) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
setResult(int, String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredFunctionCall
PUBLIC: Define the ObjectRelationalDatabaseField to be substituted for the function return.
setResult(int, String, Class<?>, DatabaseField) - Method in class org.eclipse.persistence.queries.StoredFunctionCall
PUBLIC: Define the ObjectRelationalDatabaseField to be substituted for the function return.
setResult(Object) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setResult(Object) - Method in class org.eclipse.persistence.internal.expressions.ExpressionIterator
 
setResult(Object) - Method in class org.eclipse.persistence.queries.ComplexQueryResult
INTERNAL: Set the result of the query.
setResult(Object) - Method in class org.eclipse.persistence.sessions.SessionEvent
INTERNAL: Some events may have a result associated with them (pre/postExecuteQuery).
setResult(String) - Method in class org.eclipse.persistence.queries.StoredFunctionCall
PUBLIC: Define the field name to be substitute for the function return.
setResult(String, int) - Method in class org.eclipse.persistence.queries.StoredFunctionCall
PUBLIC: Define the field name to be substitute for the function return.
setResult(String, int, String) - Method in class org.eclipse.persistence.queries.StoredFunctionCall
PUBLIC: Define the field name to be substitute for the function return.
setResult(String, Class<?>) - Method in class org.eclipse.persistence.queries.StoredFunctionCall
PUBLIC: Define the field name to be substitute for the function return.
setResult(ResultSet) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
The result set is stored for the return value of cursor selects.
setResult(Result) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
Set the Result for this Schema.
setResult(DatabaseType) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredFunctionCall
PUBLIC: Define the return type of the function.
setResult(DatabaseType, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredFunctionCall
PUBLIC: Define the return type of the function.
setResult(DatabaseType, int, int) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredFunctionCall
PUBLIC: Define the return type of the function.
setResultAlwaysXMLRoot(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
 
setResultAlwaysXMLRoot(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
setResultAlwaysXMLRoot(boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
setResultAlwaysXMLRoot(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
setResultAlwaysXMLRoot(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
setResultAlwaysXMLRoot(boolean) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
setResultCursor() - Method in class org.eclipse.persistence.queries.StoredFunctionCall
PUBLIC: Define to return cursor as result.
setResultIndex(int) - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
setResults(List<Object>) - Method in class org.eclipse.persistence.queries.ReportQueryResult
INTERNAL: Set the results.
setResultSet(ResultSet) - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Set the result set (cursor)
setResultSetConcurrency(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
setResultSetConcurrency(int) - Method in class org.eclipse.persistence.queries.ScrollableCursorPolicy
PUBLIC: The ResultSetConcurrency specifies if the resultset is updatable.
setResultSetFetchSize(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
setResultSetType(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
setResultSetType(int) - Method in class org.eclipse.persistence.queries.ScrollableCursorPolicy
PUBLIC: The ResultSetType specifies if the resultset is sensitive to changes made by others.
setResultType(int) - Method in class org.eclipse.persistence.queries.DataReadQuery
Set the result type to be configured, MAP, ARRAY, VALUE, ATTRIBUTE (MAP is the default, DatabaseRecord).
setResultType(Class<?>) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
 
setResultType(Class<?>) - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
setResultType(String) - Method in class org.eclipse.persistence.queries.DataReadQuery
Set the result type to be configured, Map, Array, Value, Attribute (Map is the default, DatabaseRecord).
setResumeUnitOfWorkOnTransactionCompletion(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Set if this UnitofWork should be resumed after the end of the transaction Used when UnitOfWork is synchronized with external transaction control
setReturnFields(Vector) - Method in class org.eclipse.persistence.internal.expressions.SQLModifyStatement
 
setReturningPolicy(ReturningPolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Sets the returning policy.
setReturnMultipleResultSetCollections(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Set if the call returns multiple result sets.
setReturnsResultSet(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
PUBLIC: Use this method to tell EclipseLink that the stored procedure will be returning a JDBC ResultSet
setReturnsResultSet(boolean) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Some database support stored procedures returning result sets.
setReturnType(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The return type is one of, NoReturn, ReturnOneRow or ReturnManyRows.
setReturnType(int) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Set the return type.
setReturnType(Class<?>) - Method in class org.eclipse.persistence.tools.schemaframework.StoredFunctionDefinition
Prints return for stored function
setReturnType(String) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
setReturnTypeClass(Class<?>) - Method in class org.eclipse.persistence.internal.codegen.ReflectiveMethodDefinition
 
setReuseContainer(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.XMLContainerMapping
Specify if a pre-existing container on the field/property should be used.
setReuseContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
Specify whether the original container on the object should be used if present.
setReuseContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
Specify whether the original container on the object should be used if present.
setReuseContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
Specify whether the original container on the object should be used if present.
setReuseContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
Specify whether the original container on the object should be used if present.
setReuseContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
Specify whether the original container on the object should be used if present.
setReuseContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
Specify whether the original container on the object should be used if present.
setReuseContainer(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
Specify whether the original container on the object should be used if present.
setRMIRegistryNamingServiceConfig(RMIRegistryNamingServiceConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.RMITransportManagerConfig
 
setRootElementName(String) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setRootElementName(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setRootElementName(String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setRootElementNamespaceUri(String) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setRootElementNamespaceUri(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setRootElementNamespaceUri(String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setRootEntity(FetchGroupTracker) - Method in class org.eclipse.persistence.queries.FetchGroup
INTERNAL:
setRootGroup(ATTRIBUTE_GROUP) - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
setRow(AbstractRecord) - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Set the row.
setRow(AbstractRecord) - Method in class org.eclipse.persistence.internal.sessions.TransformationMappingChangeRecord
This method is used to add a changed value to the changeRecord.
setRuntimeServicesMBean(MBeanRuntimeServicesMBean) - Method in class org.eclipse.persistence.platform.server.JMXServerPlatformBase
INTERNAL: Set the cached server specific services MBean
setScale(int) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Used to specify the scale for a decimal column when generating DDL.
setSchema(Schema) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
setSchema(Schema) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
setSchema(Schema) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
setSchema(Schema) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
setSchema(Schema) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
setSchema(Schema) - Method in class org.eclipse.persistence.oxm.XMLBinder
 
setSchema(Schema) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Include
 
setSchemaContext(String) - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
Set the path to the simple/complex type definition, element, or group to be referenced in the schema
setSchemaContextAsQName(QName) - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
 
setSchemaInstanceIncluded(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyAttributeMapping
 
setSchemaInstanceIncluded(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
setSchemaLocation(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setSchemaLocation(String) - Method in class org.eclipse.persistence.internal.oxm.Root
Sets the schema location.
setSchemaLocation(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Include
 
setSchemaLocation(String) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Set the schema location on this XMLMarshaller
setSchemaReference(XMLSchemaReference) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Set the SchemaReference to associate with this descriptor
setSchemaReference(XMLSchemaReference) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: Set the SchemaReference to associate with this descriptor
setSchemas(Object[]) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
setSchemas(Object[]) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
setSchemas(Object[]) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
setSchemaType(QName) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Sets the schematype associated with this XMLField This is an optional setting; when set the schema type will be used to format the XML appropriately
setSchemaType(QName) - Method in class org.eclipse.persistence.internal.oxm.Root
Sets the schema type that should be associated with this XMLRoot object.
setSchemaType(QName) - Method in class org.eclipse.persistence.oxm.XMLField
Sets the schematype associated with this XMLField This is an optional setting; when set the schema type will be used to format the XML appropriately
setSchemaType(QName) - Method in class org.eclipse.persistence.oxm.XMLUnionField
Adds the new type value to the list of types
setSchemaTypes(ArrayList) - Method in class org.eclipse.persistence.oxm.XMLUnionField
Sets the schema types that this attribute can be mapped to Valid QName schema types can be found on org.eclipse.persistence.oxm.XMLConstants
setSecondChild(Expression) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
 
setSelectCall(SQLCall) - Method in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
setSelectCall(SQLCall) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
setSelectCallForExist(SQLCall) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
setSelectCallForExist(SQLCall) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
setSelectCallForNotExist(SQLCall) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
setSelectClause(String) - Method in class org.eclipse.persistence.tools.schemaframework.ViewDefinition
The select clause is the select statement that is mapped into the view.
setSelectIfOrderedBy(boolean) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Set whether this expression should be included in the SELECT clause of a query that uses it in the ORDER BY clause.
setSelectionCall(Call) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: This is a property on the mapping which will allow custom call to be substituted for reading a reference object.
setSelectionCriteria(Expression) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Set the selection criteria of the query.
setSelectionCriteria(Expression) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Sets the selection criteria to be used as a where clause to read reference objects.
setSelectionCriteria(Expression) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Sets the selection criteria to be used as a where clause to read reference objects.
setSelectionCriteria(Expression) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: To any user of this object.
setSelectionCriteria(Expression) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Set the Expression/where clause of the query.
setSelectionCriteriaClone(Expression) - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: The clone of the selection criteria is needed for in-memory conforming each object read from the Cursor.
setSelectionId(Object) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: The Id of the object to be selected by the query.
setSelectionObject(Object) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Used to set the where clause of the query.
setSelectionQuery(ReadQuery) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Sets the query
setSelectionQueryContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Set the container policy on the selection query for this mapping.
setSelectionQueryContainerPolicy(ContainerPolicy) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Set the container policy on the selection query for this mapping.
setSelectionSQLString(String) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: This method is not supported in an EIS environment.
setSelectionSQLString(String) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: This method is not supported in an EIS environment.
setSelectionSQLString(String) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: This is a property on the mapping which will allow custom SQL to be substituted for reading a reference object.
setSelector(int) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Set the selector id.
setSelectQuery(ValueReadQuery) - Method in class org.eclipse.persistence.sequencing.QuerySequence
PUBLIC:
setSelectSequenceNumberQuery(ValueReadQuery) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
OBSOLETE: Can override the default query for returning the sequence numbers.
setSelfRecord(boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setSelfRecord(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
Sets the flag which indicates if this UnmarshalRecord represents a 'self' record
setSelfRecord(boolean) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setSendMode(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.RMITransportManagerConfig
 
setSeparator(String) - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
 
setSeparators(String[]) - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
 
setSequence(Sequence) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setSequence(Sequence) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
setSequence(Sequence) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Group
 
setSequence(Sequence) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setSequence(Sequence) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
Set the descriptor's sequence.
setSequenceConfigs(Vector<SequenceConfig>) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
setSequenceConnectionPoolConfig(ConnectionPoolConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.PoolsConfig
 
setSequenceCounterField(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setSequenceCounterField(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
setSequenceCounterFieldName(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setSequencedObject(boolean) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
setSequenceMapping(AbstractDirectMapping) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: Set the sequence mapping.
setSequenceNameField(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setSequenceNameField(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
setSequenceNameFieldName(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setSequenceNumberField(DatabaseField) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the sequence number field.
setSequenceNumberFieldName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the sequence number field name.
setSequenceNumberFieldName(String) - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Set the sequence number field name.
setSequenceNumberName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the sequence number name.
setSequencePreallocationSize(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Set the number of sequence values to preallocate.
setSequencePreallocationSize(int) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method provides access for setting the sequence pre-allocation size
setSequencePreallocationSize(int) - Method in class org.eclipse.persistence.services.RuntimeServices
This method provide access for setting the sequence pre-allocation size
setSequencePreallocationSize(Integer) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setSequencePreallocationSize(Integer) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
setSequences(List<Sequence>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Choice
 
setSequences(List<Sequence>) - Method in interface org.eclipse.persistence.internal.oxm.schema.model.NestedParticle
 
setSequences(List<Sequence>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Sequence
 
setSequences(Map<String, Sequence>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Sets sequences - for XML support only
setSequences(Map<String, Sequence>) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
INTERNAL: Used only for reading from XML.
setSequences(Map<String, Sequence>) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Used only for reading the login from XML.
setSequenceTable(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setSequenceTable(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.SequencingConfig
 
setSequenceTableName(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setSequencingConfig(SequencingConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
setSequencingHome(SequencingHome) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
INTERNAL: Set the SequencingHome object used by the session.
setSerializedObjectPolicy(SerializedObjectPolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL:
setSerializer(Serializer) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
Set the Serializer to use by default for serialization.
setSerializer(Serializer) - Method in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
Set the serialize used for this converter.
setSerializer(Serializer) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
PUBLIC: Set the Serializer to use for serialization of commands.
setSerializer(Serializer) - Method in interface org.eclipse.persistence.sessions.Session
Set the Serializer to use by default for serialization.
setSerializerClassName(String) - Method in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
Set the class name of the serializer.
setSerializerPackage(String) - Method in class org.eclipse.persistence.mappings.converters.SerializedObjectConverter
Set the package used for XML and JSON serialization JAXBContext.
setServerClassName(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.platform.CustomServerPlatformConfig
 
setServerIndirectionObject(Object) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Set the object on the server that holds on to the remote value holder.
setServerName(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: The server name is the name of the database instance.
setServerPlatform(ServerPlatform) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Set the server platform to handle server specific behavior for WLS, Oc4j, etc This is not permitted after the session is logged in.
setServerPlatform(ServerPlatform) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
PUBLIC: The ServerPlatform must be set manually when the RemoteCommandManager'CommandProcessor is not EclipseLink Session.
setServerPlatform(ServerPlatform) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Set the server platform defining server-specific behavior for the receiver (Oc4j, WLS, ...
setServerPlatformConfig(ServerPlatformConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
setServiceId(ServiceId) - Method in class org.eclipse.persistence.internal.sessions.coordination.RemoteConnection
INTERNAL: Set the service info of the receiving service
setServiceId(ServiceId) - Method in class org.eclipse.persistence.sessions.coordination.Command
ADVANCED: Set the service identifier of the service where the command originated
setServiceName(String) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
ADVANCED: This method is used to set the globally unique identifier for this connection.
setSession(ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
setSession(ABSTRACT_SESSION) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
setSession(ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setSession(CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setSession(CoreAbstractSession) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
setSession(CoreAbstractSession) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
setSession(AbstractSession) - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
INTERNAL: The session in which the event is raised.
setSession(AbstractSession) - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL:
setSession(AbstractSession) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Set the session in which we expect this expression to be translated.
setSession(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setSession(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
 
setSession(AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
setSession(AbstractSession) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
 
setSession(AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Set the session.
setSession(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Set the session that this is managing commits for.
setSession(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
 
setSession(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Set the associated server side session.
setSession(AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Set the session.
setSession(AbstractSession) - Method in class org.eclipse.persistence.logging.SessionLogEntry
Set the session that generated the log entry.
setSession(AbstractSession) - Method in class org.eclipse.persistence.mappings.converters.ConverterClass
 
setSession(AbstractSession) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
 
setSession(AbstractSession) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
setSession(AbstractSession) - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Set the session handle
setSession(AbstractSession) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the session for the query
setSession(AbstractSession) - Method in class org.eclipse.persistence.services.RuntimeServices
INTERNAL: Define the session that this instance is providing runtime services for
setSession(AbstractSession) - Method in class org.eclipse.persistence.sessions.CopyGroup
INTERNAL: Set the session.
setSession(AbstractSession) - Method in interface org.eclipse.persistence.sessions.ExternalTransactionController
INTERNAL: Set the manager's session.
setSession(AbstractSession) - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
 
setSession(AbstractSession) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Set the manager's session.
setSession(DatabaseSessionImpl) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
 
setSession(DistributedSession) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteConnection
 
setSession(Session) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
setSession(Session) - Method in class org.eclipse.persistence.logging.JavaLog
PUBLIC:
setSession(Session) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Set the session that owns this SessionLog.
setSession(Session) - Method in class org.eclipse.persistence.sessions.remote.rmi.RMIServerSessionManagerDispatcher
 
setSession(Session) - Method in class org.eclipse.persistence.sessions.SessionEvent
INTERNAL: The session in which the event is raised.
setSession(Session) - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Set the session for this session event manager
setSession(Session) - Method in interface org.eclipse.persistence.sessions.SessionProfiler
INTERNAL: Set the session.
setSession(Session) - Method in class org.eclipse.persistence.sessions.SessionProfilerAdapter
INTERNAL: Set the session.
setSession(Session) - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
setSession(Session) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
setSessionConfigs(Vector<SessionConfig>) - Method in class org.eclipse.persistence.internal.sessions.factories.model.SessionConfigs
 
setSessionCustomizerClass(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
setSessionEventListeners(Vector<String>) - Method in class org.eclipse.persistence.internal.sessions.factories.model.event.SessionEventManagerConfig
 
setSessionEventManagerConfig(SessionEventManagerConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionConfig
 
setSessionLog(SessionLog) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Set the session log to which an accessor logs messages and SQL.
setSessionLog(SessionLog) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Set the session log.
setSessionLog(SessionLog) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Set the session log to which an accessor logs messages and SQL.
setSessionName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the name of the session local to this descriptor.
setSessionName(String) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Set the name of the session to execute the mapping's queries under.
setSessionName(String) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Set the name of the session to execute the mapping's queries under.
setSessionName(String) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Set the name of the session to execute the mapping's queries under.
setSessionName(String) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
PUBLIC: Set the name of the session to execute the mapping's queries under.
setSessionName(String) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Set the name of the session to execute the mapping's queries under.
setSessionName(String) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Set the name of the session that the query should be executed under.
setSessionName(String) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: Set the name of the Session in the sessions XML file desired to be loaded.
setSessionNameByClass(HashMap) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Set sessions indexed by class, each class can only have one default session.
setSessionNames(Vector<String>) - Method in class org.eclipse.persistence.internal.sessions.factories.model.session.SessionBrokerConfig
 
setSessions(ConcurrentMap<String, Session>) - Method in class org.eclipse.persistence.sessions.factories.SessionManager
INTERNAL: Set a hashtable of all sessions
setSessionsByName(Map) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Set sessions indexed by name.
setSessionString(String) - Method in class org.eclipse.persistence.logging.EclipseLinkLogRecord
 
setSetMethod(Method) - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Set the set method for the attribute accessor.
setSetMethodName(String) - Method in class org.eclipse.persistence.internal.descriptors.MethodAttributeAccessor
Set the name of the set method for the attribute accessor.
setSetMethodName(String) - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeMethodInfo
 
setSetMethodName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
Set the methodName used to set the value for the mapping's attribute into the object.
setSetMethodName(String) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
PUBLIC: Set the methodName used to set the value for the mapping's attribute into the object.
setSetPerformedForAbsentNode(boolean) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.NullPolicy
Set the isSetPerformedForAbsentNode flag
setSetting(Setting) - Method in class org.eclipse.persistence.internal.oxm.Reference
 
setShallowCommits(Map) - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Set any objects that have been shallow committed during this commit process.
setShortestTime(long) - Method in class org.eclipse.persistence.tools.profiler.Profile
 
setShouldAcquireCascadedLocks(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: PERF: Set if deferred locks should be used.
setShouldAcquireValueAfterInsert(boolean) - Method in class org.eclipse.persistence.sequencing.QuerySequence
PUBLIC:
setShouldAllowInstantiationDeferral(boolean) - Method in class org.eclipse.persistence.internal.indirection.CacheBasedValueHolder
Set if instantiation deferral on modification should be available.
setShouldAllowNull(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Set if this type is allowed to be null for this platform
setShouldAllowNull(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Set whether the receiver should allow null values.
setShouldAlwaysConformResultsInUnitOfWork(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: set if the descriptor is defined to always conform the results in unit of work in read query.
setShouldAlwaysOverrideExistingValue(boolean) - Method in class org.eclipse.persistence.sequencing.Sequence
ADVANCED: Set that to true if the sequence should always override the existing pk value.
setShouldAlwaysRefreshCache(boolean) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: When the shouldAlwaysRefreshCache argument passed into this method is true, this method configures a ClassDescriptor to always refresh the cache if data is received from the database by any query.
setShouldAlwaysRefreshCache(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: When the shouldAlwaysRefreshCache argument passed into this method is true, this method configures a ClassDescriptor to always refresh the cache if data is received from the database by any query.
setShouldAlwaysRefreshCacheOnRemote(boolean) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: When the shouldAlwaysRefreshCacheOnRemote argument passed into this method is true, this method configures a ClassDescriptor to always remotely refresh the cache if data is received from the database by any query in a RemoteSession.
setShouldAlwaysRefreshCacheOnRemote(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: When the shouldAlwaysRefreshCacheOnRemote argument passed into this method is true, this method configures a ClassDescriptor to always remotely refresh the cache if data is received from the database by any query in a RemoteSession.
setShouldBeDeleted(boolean) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
This method was created in VisualAge.
setShouldBeReadOnly(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Define if the descriptor reference class is read-only
setShouldBindAllParameters(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Bind all arguments to any SQL statement.
setShouldBindAllParameters(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Bind all arguments to any SQL statement.
setShouldBindAllParameters(boolean) - Method in class org.eclipse.persistence.services.DevelopmentServices
This method is used to control if All parameters should be bound
setShouldBindAllParameters(boolean) - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method is used to control if All parameters should be bound
setShouldBindAllParameters(boolean) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set whether to bind all arguments to any SQL statement.
setShouldBindAllParameters(Boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Sets the internal tri-state value of shouldBindAllParams Used to cascade this value to other queries
setShouldBindLiterals(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
PUBLIC: Allows user to choose whether to bind literals in DatabaseCalls or not.
setShouldBindPartialParameters(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used to enable parameter binding and override the platform default
setShouldBreak(boolean) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setShouldBuildNullForNullPk(boolean) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: If primary key is null ObjectBuilder.buildObject returns null in case this flag is set to true (instead of throwing exception).
setShouldBuildOutputRow(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Set whether the call has to build output row
setShouldCacheAllStatements(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Cache all prepared statements, this requires full parameter binding as well.
setShouldCacheAllStatements(boolean) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Method used to set if statements should be cached.
setShouldCacheAllStatements(boolean) - Method in class org.eclipse.persistence.services.RuntimeServices
Method used to set if statements should be cached.
setShouldCacheAllStatements(boolean) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set whether prepared statements should be cached.
setShouldCacheStatement(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Bound calls can use prepared statement caching.
setShouldCacheStatement(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Cache the prepared statements, this requires full parameter binding as well.
setShouldCascadeCloneToJoinedRelationship(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: True if the value holder for the joined attribute should be triggered.
setShouldCascadeOnDelete(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
PUBLIC: Enables delete cascading on the database.
setShouldCatchExceptions(boolean) - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: This method assigns the value to the variable (shouldCatchExceptions) that defines whether we should catch all Descriptor Exceptions or not.
setShouldCheckClassLoader(boolean) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: Set if the session will be refreshed from the file if the class loader requesting the load is different than the loaded session's class loader.
setShouldCheckDatabase(boolean) - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: This method assigns the value to the variable (shouldCheckDatabase) that defines whether we should check the database or not.
setShouldCheckInstantiationPolicy(boolean) - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: This method assigns the value to the variable (shouldCheckInstantiationPolicy) that defines whether we should check InstantiationPolicy or not.
setShouldConvertDataToStrings(boolean) - Method in class org.eclipse.persistence.eis.EISPlatform
Set if all data set into the adapter should be first converted to strings.
setShouldCreateIndicesOnForeignKeys(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for table creation.
setShouldCreateIndicesOnForeignKeys(boolean) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used for table creation.
setShouldDeferExecutionInUOW(boolean) - Method in class org.eclipse.persistence.queries.ModifyAllQuery
PUBLIC: Set a flag indicating whether execution should be deferred in UOW until commit.
setShouldDeferInsert(boolean) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
 
setShouldDisableCacheHits(boolean) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Set if cache hits on primary key read object queries should be disabled.
setShouldDisableCacheHits(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set if cache hits on primary key read object queries should be disabled.
setShouldDisableCacheHitsOnRemote(boolean) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Set if the remote session cache hits on primary key read object queries is allowed or not.
setShouldDisableCacheHitsOnRemote(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set if the remote session cache hits on primary key read object queries is allowed or not.
setShouldDiscoverNewObjects(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Set if this UnitofWork should discover new objects on commit.
setShouldDisplayData(Boolean) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC: Set whether bind parameters should be displayed when logging SQL.
setShouldDisplayData(Boolean) - Method in interface org.eclipse.persistence.logging.SessionLog
Set whether bind parameters should be displayed when logging SQL.
setShouldEnableDistributedIndirectionGarbageCollection(boolean) - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
ADVANCED: Allow the server-side value holders to be cleaned-up when the client-side value holder finalize.
setShouldExecuteSelectNodes(boolean) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setShouldExtendPessimisticLockScope(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
ADVANCED: Indicates whether pessimistic lock of ObjectLevelReadQuery with isPessimisticLockScopeExtended set to true should be applied through this mapping beyond the tables mapped to the source object.
setShouldExtendPessimisticLockScope(boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Indicates whether pessimistic lock should also be applied to relation tables (ManyToMany and OneToOne mappings), reference tables (DirectCollection and AggregateCollection mapping).
setShouldExtractWhereClauseFromSelectCallForExist(boolean) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
setShouldExtractWhereClauseFromSelectCallForExist(boolean) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
setShouldFilterDuplicates(boolean) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Set if duplicate rows should be filter when using 1-m joining.
setShouldFilterDuplicates(boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Set if duplicate rows should be filter when using 1-m joining.
setShouldForceBindAllParameters(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used to enable parameter binding and override the platform default
setShouldForceFieldNamesToUpperCase(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Can be used if the app expects upper case but the database is not return consistent case, i.e.
setShouldForceFieldNamesToUpperCase(boolean) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
ADVANCED: This setting can be used if the application expects upper case but the database does not return consistent case (e.g.
setShouldHandleUnmappedFields(boolean) - Method in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
INTERNAL: Indicates whether to expect unmapped fields.
setShouldHandleWrites(boolean) - Method in class org.eclipse.persistence.history.HistoryPolicy
Sets if TopLink is responsible for writing history.
setShouldIgnoreCaseOnFieldComparisons(boolean) - Static method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allow for case in field names to be ignored as some databases are not case sensitive and when using custom this can be an issue.
setShouldIgnoreCaseOnFieldComparisons(boolean) - Static method in class org.eclipse.persistence.sessions.DatabaseLogin
ADVANCED: Allow for case in field names to be ignored as some databases are not case sensitive.
setShouldIncludeData(boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Set if the rows for the result of the query should also be returned using a complex query result.
setShouldIncrementTargetLockValueOnAddOrRemoveTarget(boolean) - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
PUBLIC: Set value that indicates whether target's optimistic locking value should be incremented on target being added to / removed from a source (default value is true).
setShouldIncrementTargetLockValueOnDeleteSource(boolean) - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
PUBLIC: Set value that indicates whether target's optimistic locking value should be incremented on the source deletion (default value is true).
setShouldInlineBinaryData(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
 
setShouldInlineBinaryData(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
 
setShouldInlineBinaryData(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
setShouldInlineBinaryData(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
 
setShouldIterateOnAggregates(boolean) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Set whether the aggregate reference objects themselves should be processed.
setShouldIterateOnFetchGroupAttributesOnly(boolean) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Set whether the attributes outside fetch group should be processed.
setShouldIterateOnIndirectionObjects(boolean) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Set whether the indirection objects themselves (e.g.
setShouldIterateOnPrimitives(boolean) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Set whether to process primitive reference objects (e.g.
setShouldIterateOverIndirectionObjects(boolean) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Set whether to process the objects contained by indirection objects (e.g.
setShouldIterateOverUninstantiatedIndirectionObjects(boolean) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Set whether to *instantiate* and process the objects contained by indirection objects (e.g.
setShouldIterateOverWrappedObjects(boolean) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setShouldKeepValues(boolean) - Method in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
 
setShouldLoad(boolean) - Method in class org.eclipse.persistence.queries.FetchGroup
Configure this group to also act as a LoadGroup when set to true and load all of the specified relationships so that the entities returned from the query where this group was used have the requested relationships populated.
setShouldLoadAll(boolean) - Method in class org.eclipse.persistence.queries.FetchGroup
Configure this group to also act as a LoadGroup the same as FetchGroup.setShouldLoad(boolean).
setShouldLoadResultIntoSelectionObject(boolean) - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Allow for the selection object of the query to be refreshed or put into the EclipseLink cache.
setShouldLockForClone(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: When set to false, this setting will allow the UOW to avoid locking the shared cache instance in order to perform a clone.
setShouldLogExceptionStackTrace(boolean) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
By default the stack is logged for FINER or less (finest).
setShouldLogExceptionStackTrace(boolean) - Method in class org.eclipse.persistence.logging.EclipseLinkLogRecord
 
setShouldLogExceptionStackTrace(boolean) - Method in interface org.eclipse.persistence.logging.SessionLog
By default stack trace is logged for SEVERE all the time and at FINER level for WARNING or less.
setShouldLogExceptionStackTrace(Boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.LoggingOptionsConfig
 
setShouldLogin(boolean) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: Set if the loaded session should be connected.
setShouldLogPerformanceProfiler(boolean) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to turn on Profile logging when using the Performance Profiler
setShouldLogPerformanceProfiler(boolean) - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to turn on Profile logging when using the Performance Profiler
setShouldLogProfile(boolean) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
PUBLIC: Set whether after each query execution the profile result should be logged.
setShouldMaintainCache(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Set if the identity map (cache) should be used or not.
setShouldModifyVersionField(Boolean) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Holds a Boolean indicating whether version field should be modified.
setShouldNewObjectsBeCached(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: By default new objects are not cached until the exist on the database.
setShouldNewObjectsBeCached(boolean) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: By default new objects are not cached until the exist on the database.
setShouldOnlyRefreshCacheIfNewerVersion(boolean) - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: When the shouldOnlyRefreshCacheIfNewerVersion argument passed into this method is true, this method configures a ClassDescriptor to only refresh the cache if the data received from the database by a query is newer than the data in the cache (as determined by the optimistic locking field) and as long as one of the following is true: the ClassDescriptor was configured by calling ClassDescriptor.alwaysRefreshCache() or ClassDescriptor.alwaysRefreshCacheOnRemote(), the query was configured by calling ObjectLevelReadQuery.refreshIdentityMapResult(), or the query was a call to Session.refreshObject(java.lang.Object)
setShouldOnlyRefreshCacheIfNewerVersion(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: When the shouldOnlyRefreshCacheIfNewerVersion argument passed into this method is true, this method configures a ClassDescriptor to only refresh the cache if the data received from the database by a query is newer than the data in the cache (as determined by the optimistic locking field) and as long as one of the following is true: the ClassDescriptor was configured by calling ClassDescriptor.alwaysRefreshCache() or ClassDescriptor.alwaysRefreshCacheOnRemote(), the query was configured by calling ObjectLevelReadQuery.refreshIdentityMapResult(), or the query was a call to Session.refreshObject(java.lang.Object)
setShouldOptimizeDataConversion(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
PUBLIC: Set if our driver level data conversion optimization is enabled.
setShouldOptimizeDataConversion(boolean) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set whether driver level data conversion optimization is enabled.
setShouldOptimizeDates(boolean) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return if JDBC date access should be optimized.
setShouldOptimizeResultSetAccess(boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Set to indicate whether ObjectLevelReadQuery should by default use ResultSet Access optimization.
setShouldOrderMappings(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This is set to turn off the ordering of mappings.
setShouldOuterJoinSubclasses(boolean) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Set if an outer join should be used to read subclasses.
setShouldOuterJoinSubclasses(boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Set if an outer join should be used to read subclasses.
setShouldPerformDeletesFirst(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: By default deletes are performed last in a unit of work.
setShouldPerformDeletesFirst(boolean) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: By default deletes are performed last in a unit of work.
setShouldPrepare(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Set if the query should be prepared.
setShouldPreserveDocument(boolean) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: Specifies that object built from this descriptor should retain any unmapped information from their original XML Document when being written back out.
setShouldPrintConnection(boolean) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
By default the connection is printed, this can be turned off.
setShouldPrintConnection(boolean) - Method in interface org.eclipse.persistence.logging.SessionLog
By default the connection is always printed whenever available, this can be turned off.
setShouldPrintConnection(Boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.LoggingOptionsConfig
 
setShouldPrintDate(boolean) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
By default the date is always printed, but can be turned off.
setShouldPrintDate(boolean) - Method in class org.eclipse.persistence.logging.EclipseLinkLogRecord
 
setShouldPrintDate(boolean) - Method in interface org.eclipse.persistence.logging.SessionLog
By default date is printed, this can be turned off.
setShouldPrintDate(Boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.LoggingOptionsConfig
 
setShouldPrintInternalException(boolean) - Static method in exception org.eclipse.persistence.exceptions.EclipseLinkException
PUBLIC: Allows overriding of EclipseLink's exception chaining detection.
setShouldPrintQualifiedNames(boolean) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
setShouldPrintSession(boolean) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
By default the session (and its connection is available) are printed, this can be turned off.
setShouldPrintSession(boolean) - Method in interface org.eclipse.persistence.logging.SessionLog
By default the Session is always printed whenever available, this can be turned off.
setShouldPrintSession(Boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.LoggingOptionsConfig
 
setShouldPrintThread(boolean) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
By default the thread is logged for FINE or less (finer,etc.).
setShouldPrintThread(boolean) - Method in class org.eclipse.persistence.logging.EclipseLinkLogRecord
 
setShouldPrintThread(boolean) - Method in interface org.eclipse.persistence.logging.SessionLog
By default the thread is logged at FINE or less level, this can be turned off.
setShouldPrintThread(Boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.log.LoggingOptionsConfig
 
setShouldProfilePerformance(boolean) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to turn on Performance Profiling
setShouldProfilePerformance(boolean) - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to turn on Performance Profiling
setShouldPropagateAsynchronously(boolean) - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
ADVANCED: Set whether this command manager should propagate commands synchronously or asynchronously.
setShouldPropagateAsynchronously(boolean) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
ADVANCED: Set whether this command manager should propagate commands synchronously or asynchronously.
setShouldPropagateChanges(boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Set whether changes should be propagated to other sessions or applications in a EclipseLink cluster through the Remote Command Manager mechanism.
setShouldPropagateChanges(boolean) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
ADVANCED: Set if cache changes should be propagated to other sessions or applications in a EclipseLink cluster through the Remote Command Manager mechanism.
setShouldReadSubclasses(boolean) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Set the descriptor to read instance of itself and its subclasses when queried.
setShouldReadSubclasses(Boolean) - Method in class org.eclipse.persistence.core.descriptors.CoreInheritancePolicy
INTERNAL: Set the descriptor to read instance of itself and its subclasses when queried.
setShouldReadSubclasses(Boolean) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Set the descriptor to read instance of itself and its subclasses when queried.
setShouldReadWholeDocument(boolean) - Method in class org.eclipse.persistence.mappings.xdb.DirectToXMLTypeMapping
PUBLIC:
setShouldRecalculateAfterUpdateEvent(boolean) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
ADVANCED Set whether this ObjectChangeSet should be recalculated after changes in event
setShouldRecalculateAfterUpdateEvent(boolean) - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCED Set whether this ObjectChangeSet should be recalculated after changes in event
setShouldRefresh(boolean) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: Set if the loaded session should be refreshed from the file.
setShouldRefreshIdentityMapResult(boolean) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
PUBLIC: Set if the attributes of the object(s) resulting from the query should be refreshed.
setShouldRefreshInvalidObjectsOnClone(boolean) - Method in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
PUBLIC: Set if expired object should be refreshed prior to cloning, default is true.
setShouldRefreshRemoteIdentityMapResult(boolean) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
PUBLIC: Set if the attributes of the object(s) resulting from the query should be refreshed.
setShouldRegisterResultsInUnitOfWork(boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set to false to have queries conform to a UnitOfWork without registering any additional objects not already in that UnitOfWork.
setShouldRegisterResultsInUnitOfWork(boolean) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Set to false to have queries conform to a UnitOfWork without registering any additional objects not already in that UnitOfWork.
setShouldRemoveConnectionOnError(boolean) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
PUBLIC: Set whether connections to remote services should be disconnected when an error occurs.
setShouldResetPrimaryKey(boolean) - Method in class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: Set if the primary key should be reset to null.
setShouldResetVersion(boolean) - Method in class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: Set if the version should be reset to null.
setShouldRetrieveBypassCache(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: JPA flag used to control the behavior of the shared cache.
setShouldRetrieveFirstPrimaryKey(boolean) - Method in class org.eclipse.persistence.queries.ReportQuery
ADVANCED: Sets if the query results should contain the first primary key of each associated object.
setShouldRetrievePrimaryKeys(boolean) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Set if the query results should contain the primary keys or each associated object.
setShouldReturnGeneratedKeys(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Indicate that this call should set Statement.RETURN_GENERATED_KEYS when executing
setShouldReturnGeneratedKeys(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: JPA flag used to control the behavior of IDENTITY generation.
setShouldReturnNameValuePairs(boolean) - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
Set the flag that indicates whether or not to return populated DatabaseRecord(s) as opposed to raw data when an SQLResultSetMapping is not set.
setShouldReturnSingleAttribute(boolean) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by only returning the attribute (as opposed to wrapping in a ReportQueryResult).
setShouldReturnSingleResult(boolean) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by only returning the first result.
setShouldReturnSingleValue(boolean) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by only returning a single value.
setShouldReturnWithoutReportQueryResult(boolean) - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by returning a nested list instead of the ReportQueryResult.
setShouldReuseJMSTopicPublisher(boolean) - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
PUBLIC: flag used to toggle between j2EE/JMS spec compliant behavior and legacy behavior.
setShouldSelectBeforeUpdate(boolean) - Method in class org.eclipse.persistence.sequencing.QuerySequence
PUBLIC:
setShouldSkipUpdate(boolean) - Method in class org.eclipse.persistence.sequencing.QuerySequence
PUBLIC:
setShouldStoreBypassCache(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: JPA flag used to control the behavior of the shared cache.
setShouldStoreByPassCache(boolean) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
 
setShouldTerminateTransaction(boolean) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
 
setShouldThrowConformExceptions(int) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Conforming queries can be set to provide different levels of detail about the exceptions they encounter There are two levels: DO_NOT_THROW_CONFORM_EXCEPTIONS = 0; THROW_ALL_CONFORM_EXCEPTIONS = 1;
setShouldThrowConformExceptions(int) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Conforming queries can be set to provide different levels of detail about the exceptions they encounter There are two levels:
DO_NOT_THROW_CONFORM_EXCEPTIONS = 0;
THROW_ALL_CONFORM_EXCEPTIONS = 1;
setShouldTrackCurrentGroup(boolean) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setShouldTrackStack(boolean) - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
INTERNAL: This can be set during debugging to record the stacktrace when a lock is acquired.
setShouldTranslate(boolean) - Method in class org.eclipse.persistence.logging.SessionLogEntry
Set if the message should be translated.
setShouldTrimStrings(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setShouldTrimStrings(boolean) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: By default CHAR field values have trailing blanks trimmed, this can be configured.
setShouldUpdateReadTimeOnUpdate(boolean) - Method in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
PUBLIC: Set whether to update the stored time an object was read when an object is updated.
setShouldUseClassLoaderFromCurrentThread(boolean) - Method in class org.eclipse.persistence.internal.helper.ConversionManager
ADVANCED: This flag should be set if the current thread classLoader should be used.
setShouldUseClassNameAsIndicator(boolean) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Set if the descriptor uses the classes fully qualified name as the indicator.
setShouldUseDatabaseTime(boolean) - Method in class org.eclipse.persistence.history.HistoryPolicy
Sets if the Timestamp used in maintainaing history should be the current time according to the database.
setShouldUseDefaultFetchGroup(boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Set false if the user does not want to use the default fetch group defined in the descriptor level.
setShouldUseDescriptorAliases(boolean) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Indicates whether descriptors should use aliasDescriptors map.
setShouldUseEqualityForNulls(boolean) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: Matches an included null attribute in the example object either to objects with that attribute also set to null or to any value other than null.
setShouldUseExclusiveConnection(boolean) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
ADVANCED: If the user has isolated data and specified that the client session should use an exclusive connection then by setting this condition to true EclipseLink will ensure that the query is executed through the exclusive connection.
setShouldUseGeneratedKeysIfPlatformSupports(boolean) - Method in class org.eclipse.persistence.sequencing.NativeSequence
 
setShouldUseIdentityIfPlatformSupports(boolean) - Method in class org.eclipse.persistence.sequencing.NativeSequence
 
setShouldUseInheritedDefaultFetchGroup(boolean) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
PUBLIC: Set whether defaultFetchGroup should be copied from the parent if not set.
setShouldUseLocatorForLOBWrite(boolean) - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
PUBLIC: Set if the locator is required for the LOB write.
setShouldUseOptimization(boolean) - Method in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
 
setShouldUseOuterJoinForMultitableInheritance(boolean) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL: set the flag indicating whether subclasses should be joined
setShouldUseRownumFiltering(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
PUBLIC: Set if SQL-Level pagination should be used for FirstResult and MaxRows settings.
setShouldUseSchemaValidation(boolean) - Static method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Set if schema validation will be used when parsing the 10g (10.1.3) sessions XML.
setShouldUseSchemaValidation(boolean) - Static method in class org.eclipse.persistence.sessions.factories.XMLProjectReader
PUBLIC: Set if schema validation will be used when parsing the deployment XML.
setShouldUseSeparateConnection(boolean) - Method in interface org.eclipse.persistence.sequencing.SequencingControl
PUBLIC: Set whether separate connection(s) for sequencing could be used (by default it couldn't).
setShouldUseSerializedObjectPolicy(boolean) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Set a flag that indicates whether the query should use SerializedObjectPolicy if descriptor has it.
setShouldUseSharedCache(boolean) - Method in class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
setShouldUseSharedEMF(boolean) - Method in class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
setShouldUseTransaction(boolean) - Method in class org.eclipse.persistence.sequencing.QuerySequence
PUBLIC:
setShouldUseWrapperPolicy(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: The wrapper policy can be enable on a query.
setShouldValidateExistence(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Set the default to determine if does-exist should be performed on persist.
setShouldValidateUpdateCallCacheUse(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set if additional validation should be performed before the query uses the update call cache.
setShouldVerifyDelete(boolean) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
PUBLIC: Verify delete is used during delete and update on private 1:1's outside of a unit of work only.
setShouldVerifyDelete(boolean) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Verify delete is used during delete and update on private 1:1's outside of a unit of work only.
setSimpleContent(SimpleContent) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setSimpleType(SimpleType) - Method in class org.eclipse.persistence.internal.oxm.schema.model.List
 
setSimpleType(SimpleType) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setSimpleType(SimpleType) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
setSimpleTypes(List<SimpleType>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Union
 
setSingleTableStrategy() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Used to indicate a SINGLE_TABLE inheritance strategy.
setSize(int) - Method in class org.eclipse.persistence.indirection.IndirectList
 
setSize(int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
setSize(int) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
Set the batch fetch size.
setSize(int) - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Set the cache size
setSize(int) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Set the size of the field, this is only required for some field types.
setSize(int) - Method in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
PUBLIC: Set the maximum size of the array.
setSizeDisallowed() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Set this type to not allow a size specification.
setSizeOptional() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Set this type to optionally have a size specification.
setSizeQuery(ValueReadQuery) - Method in class org.eclipse.persistence.queries.CursoredStreamPolicy
Set the query used to read the size.
setSizeRequired() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Set this type to require to have a size specification.
setSmartMerge(boolean) - Static method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Set smart merge flag.
setSopObject(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL:
setSopObject(Object) - Method in class org.eclipse.persistence.internal.sessions.ResultSetRecord
 
setSopObject(Object) - Method in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
 
setSourceAttributeName(String) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
setSourceClassName(String) - Method in class org.eclipse.persistence.logging.SessionLogEntry
Set the source class name to the message.
setSourceFields(List<String>) - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
setSourceFields(Vector<String>) - Method in class org.eclipse.persistence.tools.schemaframework.UniqueKeyConstraint
PUBLIC:
setSourceForeignKeyFields(List<DatabaseField>) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Sets the source foreign key fields.
setSourceForeignKeysToTargetKeys(Map<DatabaseField, DatabaseField>) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Set the source keys to target keys fields association.
setSourceKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Set the source key field names associated with the mapping.
setSourceKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Set the source key field names associated with the mapping.
setSourceKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Set the source key field names associated with the mapping.
setSourceKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Set the source key field names associated with the mapping.
setSourceKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Set the source key field names associated with the mapping.
setSourceKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: set all the primary key names associated with this mapping
setSourceKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Set the source fields.
setSourceKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Set the source fields.
setSourceKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Set the source key fields.
setSourceKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Set the source fields.
setSourceMapping(DatabaseMapping) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL:
setSourceMethodName(String) - Method in class org.eclipse.persistence.logging.SessionLogEntry
Set the source method name to the message.
setSourceObject(Object) - Method in exception org.eclipse.persistence.exceptions.ConversionException
INTERNAL: Set the object for which the problem was detected.
setSourceObject(Object) - Method in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
 
setSourceObject(Object) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
setSourceObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: set the source object into QueryBasedValueHolder.
setSourceObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: set the source object into QueryBasedValueHolder.
setSourceObject(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: set the source object into QueryBasedValueHolder.
setSourceRelationKeyFieldName(String) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Set the source key field in the relation table.
setSourceRelationKeyFieldName(String) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Set the source key field in the relation table.
setSourceRelationKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Set the source relation key field names associated with the mapping.
setSourceRelationKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Set the source relation key field names associated with the mapping.
setSourceRelationKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Set the source fields.
setSourceRelationKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Set the source fields.
setSourceToTargetKeyFieldAssociations(HashMap) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
INTERNAL: Set the list of source-target xmlfield pairs.
setSourceToTargetKeyFieldAssociations(Vector) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Set a collection of the source to target field associations.
setSourceToTargetKeyFields(Map<DatabaseField, DatabaseField>) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: Set the source keys to target keys fields association.
setSourceToTargetKeyFields(Map<DatabaseField, DatabaseField>) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Set the source keys to target keys fields association.
setSourceToTargetQueryKeyFieldAssociations(Vector) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
PUBLIC: Set a collection of the source to target query key/field associations.
setSourceToTargetQueryKeyFields(Map) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Set the source keys to target keys fields association.
setSpecialOperations(Map) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: The special operations to use in place of equal.
setSQLResultMapping(SQLResultSetMapping) - Method in class org.eclipse.persistence.queries.SQLResult
INTERNAL: Set the SQLResultSetMapping this SQLResult is part of.
setSQLResultSetMapping(SQLResultSetMapping) - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: This will be the SQLResultSetMapping that is used by this query to process the database results
setSQLResultSetMappingName(String) - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: This will be the SQLResultSetMapping that is used by this query to process the database results
setSQLResultSetMappingNames(List<String>) - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: This will be the SQLResult
setSQLResultSetMappings(List<SQLResultSetMapping>) - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
PUBLIC: This will be the SQLResultSetMappings that are used by this query to process the database results
setSQLStatement(SQLStatement) - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Set the sqlStatement
setSQLStatement(SQLStatement) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: To any user of this object.
setSQLStatements(Vector) - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Normally only a single statement is used, however multiple table may require multiple statements on write.
setSQLString(String) - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: To any user of this object.
setSQLString(String) - Method in class org.eclipse.persistence.queries.SQLCall
Set the SQL string.
setSQLStringInternal(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Set the SQL string.
setSqlType(int) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Set the JDBC type that corresponds to the field.
setSqlTypeName(String) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDatabaseField
ADVANCED: For ARRAY and STRUCT fields, this is the user defined type for the field.
setStack(Exception) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
setStartDelimiter(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Delimiter to use for fields and tables using spaces or other special values.
setStartFields(List<DatabaseField>) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL:
setStartFieldType(Class<?>) - Method in class org.eclipse.persistence.history.HistoryPolicy
ADVANCED: Sets the type of all start fields.
setStartString(String) - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
 
setStartStrings(String[]) - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
 
setStartValue(Comparable) - Method in class org.eclipse.persistence.descriptors.partitioning.RangePartition
PUBLIC: Set the range start value.
setStatement(Statement) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
The statement is stored for the return value of cursor selects.
setStatement(SQLSelectStatement) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Set the statement that expression is for.
setStatement(SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.ExpressionIterator
 
setStatement(SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
 
setStatementCache(Hashtable<String, Statement>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
The statement cache stores a fixed sized number of prepared statements.
setStatementCacheSize(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
The statement cache size for prepare parameterized statements.
setStatementCacheSize(int) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
Used to set the statement cache size.
setStatementCacheSize(int) - Method in class org.eclipse.persistence.services.RuntimeServices
Used to set the statement cache size.
setStatementCacheSize(int) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: If prepared statement caching is used this configures the cache size.
setStatements(List<String>) - Method in class org.eclipse.persistence.tools.schemaframework.PackageDefinition
The statements are the SQL lines of code.
setStatements(List<String>) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The statements are the SQL lines of code in procedure.
setStoredProcedureTerminationToken(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setStreamsForBinding(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setStringBinding(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setStringBindingSize(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setStringBindingSize(int) - Method in class org.eclipse.persistence.services.DevelopmentServices
Sets the size of strings after which they will be bound into the statement
setStringBindingSize(int) - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
Sets the size of strings after which they will be bound into the statement
setStringBindingSize(int) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used to help bean introspection.
setStructConverterClasses(Vector<String>) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.StructConverterConfig
 
setStructConverterConfig(StructConverterConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setStructConverters(Collection<String>) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Returns structure converter class names that would be set on the databasePlatform instance This is used to avoid the platform instance changing at login.
setStructureName(String) - Method in class org.eclipse.persistence.mappings.structures.ArrayMapping
PUBLIC: Set the name of the structure.
setStructureName(String) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
PUBLIC: Set the name of the structure.
setStructureName(String) - Method in class org.eclipse.persistence.mappings.structures.ObjectArrayMapping
PUBLIC: Set the name of the structure.
setStructureName(String) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
PUBLIC: Set the name of the structure.
setStuckOnReleaseDeferredLock(boolean) - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
setStuckThreadAcquiringLockForReading(boolean) - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
setStuckThreadAcquiringLockForWriting(boolean) - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
setSubclassShouldLoad(boolean) - Method in class org.eclipse.persistence.queries.FetchGroup
passes should load to subclasses.
setSubQuery(ReportQuery) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
 
setSubSelect(Expression) - Method in class org.eclipse.persistence.internal.expressions.SubSelectDatabaseTable
 
setSubSelect(SubSelectExpression) - Method in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
 
setSubSize(int) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Set the sub-size of the field.
setSubstitutionGroup(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setSuperClass(String) - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
If the class to be generated is an interface, do not use this method.
setSupportsAutoCommit(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
supportsAutoCommit can be set to false for JDBC drivers which do not support autocommit.
setSupportsForeignKeyConstraints(boolean) - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
 
setSupportsIdentity(boolean) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
ADVANCED: Oracle db doesn't support identity.
setSupportsLocalTransactions(boolean) - Method in class org.eclipse.persistence.eis.EISPlatform
Set if this platform supports local transactions.
setSupportsReturnGeneratedKeys(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Indicates whether the platform supports the use of Statement.RETURN_GENERATED_KEYS.
setSuscriber(TopicSubscriber) - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: set the TopicSubscriber on a local RemoteConnection for reading JMS messages when this runnable connection is started in a thread.
setSwaRef(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
 
setSwaRef(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
 
setSwaRef(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
setSwaRef(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
 
setSynchronizationType(int) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
setSynchronized(boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Set isSynchronized flag to indicate that this session is synchronized.
setSynchronized(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Set isSynchronized flag to indicate that this session is a synchronized unit of work.
setSynchronized(boolean) - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: Set isSynchronized flag to indicate that members of session broker are synchronized.
setSynchronized(boolean) - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Set isSynchronized flag to indicate that this session is synchronized.
setSystemId(String) - Method in class org.eclipse.persistence.internal.oxm.record.ExtendedResult
 
setSystemId(String) - Method in class org.eclipse.persistence.internal.oxm.record.ExtendedSource
 
setTable(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.sequencing.TableSequenceConfig
 
setTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.SQLModifyStatement
 
setTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.TableExpression
INTERNAL: Added for temporal querying.
setTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Set the table for the field.
setTable(DatabaseTable) - Method in class org.eclipse.persistence.sequencing.TableSequence
 
setTable(DatabaseTable) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
 
setTableAliases(Map<DatabaseTable, DatabaseTable>) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
setTableAliases(TableAliasLookup) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
INTERNAL: For CR#2456, Table identity involves having two tables sharing the same aliasing table.
setTableAliasInSelectCallForExist(String) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
setTableAliasInSelectCallForExist(String) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
setTableAliasInSelectCallForNotExist(String) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
setTableCreationSuffix(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
PUBLIC: Get the String used on all table creation statements generated from the DefaultTableGenerator with a session using this project (DDL generation).
setTableCreationSuffix(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Get the String used on all table creation statements generated from the DefaultTableGenerator with a session using this project (DDL generation).
setTableCreator(TableCreator) - Method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Set the table creator to generate from.
setTableDefinitions(List<TableDefinition>) - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Set the tables.
setTableForAggregateMappingKey(DatabaseTable) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: If this mapping is used as the key of a CollectionTableMapMapping, the table used by this mapping will be the relation table.
setTableName(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Specify the table name for the class of objects the receiver describes.
setTableName(String) - Method in class org.eclipse.persistence.descriptors.RelationalDescriptor
PUBLIC: Specify the table name for the class of objects the receiver describes.
setTableName(String) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
setTableName(String) - Method in class org.eclipse.persistence.sequencing.TableSequence
 
setTableNames(Vector) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Specify the all table names for the class of objects the receiver describes.
setTableNames(Vector) - Method in class org.eclipse.persistence.descriptors.RelationalDescriptor
PUBLIC: Specify the all table names for the class of objects the receiver describes.
setTableNames(Vector) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
setTablePerClassPolicy(TablePerClassPolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Sets the table per class policy.
setTablePerTenant() - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL: This method is used to update the table per tenant descriptor with a table per tenant prefix or suffix on its associated tables.
setTableQualifier(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the table Qualifier for this descriptor.
setTableQualifier(String) - Method in class org.eclipse.persistence.descriptors.RelationalDescriptor
PUBLIC: Set the table Qualifier for this descriptor.
setTableQualifier(String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Set the qualifier for the table.
setTableQualifier(String) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Set the qualifier for the table.
setTableQualifier(String) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
setTableQualifier(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
setTableQualifier(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the default qualifier for all tables.
setTableQualifier(String) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Set the default qualifier for all tables.
setTableQualifier(String, String, String) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
setTables(List<DatabaseTable>) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
setTables(Vector<DatabaseTable>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Sets the tables
setTables(Vector<DatabaseTable>) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Sets the tables
setTables_databaseFieldsToValues(HashMap) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
setTableSchemaPerTenant() - Method in class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
setTableSchemaPerTenant() - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL: This method is used to update the table per tenant descriptor with a table per tenant schema.
setTablesToPrimaryKeyFields(HashMap) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
setTargetFields(List<String>) - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
setTargetForeignKeyFieldName(String) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
PUBLIC: Define the target foreign key relationship in the one-to-many mapping.
setTargetForeignKeyFieldName(String) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Define the target foreign key relationship in the 1-1 mapping.
setTargetForeignKeyFieldNames(String[], String[]) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
PUBLIC: Define the target foreign key relationship in the one-to-many mapping.
setTargetForeignKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
PUBLIC: Set the target foregin key field names associated with the mapping.
setTargetForeignKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Set the target key field names associated with the mapping.
setTargetForeignKeyFields(List<DatabaseField>) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Sets the target foreign key fields.
setTargetForeignKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: set the target foregin key fields associated with the mapping
setTargetForeignKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Set the target fields.
setTargetForeignKeysToSourceKeys(Map<DatabaseField, DatabaseField>) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Set the target fields.
setTargetForeignKeyToSourceKeys(Map<DatabaseField, DatabaseField>) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
 
setTargetKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Set the target key field names associated with the mapping.
setTargetKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Set the target key field names associated with the mapping.
setTargetKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Set the target fields.
setTargetKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Set the target fields.
setTargetNamespace(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setTargetObjectPrimaryKeys(Object) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Set target object primary keys.
setTargetPrimaryKeyFields(List<DatabaseField>) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatementForTempTable
 
setTargetRelationKeyFieldName(String) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
PUBLIC: Set the target key field in the relation table.
setTargetRelationKeyFieldName(String) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
PUBLIC: Set the target key field in the relation table.
setTargetRelationKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Set the target relation key field names associated with the mapping.
setTargetRelationKeyFieldNames(Vector) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Set the target relation key field names associated with the mapping.
setTargetRelationKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Set the target fields.
setTargetRelationKeyFields(Vector<DatabaseField>) - Method in class org.eclipse.persistence.mappings.RelationTableMechanism
INTERNAL: Set the target fields.
setTargetTable(String) - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
setTargetTable(String) - Method in class org.eclipse.persistence.tools.schemaframework.IndexDefinition
PUBLIC: set qualified table name.
setTargetTable(DatabaseTable) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatementForTempTable
 
setTargetToSourceKeyFields(Map<DatabaseField, DatabaseField>) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: Set the target keys to source keys fields association.
setTargetToSourceKeyFields(Map<DatabaseField, DatabaseField>) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Set the target keys to source keys fields association.
setTemporaryCachedQueryResults(Object) - Method in class org.eclipse.persistence.queries.ReadQuery
INTERNAL: Put results in the temporary cache.
setTempSession(AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
 
setTenantDiscriminatorFields(Map<DatabaseField, String>) - Method in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
INTERNAL:
setTenantTableDiscriminatorType(TenantTableDiscriminatorType) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
PUBLIC: Set the tenant table discriminator type.
setTerminationString(String) - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
 
setTerminationStrings(String[]) - Method in class org.eclipse.persistence.expressions.ListExpressionOperator
 
setTextNode(XPathNode) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
setTextWrapperFragment(XPathFragment) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setTextWrapperFragment(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setTextWrapperFragment(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setThread(Thread) - Method in class org.eclipse.persistence.logging.SessionLogEntry
Set the thread that was active when the log entry was generated.
setThreadNotAbleToAccessResource(Thread) - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
setThreadPool(ExecutorService) - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: Set the thread pool to use.
setThreadPoolSize(int) - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
Set the thread pool size.
setThreadPoolSize(int) - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
Set the thread pool size.
setTimestampQuery(ValueReadQuery) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Can override the default query for returning a timestamp from the server.
setTimestampQuery(ValueReadQuery) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Can override the default query for returning a timestamp from the server.
setTimestampQuery(ValueReadQuery) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Override the default query for returning a timestamp from the server.
setTimeToLive(long) - Method in class org.eclipse.persistence.descriptors.invalidation.TimeToLiveCacheInvalidationPolicy
PUBLIC: Set the time-to-live specified by this policy.
setTimeZone(TimeZone) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
The specified TimeZone will be used for all String to date object conversions.
setTimeZoneQualified(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
Specify if Specify if when date objects are converted to Strings in the XML Schema time or dateTime format
Setting - Class in org.eclipse.persistence.oxm.sequenced
Setting objects are used to control the order in which the mappings for Sequenced Objects are processed.
Setting() - Constructor for class org.eclipse.persistence.oxm.sequenced.Setting
 
Setting(String, String) - Constructor for class org.eclipse.persistence.oxm.sequenced.Setting
 
setTolerateInvalidJPQL(boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Indicates whether an invalid NamedQuery will be tolerated at init time.
setTopic(Topic) - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: Set the Topic.
setTopicConnection(TopicConnection) - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: Set the TopicConnection.
setTopicConnectionFactory(TopicConnectionFactory) - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: Set the TopicConnectionFactory, which is used if the publisher is not set to obtain the TopicConnection, TopicSession and TopicPublisher
setTopicConnectionFactoryName(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.JMSPublishingTransportManagerConfig
 
setTopicConnectionFactoryName(String) - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
PUBLIC: Configure the JMS Topic Connection Factory Name for the JMS Topic connections.
setTopicHostUrl(String) - Method in class org.eclipse.persistence.sessions.coordination.jms.JMSPublishingTransportManager
PUBLIC: Configure the URL of the machine on the network that hosts the JMS Topic.
setTopicHostURL(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.JMSPublishingTransportManagerConfig
 
setTopicName(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.JMSPublishingTransportManagerConfig
 
setTopicName(String) - Method in class org.eclipse.persistence.sessions.coordination.broadcast.BroadcastTransportManager
PUBLIC: Configure the Topic name for the Topic that this TransportManager will be connecting to.
setTopicSession(TopicSession) - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: set the TopicSession to be used when this RemoteConnection executes a command if the publisher is also set.
setTopLevelAttributes(Map<String, Attribute>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setTopLevelComplexTypes(Map<String, ComplexType>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setTopLevelElements(Map<String, Element>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setTopLevelSimpleTypes(Map<String, SimpleType>) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Schema
 
setTotalDigits(int) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Element
 
setTotalDigits(int) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setTotalDigits(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setTotalTime(long) - Method in class org.eclipse.persistence.tools.profiler.Profile
 
setTrackedAttributeName(String) - Method in interface org.eclipse.persistence.descriptors.changetracking.CollectionChangeTracker
PUBLIC: Set the Attribute name this collection is mapped under.
setTrackedAttributeName(String) - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Set the mapping attribute name, used to raise change events.
setTrackedAttributeName(String) - Method in class org.eclipse.persistence.indirection.IndirectMap
INTERNAL: Set the mapping attribute name, used to raise change events.
setTrackedAttributeName(String) - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Set the mapping attribute name, used to raise change events.
setTransaction(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: PERF: Set the associated external transaction.
setTransaction(Object) - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
 
setTransactionController(AbstractTransactionController) - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
 
setTransactionId(Object) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
setTransactionIsolation(int) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Set the transaction isolation setting for a connection.
setTransactionIsolation(int) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the transaction isolation setting for the connection.
setTransactionKey(Object) - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
 
setTransactionManager(TransactionManager) - Method in class org.eclipse.persistence.transaction.JTATransactionController
PUBLIC: Set the transaction manager used to control the JTA transactions.
setTransactionManager(TransactionSynchronizationRegistry) - Method in class org.eclipse.persistence.transaction.JTA11TransactionController
PUBLIC: Set the synchronization objects registry used to control the JTA 1.1 transactions.
setTransactionMutex(ConcurrencyManager) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
 
setTransformationRecord(DOMRecord) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setTransformationRecord(TRANSFORMATION_RECORD) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setTransformationRecord(TRANSFORMATION_RECORD) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setTransformer(AttributeTransformer) - Method in class org.eclipse.persistence.internal.indirection.TransformerBasedValueHolder
Set the transformer.
setTransformerClass(Class<?>) - Method in class org.eclipse.persistence.internal.descriptors.TransformerBasedFieldTransformation
 
setTransformerClassName(String) - Method in class org.eclipse.persistence.internal.descriptors.TransformerBasedFieldTransformation
 
setTranslationRow(AbstractRecord) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
INTERNAL: Set the row for translation
setTranslationRow(AbstractRecord) - Method in class org.eclipse.persistence.internal.expressions.SQLStatement
INTERNAL: Set the row for translation
setTranslationRow(AbstractRecord) - Method in class org.eclipse.persistence.queries.Cursor
INTERNAL: Sets the translation row this query was executed with.
setTranslationRow(AbstractRecord) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Set the row for translation
setTransportClass(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.UserDefinedTransportManagerConfig
 
setTransportManager(TransportManager) - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
ADVANCED: Set a specific transport manager to manage sending and receiving of remote commands.
setTransportManager(TransportManager) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
setTransportManagerConfig(TransportManagerConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.rcm.RemoteCommandManagerConfig
 
setTrimStrings(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.DatabaseLoginConfig
 
setTuner(SessionTuner) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
Set the tuner used to tune the configuration of this session.
setType(int) - Method in class org.eclipse.persistence.expressions.ExpressionOperator
ADVANCED: Set the type of function.
setType(int) - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
setType(int) - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
Set to indicate if the schema reference references a simple type definition, complex type definition, element or group.
setType(Class<?>) - Method in class org.eclipse.persistence.internal.codegen.ReflectiveAttributeDefinition
 
setType(Class<?>) - Method in interface org.eclipse.persistence.internal.core.helper.CoreField
Set the Java class type that corresponds to the field.
setType(Class<?>) - Method in class org.eclipse.persistence.internal.descriptors.QueryArgument
 
setType(Class<?>) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Set the Java class type that corresponds to the field.
setType(Class<?>) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Set the type of the field.
setType(Class<?>) - Method in class org.eclipse.persistence.tools.schemaframework.NestedTableDefinition
PUBLIC: Set the type of the field.
setType(Class<?>) - Method in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
PUBLIC: Set the type of the field.
setType(Object) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
The inferred type of this parameter.
setType(String) - Method in class org.eclipse.persistence.internal.codegen.NonreflectiveAttributeDefinition
 
setType(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
setType(BatchFetchType) - Method in class org.eclipse.persistence.queries.BatchFetchPolicy
Set the batch fetch type, (JOIN, IN, EXISTS).
setType(DynamicType) - Method in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
 
setTypeDefinition(String) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Set the type definition of the field.
setTypeDefParticle(TypeDefParticle) - Method in class org.eclipse.persistence.internal.oxm.schema.model.ComplexType
 
setTypeDefParticle(TypeDefParticle) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Extension
 
setTypeDefParticle(TypeDefParticle) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Restriction
 
setTypeField(DatabaseField) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: This method set the typeField of the mapping to the parameter field
setTypeFieldName(String) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
PUBLIC: This method sets the name of the typeField of the mapping.
setTypeIndicatorNameTranslation(Map) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: For avoiding classpath dependencies on the Mapping Workbench
setTypeIndicatorTranslation(Map) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Set the typeIndicatorTranslations hashtable to the new Hashtable translations
setTypeName(String) - Method in class org.eclipse.persistence.internal.descriptors.QueryArgument
INTERNAL: Set the classname of the type.
setTypeName(String) - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
setTypeName(String) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
setTypeName(String) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Set the type name of the field.
setTypeName(String) - Method in class org.eclipse.persistence.tools.schemaframework.NestedTableDefinition
PUBLIC: Set the type of the field.
setTypeName(String) - Method in class org.eclipse.persistence.tools.schemaframework.TypeTableDefinition
PUBLIC: The name of the type that this table is of.
setTypeName(String) - Method in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
PUBLIC: Set the type of the field.
setTypeQName(QName) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setTypeQName(QName) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setTypeQName(QName) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setTypeSize(int) - Method in class org.eclipse.persistence.tools.schemaframework.NestedTableDefinition
PUBLIC: Set the size of the element field, this is only required for some field types.
setTypeSize(int) - Method in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
PUBLIC: Set the size of the element field, this is only required for some field types.
setUninstantiated() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Set the instantiated flag to false.
setUnion(Union) - Method in class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
setUnionExpressions(List<Expression>) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
setUnionExpressions(List<Expression>) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Set any union expressions.
setUnionUnpartitionableQueries(boolean) - Method in class org.eclipse.persistence.descriptors.partitioning.FieldPartitioningPolicy
PUBLIC: Set if queries that do not contain the partition field should be sent to every database and have the result unioned.
setUnique(boolean) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Used for generating DDL.
setUnique(boolean) - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Set whether the receiver is a unique constraint field.
setUniqueKeys(List<UniqueKeyConstraint>) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC:
setUnitOfWork(UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
INTERNAL: Set the unit of work associated with this listener
setUnitOfWork(UnitOfWorkImpl) - Method in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
 
setUnitOfWorkCacheIsolationLevel(int) - Method in class org.eclipse.persistence.descriptors.CachePolicy
ADVANCED: This setting configures how the session cache will be used in a unit of work.
setUnitOfWorkCacheIsolationLevel(int) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: This setting configures how the session cache will be used in a unit of work.
setUnitOfWorkChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Sets the current UnitOfWork change set to be the one passed in.
setUnitOfWorkClone(Object) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Sets the UnitOfWork Clone that this ChangeSet was built for.
setUnitsOfWork(ConcurrentMap<Object, UnitOfWorkImpl>) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Set the table of transactions to units of work.
setUnmappedContentHandlerClass(Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Set the class that will be instantiated to handled unmapped content Class must implement the org.eclipse.persistence.oxm.unmapped.UnmappedContentHandler interface
setUnmarshalAttributeGroup(Object) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
setUnmarshalAttributeGroup(CoreAttributeGroup) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setUnmarshalAttributeGroup(CoreAttributeGroup) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setUnmarshalAttributeGroup(CoreAttributeGroup) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setUnmarshalContext(UnmarshalContext) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setUnmarshalContext(UnmarshalContext) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setUnmarshalContext(UnmarshalContext) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setUnmarshaller(Unmarshaller) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
setUnmarshaller(Unmarshaller) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
INTERNAL:
setUnmarshaller(XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setUnmarshaller(XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL:
setUnmarshaller(UNMARSHALLER) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setUnmarshalListener(XMLUnmarshalListener) - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
 
setUnmarshalListener(UNMARSHALLER_LISTENER) - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
 
setUnmarshalNamespaceResolver(UnmarshalNamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
setUnmarshalNamespaceResolver(UnmarshalNamespaceResolver) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setUnmarshalNamespaceResolver(UnmarshalNamespaceResolver) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setUnmarshalNamespaceResolver(UnmarshalNamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setUnmarshalNodeValue(NodeValue) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
setUnmarshalRecord(UNMARSHAL_RECORD) - Method in class org.eclipse.persistence.internal.oxm.unmapped.DefaultUnmappedContentHandler
 
setUnmarshalRecord(UNMARSHAL_RECORD) - Method in interface org.eclipse.persistence.internal.oxm.unmapped.UnmappedContentHandler
Set the UnmarshalRecord which gives access to mechanisms used during the unmarshal process such as an Unmarshaller and a Session.
setUnregisteredExistingObjects(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Used to set the unregistered existing objects vector used when validation has been turned off.
setUnregisteredNewObjects(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL:
setUnregisteredNewObjectsCache(List) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
Set unregistered new object cache
setUnregisteredNewObjectsInParent(Map) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL:
setUOWChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Used to set the parent change Set.
setUpdatable(boolean) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
Used to specify whether the column should be included in SQL INSERT statements.
setUpdateAllFields(boolean) - Method in class org.eclipse.persistence.descriptors.CMPPolicy
ADVANCED: Configure whether TopLink should update all fields for an object of this type when an update occurs.
setUpdateCall(Call) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's update call.
setUpdateCallCacheSize(int) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the size of the update call cache.
setUpdateClauses(HashMap) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
setUpdateQuery(DataModifyQuery) - Method in class org.eclipse.persistence.sequencing.QuerySequence
PUBLIC:
setUpdateQuery(UpdateObjectQuery) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's update query.
setUpdateSequenceQuery(DataModifyQuery) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
This method sets the update sequence number query.
setUpdateSQLString(String) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
ADVANCED: Set the receiver's update SQL string.
setupDocumentPreservationPolicy(DatabaseSession) - Method in class org.eclipse.persistence.oxm.XMLContext
 
setupHandlerForKeepAsElementPolicy(UnmarshalRecord, XPathFragment, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLRelationshipMappingNodeValue
 
setupLocator(Document) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
 
setupLockingClauseForJoinedExpressions(ForUpdateOfClause, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Used for joining in conjunction with pessimistic locking.
setupSession(SESSION) - Method in class org.eclipse.persistence.internal.oxm.Context.ContextState
 
setupWriteFieldsForInsert(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Put the initial writelock value into the modifyRow.
setupWriteFieldsForInsert(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: This method must be included in any locking policy.
setupWriteFieldsForInsert(ObjectLevelModifyQuery) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: Add the initial right lock values to the modify row in the query.
setUrl(String) - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
ADVANCED: Set the URL for this command manager.
setUrl(String) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
ADVANCED: Set the URL for this command manager.
setURL(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
 
setURL(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.RMIRegistryNamingServiceConfig
 
setURL(String) - Method in class org.eclipse.persistence.sessions.coordination.ServiceId
INTERNAL: Set the URL for the service
setURL(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the JDBC URL.
setURL(URL) - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaURLReference
 
setURLString(String) - Method in class org.eclipse.persistence.oxm.schema.XMLSchemaURLReference
 
setUse(String) - Method in class org.eclipse.persistence.internal.oxm.schema.model.Attribute
 
setUseDelimiters(boolean) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
setUseDelimiters(boolean) - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
setUseDescriptorsToValidateInheritedObjects(boolean) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Sets if we should use the descriptor inheritance to determine if an object can be returned from the identity map or not.
setUseEclipseLinkProfiling() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to turn on EclipseLink Performance Profiling
setUseEclipseLinkProfiling() - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to turn on EclipseLink Performance Profiling
setUseExclusiveConnection(boolean) - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.ConnectionPolicyConfig
 
setUseJDBCStoredProcedureSyntax(Boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return true if JDBC syntax should be used for stored procedure calls.
setUseLazyInstantiation(boolean) - Method in interface org.eclipse.persistence.indirection.IndirectCollection
INTERNAL Set whether this collection should attempt do deal with adds and removes without retrieving the collection from the dB
setUseLazyInstantiation(boolean) - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL Set whether this collection should attempt do deal with adds and removes without retrieving the collection from the dB
setUseLazyInstantiation(boolean) - Method in class org.eclipse.persistence.indirection.IndirectMap
INTERNAL Set whether this collection should attempt do deal with adds and removes without retrieving the collection from the dB
setUseLazyInstantiation(boolean) - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL Set whether this collection should attempt do deal with adds and removes without retrieving the collection from the dB
setUseLazyInstantiation(Boolean) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
ADVANCED: This method will only change the behavior of TransparentIndirectionPolicy.
setUseLazyInstantiation(Boolean) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
ADVANCED: IndirectList and IndirectSet can be configured not to instantiate the list from the database when you add and remove from them.
setUseLazyInstantiationForIndirectCollection(Boolean) - Method in class org.eclipse.persistence.mappings.CollectionMapping
ADVANCED: Calling this method will only affect behavior of mappings using transparent indirection This method should only be called after this mapping's indirection policy has been set IndirectList and IndirectSet can be configured not to instantiate the list from the database when you add and remove from them.
setUseNationalCharacterVaryingTypeForString(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setUseNoProfiling() - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method is used to turn off all Performance Profiling, DMS or EclipseLink.
setUseNoProfiling() - Method in class org.eclipse.persistence.services.RuntimeServices
This method is used to turn off all Performance Profiling, DMS or EclipseLink.
setUserDefinedForeignKeyConstraints(Map<String, ForeignKeyConstraint>) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
PUBLIC: Set the foreign key constraints for this table.
setUserJavaTypesForDeploymentXML(ArrayList) - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL:
setUsername(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.login.LoginConfig
 
setUsername(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.transport.naming.JNDINamingServiceConfig
 
setUserName(String) - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
ADVANCED: Set the user name used as the value to the SECURITY_PRINCIPAL key in the cached context properties.
setUserName(String) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: The user name is the database login name.
setUserName(String) - Method in interface org.eclipse.persistence.sessions.Login
PUBLIC: All logins must take a user name and password.
setUserXMLTypesForDeploymentXML(ArrayList) - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL:
setUsesBatchReading(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Indicates whether the referenced object should always be batch read on read all queries.
setUsesBatchWriting(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setUsesBatchWriting(boolean) - Method in class org.eclipse.persistence.services.DevelopmentServices
This method is used to turn on EclipseLink Batch Writing.
setUsesBatchWriting(boolean) - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method is used to turn on TopLink Batch Writing.
setUsesBatchWriting(boolean) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use batch writing.
setUsesBinding(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Set that this call should or shouldn't bind all parameters
setUsesByteArrayBinding(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setUsesByteArrayBinding(boolean) - Method in class org.eclipse.persistence.services.DevelopmentServices
This method allows control of whether byte arrays should be bound into the statement or not.
setUsesByteArrayBinding(boolean) - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method allows control of whether byte arrays should be bound into the statement or not.
setUsesByteArrayBinding(boolean) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use parameter binding for large binary data.
setUseSemaphoreInObjectBuilder(boolean) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setUseSemaphoreToLimitConcurrencyOnWriteLockManagerAcquireRequiredLocks(boolean) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
setUsesExternalConnectionPooling(boolean) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Return whether EclipseLink uses some external connection pooling service such as a JDBC 2.0 driver.
setUsesExternalTransactionController(boolean) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Return whether EclipseLink uses some external transaction service such as JTS.
setUsesIndirection(boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Indirection means that a ValueHolder will be put in-between the attribute and the real object.
setUsesIndirection(boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Will be used by Gromit.
setUsesJDBCBatchWriting(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Some JDBC 2 drivers to not support batching, so this lets are own batching be used.
setUsesJDBCBatchWriting(boolean) - Method in class org.eclipse.persistence.services.DevelopmentServices
This method is used to turn on JDBC Batch Writing.
setUsesJDBCBatchWriting(boolean) - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method is used to turn on JDBC Batch Writing.
setUsesJDBCBatchWriting(boolean) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Calling this method with an argument of true indicates to EclipseLink that the JDBC driver supports batch writing.
setUsesNativeBatchWriting(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Advanced: This is used to enable native batch writing on drivers that support it.
setUsesNativeSQL(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setUsesNativeSQL(boolean) - Method in class org.eclipse.persistence.services.DevelopmentServices
This method allows the client to set if Native SQL should be used.
setUsesNativeSQL(boolean) - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method allows the client to set if Native SQL should be used.
setUsesNativeSQL(boolean) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use database specific sql grammar not JDBC specific.
setUsesServerTime(boolean) - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
PUBLIC: Set if policy uses server time.
setUsesSingleNode(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.CollectionReferenceMapping
 
setUsesSingleNode(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
Sets whether the mapping uses a single node.
setUsesSingleNode(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Sets whether the mapping uses a single node.
setUsesSingleNode(boolean) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
PUBLIC: Sets whether the mapping uses a single node.
setUsesSingleNode(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
 
setUsesSingleNode(boolean) - Method in class org.eclipse.persistence.oxm.XMLField
PUBLIC: Sets whether the mapping uses a single node.
setUsesStreamsForBinding(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setUsesStreamsForBinding(boolean) - Method in class org.eclipse.persistence.services.DevelopmentServices
This method is used to set if streams should be used for binding.
setUsesStreamsForBinding(boolean) - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method is used to set if streams should be used for binding.
setUsesStreamsForBinding(boolean) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use streams to store large binary data.
setUsesStringBinding(boolean) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
setUsesStringBinding(boolean) - Method in class org.eclipse.persistence.services.DevelopmentServices
Allows the client to set if String should be bound into the statement or not.
setUsesStringBinding(boolean) - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
Allows the client to set if String should be bound into the statement or not.
setUsesStringBinding(boolean) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used to help bean introspection.
setUseUniqueFieldAliases(boolean) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: If set unique field aliases will be generated of the form "fieldname AS fieldnameX" Where fieldname is the column name and X is an incremental value ensuring uniqueness
setUseXMLRoot(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyCollectionMapping
 
setUseXMLRoot(boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyObjectMapping
 
setUseXMLRoot(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
setUseXMLRoot(boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
setUseXsdTypesWithPrefix(boolean) - Method in class org.eclipse.persistence.internal.oxm.JsonTypeConfiguration
If there should be xsd prefix when using simple types, e.g.
setUUIDQuery(ValueReadQuery) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Can override the default query for returning a UUID from the server.
setUUIDQuery(ValueReadQuery) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Can override the default query for returning a UUID from the server.
setValidateExample(boolean) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: When set to true the example object will be validated for unsupported mapping types.
setValidationLevel(int) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not referred in the unit of work cache.
setValidationLevel(int) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not referred in the unit of work cache.
setValidationLevel(String) - Method in class org.eclipse.persistence.internal.jpa.jpql.HermesParser
 
setValidationLevel(String) - Method in interface org.eclipse.persistence.queries.JPAQueryBuilder
Allow the parser validation level to be set.
setValidationMode(int) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
setValidationMode(int) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
setValidationMode(int) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
setValidationMode(int) - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
Set the validation mode.
setValidationMode(int) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
setValidationMode(XMLReader, int) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
setValidatorHandler(ValidatorHandler) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
setValidatorHandler(ValidatorHandler) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
setValue(Object) - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl.PropertyWrapper
Sets the value.
setValue(Object) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
 
setValue(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordEntry
 
setValue(Object) - Method in class org.eclipse.persistence.mappings.Association
PUBLIC: Set the value.
setValue(Object) - Method in class org.eclipse.persistence.mappings.transformers.ConstantTransformer
PUBLIC: Set the value of the constant.
setValue(Object) - Method in class org.eclipse.persistence.oxm.record.XMLEntry
 
setValue(Object) - Method in class org.eclipse.persistence.oxm.sequenced.Setting
Set the value on the Setting.
setValue(Object) - Method in class org.eclipse.persistence.queries.ReportQueryResult.RecordEntry
 
setValue(Object, boolean) - Method in class org.eclipse.persistence.oxm.sequenced.Setting
 
setValue(Object, Object) - Method in interface org.eclipse.persistence.descriptors.CMPPolicy.KeyElementAccessor
 
setValue(Object, Object) - Method in class org.eclipse.persistence.descriptors.CMPPolicy.KeyIsElementAccessor
 
setValue(String) - Method in class org.eclipse.persistence.internal.oxm.XPathPredicate
 
setValue(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.property.PropertyConfig
 
setValue(DatabaseTypeWrapper) - Method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1.ObjectTypeFieldAssociation
 
setValue(T) - Method in class org.eclipse.persistence.indirection.ValueHolder
PUBLIC: Set the wrapped object.
setValue(T) - Method in interface org.eclipse.persistence.indirection.ValueHolderInterface
PUBLIC: Set the value.
setValue(T) - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Set the object.
setValue(T) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkQueryValueHolder
Ensure that the backup value holder is populated.
setValue(T) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkTransformerValueHolder
Ensure that the backup value holder is populated.
setValue(T) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Set the object.
setValueByXPath(Object, String, NAMESPACE_RESOLVER, Object) - Method in class org.eclipse.persistence.internal.oxm.Context
Set values in the object model based on the corresponding document.
setValueByXPath(Object, String, NamespaceResolver, Object) - Method in class org.eclipse.persistence.oxm.XMLContext
Set values in the object model based on the corresponding XML document.
setValueClass(Class<?>) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
PUBLIC: This is a helper method to set the value converter to a TypeConversionConverter.
setValueConverter(CONVERTER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
Set the converter on the mapping.
setValueConverter(CONVERTER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
Set the converter on the mapping.
setValueConverter(Converter) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Set the converter on the mapping.
setValueConverter(Converter) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
PUBLIC: Set the converter on the mapping.
setValueConverter(Converter) - Method in class org.eclipse.persistence.queries.DirectReadQuery
PUBLIC: Set the converter on the query.
setValueConverterClassName(String) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: Set the converter class name on the mapping.
setValueHolder(ValueHolderInterface<C>) - Method in interface org.eclipse.persistence.indirection.IndirectContainer
PUBLIC: Set the valueHolder.
setValueHolder(ValueHolderInterface<List<E>>) - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Set the value holder.
setValueHolder(ValueHolderInterface<Map<K, V>>) - Method in class org.eclipse.persistence.indirection.IndirectMap
INTERNAL: Set the value holder.
setValueHolder(ValueHolderInterface<Set<E>>) - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Set the value holder.
setValueHolder(ValueHolderInterface<T>) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionHandler
INTERNAL: Set the ValueHolder associated with this handler.
setValueInField(Field, Object, Object) - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
Set the value of a given field in the given object with the value given.
setValueInRecord(String, Object, MappedRecord, EISAccessor) - Method in class org.eclipse.persistence.eis.EISPlatform
Stores the field value into the record.
setValueMapping(MapComponentMapping) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
 
setValues(Vector) - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
 
setValues(Vector) - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
 
setValues(Vector) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Setting values vector will not update the document so this is not supported
setValuesToExclude(Map) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: Decides which attributes to ignore based on the values they are set to.
setValueType(Class<?>) - Method in class org.eclipse.persistence.internal.descriptors.VirtualAttributeAccessor
Override the class of the values being stored.
setValueType(Class<?>) - Method in class org.eclipse.persistence.mappings.TypedAssociation
PUBLIC: Set the class of the value.
setValueWrapper(String) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Name of the property to marshal/unmarshal as a wrapper on the text() mappings Ignored marshalling XML.
setValueWrapper(String) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Name of the property to marshal/unmarshal as a wrapper on the text() mappings Ignored unmarshalling XML.
setVariableAttributeAccessor(ATTRIBUTE_ACCESSOR) - Method in interface org.eclipse.persistence.internal.oxm.mappings.VariableXPathObjectMapping
 
setVariableAttributeAccessor(AttributeAccessor) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
setVariableAttributeAccessor(AttributeAccessor) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
setVariableAttributeName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.VariableXPathObjectMapping
 
setVariableAttributeName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
setVariableAttributeName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
setVariableGetMethodName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.VariableXPathObjectMapping
 
setVariableGetMethodName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
setVariableGetMethodName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
setVariables(List<FieldDefinition>) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
The variables are the field defs of the declared variables used in the procedure.
setVariableSetMethodName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.VariableXPathObjectMapping
 
setVariableSetMethodName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
setVariableSetMethodName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
setVersion(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
INTERNAL:
setVersion(String) - Method in class org.eclipse.persistence.internal.oxm.Root
Sets the version.
setVersion(String) - Method in class org.eclipse.persistence.internal.sessions.factories.model.SessionConfigs
 
setVersion(String) - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
setViewTable(DatabaseTable) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: This expression represents something read through a view table.
setVirtualAttributeMethods(List<VirtualAttributeMethodInfo>) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the list of methods used my mappings with virtual access this list is used to determine which methods to weave
setVisitedObjects(Map) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setVisitedStack(Stack) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
setVPDIdentifier(String) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set the VPD identifier for this project.
setVPDLastIdentifierClassName(String) - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Set from individual descriptors from the project that set a VPD identifier and used in validation exception.
setWaitTimeout(int) - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
PUBLIC: Set the time in milliseconds to wait for an available connection.
setWaitTimeout(Integer) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Sets that this a pessimistic wait locking query.
setWaitTimeoutUnit(TimeUnit) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
setWarnOnUnmappedElement(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
INTERNAL: Set to true if a warning exception should be generated when an unmapped element is encountered, false otherwise.
setWasAdditionJoinCriteriaUsed(boolean) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: If the additional Join Criteria for the class this builder represents has been added to the statement then mark this as true.
setWasDefaultLockMode(boolean) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Set if this query originally used the default lock mode.
setWasJTSTransactionInternallyStarted(boolean) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return if a JTS transaction was started by the session.
setWasNonObjectLevelModifyQueryExecuted(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: True if either DataModifyQuery or ModifyAllQuery was executed.
setWasOperationSuccessful(boolean) - Method in class org.eclipse.persistence.internal.sessions.remote.Transporter
Set whether the operation which caused this transporter to be returned was successful.
setWasTransactionBegunPrematurely(boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Set a flag in the root UOW to indicate that a pess.
setWeight(Integer) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: Set the weight of the mapping, used to sort mappings DirectToField Mappings have a default weight of 1 while all other Mappings have a default weight of MAXINT.
setWhereClause(Expression) - Method in class org.eclipse.persistence.internal.expressions.SQLStatement
 
setWhitespacePreserving(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
setWhitespacePreserving(boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
setWhitespacePreserving(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
setWhitespacePreserving(boolean) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
setWithAllSubclassesExpression(Expression) - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
ADVANCED: Sets the expression to be used for querying for a class and all its subclasses.
setWorkingCopyMethod(Method) - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Set the workingCopyClone method.
setWorkingCopyMethodName(String) - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
Set the workingCopyClone method name.
setWrappedDatabaseType(DatabaseType) - Method in class org.eclipse.persistence.internal.sessions.factories.DatabaseTypeWrapper
 
setWrappedServerValueHolder(ValueHolderInterface<T>) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Set the original value holder.
setWrappedValueHolder(DatabaseValueHolder<T>) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
setWrapper(Object) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
setWrapper(Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
setWrapper(Object, Class<?>, Object) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Update the wrapper object the cache key associated with the given primary key, this is used for EJB.
setWrapper(Object, Class<?>, Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: Update the wrapper object the cache key associated with the given primary key, this is used for EJB.
setWrapper(Object, Class<?>, Object) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
INTERNAL: Update the wrapper object the cache key associated with the given primary key, this is used for EJB.
setWrapper(Object, Object) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Update the wrapper object in the CacheKey associated with the given primaryKey, this is used for EJB2.
setWrapper(Object, Object) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Update the wrapper object in the CacheKey associated with the given primaryKey, this is used for EJB2.
setWrapper(Object, Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Update the wrapper object in the CacheKey associated with the given primaryKey, this is used for EJB2.
setWrapperAsCollectionName(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
setWrapperAsCollectionName(boolean) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
setWrapperNullPolicy(AbstractNullPolicy) - Method in interface org.eclipse.persistence.internal.oxm.mappings.XMLContainerMapping
Set the Wrapper NullPolicy on the Mapping.
setWrapperNullPolicy(AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
setWrapperNullPolicy(AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
setWrapperNullPolicy(AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
setWrapperNullPolicy(AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
 
setWrapperNullPolicy(AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
setWrapperNullPolicy(AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
setWrapperNullPolicy(AbstractNullPolicy) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
 
setWrapperPolicy(WrapperPolicy) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: Sets the WrapperPolicy for this descriptor.
setWriteConnection(Accessor) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Set the connection to be used for database modification.
setWriteConnectionPoolConfig(WriteConnectionPoolConfig) - Method in class org.eclipse.persistence.internal.sessions.factories.model.pool.PoolsConfig
 
setWriteConnections(Map<String, Accessor>) - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Set the connection to be used for database modification.
setWriteLockField(DatabaseField) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
ADVANCED: Set the write lock field.
setWriteLockFieldName(String) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
PUBLIC: Set the write lock field name.
setWriteLockQueued(Object) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTENRAL: Used to set the object that the merge manager is waiting on, in order to acquire locks If this value is null then the merge manager is not waiting on any locks.
setWriteLockValue(Object) - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
setWriteLockValue(Object) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
ADVANCED: This method is used to set the writeLock value for an ObjectChangeSet Any changes to the write lock value should to through setWriteLockValue(Object obj) so that the change set is marked as being dirty.
setWriteLockValue(Object) - Method in class org.eclipse.persistence.internal.sessions.remote.ObjectDescriptor
Set write lock value of an associated object
setWriteLockValue(Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
setWriteLockValue(Object, Class<?>, Object) - Method in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Update the write lock value of the cache key associated with the given primary key,
setWriteLockValue(Object, Object) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
Update the write lock value of the CacheKey associated with the given primaryKey.
setWriteLockValue(Object, Object) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
Update the write lock value of the CacheKey associated with the given primaryKey.
setWriteLockValue(Object, Object) - Method in class org.eclipse.persistence.internal.identitymaps.NoIdentityMap
Do Nothing.
setWriteLockValue(Object, Object) - Method in class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
Avoid acquiring any lock as uow is single threaded.
setWriteLockValue(Object, Object) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
Update the write lock value of the CacheKey associated with the given primaryKey.
setWriter(OutputStream) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
setWriter(OutputStream) - Method in class org.eclipse.persistence.logging.JavaLog
PUBLIC:
setWriter(Writer) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
setWriter(Writer) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
setWriter(Writer) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Set the writer to which an accessor writes logged messages and SQL.
setWriter(Writer) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
Set the Writer that the object will be marshalled to.
setWriter(Writer) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
Set the Writer that the object will be marshalled to.
setWriter(String) - Method in class org.eclipse.persistence.logging.DefaultSessionLog
Set the writer that will receive the formatted log entries for a file name.
setXMLBinaryDataHelper(XMLBinaryDataHelper) - Static method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
setXMLContext(CONTEXT) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
Set the XMLContext used by this instance of XMLUnmarshaller.
setXMLContext(XMLContext) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
Set the XMLContext used by this instance of XMLMarshaller.
setXMLContext(XMLContext) - Method in class org.eclipse.persistence.oxm.XMLUnmarshaller
Set the XMLContext used by this instance of XMLUnmarshaller.
setXMLContextState(XMLContext.XMLContextState) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL: Set the stateful information for this XMLContext.
setXmlEventReader(XMLEventReader) - Method in class org.eclipse.persistence.internal.oxm.record.XMLEventReaderInputSource
 
setXMLEventWriter(XMLEventWriter) - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
setXmlField(XML_FIELD) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceFieldToClassAssociation
 
setXMLField(Field) - Method in class org.eclipse.persistence.internal.oxm.FieldTransformerNodeValue
 
setXMLField(Field) - Method in class org.eclipse.persistence.oxm.record.XMLEntry
 
setXMLField(XML_FIELD) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setXmlHeader(String) - Method in class org.eclipse.persistence.internal.oxm.XMLMarshaller
Set this Marshaller's XML Header.
setXMLMarshalHandler(XMLMarshalListener) - Method in class org.eclipse.persistence.oxm.XMLMarshaller
 
setXMLPlatformClass(Class<? extends XMLPlatform>) - Method in class org.eclipse.persistence.platform.xml.XMLPlatformFactory
PUBLIC: Set the implementation of XMLPlatform.
setXMLReader(XMLReader) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
setXMLReader(XMLReader) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
setXMLReader(XMLReader) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
setXMLReader(XMLReader) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
setXMLSchema(URL) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
setXMLSchema(Schema) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
setXMLSchemas(Object[]) - Method in interface org.eclipse.persistence.platform.xml.XMLParser
 
setXmlStreamReader(XMLStreamReader) - Method in class org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceContext
 
setXmlStreamReader(XMLStreamReader) - Method in class org.eclipse.persistence.internal.oxm.record.XMLStreamReaderInputSource
 
setXMLStreamWriter(XMLStreamWriter) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
setXmlType(QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionPair
 
setXMLVersion(String) - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader.LocatorImpl
 
setXOPPackage(boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
setXOPPackage(boolean) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
setXOPPackage(boolean) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
setXOPPackage(boolean) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
 
setXPath(String) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeCollectionMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeDirectCollectionMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeObjectMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in class org.eclipse.persistence.eis.mappings.EISDirectMapping
Set the Mapping field name attribute to the given XPath String.
setXPath(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeObjectMapping
 
setXPath(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Set the xpath statment for this XMLField.
setXPath(String) - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
setXPath(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
setXPath(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
setXPath(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
setXPath(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
Set the Mapping field name attribute to the given XPath String
setXPath(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentMapping
 
setXPath(String) - Method in class org.eclipse.persistence.oxm.XMLField
Set the xpath statment for this XMLField.
setXPathFragment(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
setXPathFragment(XPathFragment) - Method in class org.eclipse.persistence.internal.oxm.XPathPredicate
 
setXPathFragment(XPathFragment) - Method in class org.eclipse.persistence.oxm.XMLField
INTERNAL: Return the first XPathFragment.
setXPathInObject(String, String, Object) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathMappingNodeValue
 
setXPathNode(XPathNode) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
 
setXPathNode(XPathNode) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
setXPathNode(XPathNode) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
setXPathNode(XPathNode) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceObjectMappingNodeValue
 
setXPathNode(XPathNode) - Method in class org.eclipse.persistence.internal.oxm.XMLDirectMappingNodeValue
 
setXQueryString(String) - Method in class org.eclipse.persistence.eis.interactions.XQueryInteraction
PUBLIC: Set the XQuery string.
severe(String) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
severe(String) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: This method is called when a severe level message needs to be logged.
severe(String, String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
SEVERE - org.eclipse.persistence.logging.LogLevel
Fatal exceptions.
SEVERE - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
SEVERE_LABEL - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
SEVERE_PREFIX - Static variable in class org.eclipse.persistence.logging.AbstractSessionLog
Represents prefix to logged severe
shallowClone() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL:
shallowClone() - Method in class org.eclipse.persistence.internal.expressions.BaseExpression
INTERNAL: Clear the builder when cloning.
shallowClone() - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: Clear the builder when cloning.
shallowCommits - Variable in class org.eclipse.persistence.internal.sessions.CommitManager
Set of objects that had partial row written to resolve constraints.
shallowCopy(DiscoveryManager) - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
INTERNAL: invoke when the RCM shutdown.
shallowInsertObjectForWrite(Object, WriteObjectQuery, CommitManager) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Shallow insert the specified object, if necessary.
shallowMergeClone(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Merge the attributes of the clone into the unit of work copy.
shallowMergeClone(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Merge the attributes of the clone into the unit of work copy.
shallowRevertObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Revert the object's attributes from the parent.
shallowRevertObject(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
PUBLIC: Revert the object's attributes from the parent.
shallowUnregisterObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Unregister the object with the unit of work.
shallowUnregisterObject(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Unregister the object with the unit of work.
SHARED - org.eclipse.persistence.config.CacheIsolationType
Entity instances will be cached within the EntityManagerFactory/ServerSession level.
SHARED_CACHE_MODE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.sharedCache.mode" property determines whether second-level caching is in effect for the persistence unit.
SHARED_DESCRIPTOR_ALIAS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
sharedDescriptorAlias(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
shift - Static variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
 
SHORT - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
SHORT - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
SHORT_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
shortenStringsByRemovingVowelsToFit(String, String, int) - Static method in class org.eclipse.persistence.internal.helper.Helper
Returns a String which is a concatenation of two string which have had enough vowels removed from them so that the sum of the sized of the two strings is less than or equal to the specified size.
shortestTime - Variable in class org.eclipse.persistence.tools.profiler.Profile
 
SHOULD_IGNORE_EXCEPTION_RETURN_CONFORMED - Static variable in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
If a non-instantiated indirection object is encountered the object is assumed to conform.
SHOULD_IGNORE_EXCEPTION_RETURN_NOT_CONFORMED - Static variable in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
If a non-instantiated indirection object is encountered the object is assumed to not conform.
SHOULD_THROW_INDIRECTION_EXCEPTION - Static variable in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
If a non-instantiated indirection object is encountered an exception is thrown.
SHOULD_TRIGGER_INDIRECTION - Static variable in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
If a non-instantiated indirection object is encountered an exception it is instantiated.
SHOULD_USE_DEFERRED_LOCKS - Static variable in class org.eclipse.persistence.internal.helper.DeferredLockManager
 
shouldAcquireCascadedLocks - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
PERF: Used to optimize cache locking to only acquire deferred locks when required (no-indirection).
shouldAcquireCascadedLocks() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: PERF: Return if deferred locks should be used.
shouldAcquireValueAfterInsert - Variable in class org.eclipse.persistence.sequencing.QuerySequence
 
shouldAcquireValueAfterInsert() - Method in class org.eclipse.persistence.sequencing.DefaultSequence
INTERNAL: Indicates whether sequencing value should be acquired after INSERT.
shouldAcquireValueAfterInsert() - Method in class org.eclipse.persistence.sequencing.QuerySequence
PUBLIC:
shouldAcquireValueAfterInsert() - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: Indicates whether sequencing value should be acquired after INSERT.
shouldAcquireValueAfterInsert() - Method in class org.eclipse.persistence.sequencing.StandardSequence
 
shouldAcquireValueAfterInsert() - Method in class org.eclipse.persistence.sequencing.UUIDSequence
 
shouldAddAll() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Indicates whether addAll method should be called to add entire collection, or it's possible to call addInto multiple times instead.
shouldAddAll() - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Indicates whether addAll method should be called to add entire collection, or it's possible to call addInto multiple times instead.
shouldAllowConcurrentReadWrite() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Used for cache isolation.
shouldAllowConcurrentReadWrite() - Method in interface org.eclipse.persistence.sessions.Login
INTERNAL: Used for cache isolation.
shouldAllowInstantiationDeferral - Variable in class org.eclipse.persistence.internal.indirection.CacheBasedValueHolder
Setting to force the instantiation of the Collection on modification
shouldAllowInstantiationDeferral() - Method in class org.eclipse.persistence.indirection.ValueHolder
INTERNAL: Return if add/remove should trigger instantiation or avoid.
shouldAllowInstantiationDeferral() - Method in interface org.eclipse.persistence.indirection.WeavedAttributeValueHolderInterface
INTERNAL: Return if add/remove should trigger instantiation or avoid.
shouldAllowInstantiationDeferral() - Method in class org.eclipse.persistence.internal.indirection.CacheBasedValueHolder
INTERNAL: Return if add/remove should trigger instantiation or avoid.
shouldAllowInstantiationDeferral() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
INTERNAL: Return if add/remove should trigger instantiation or avoid.
shouldAllowInstantiationDeferral() - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
INTERNAL: Return if add/remove should trigger instantiation or avoid.
shouldAllowNativeSQLQuery(boolean) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Return true if this individual query should allow native a SQL call to be issued.
shouldAllowNull - Variable in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
shouldAllowNull - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
shouldAllowNull() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
Return if this type is allowed to be null for this platform
shouldAllowNull() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
PUBLIC: Return whether the receiver should allow null values.
shouldAlwaysConformResultsInUnitOfWork - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
shouldAlwaysConformResultsInUnitOfWork() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return if the descriptor is defined to always conform the results in unit of work in read query.
shouldAlwaysOverrideExistingValue - Variable in class org.eclipse.persistence.sequencing.Sequence
 
shouldAlwaysOverrideExistingValue() - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: Indicates whether the existing pk value should always be overridden by the sequence.
shouldAlwaysOverrideExistingValue(String) - Method in class org.eclipse.persistence.sequencing.DefaultSequence
INTERNAL: Indicates whether the existing pk value should always be overridden by the sequence.
shouldAlwaysOverrideExistingValue(String) - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: Indicates whether the existing pk value should always be overridden by the sequence.
shouldAlwaysRefreshCache - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
shouldAlwaysRefreshCache() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: This method returns true if the ClassDescriptor is configured to always refresh the cache if data is received from the database by any query.
shouldAlwaysRefreshCache() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This method returns true if the ClassDescriptor is configured to always refresh the cache if data is received from the database by any query.
shouldAlwaysRefreshCacheOnRemote - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
shouldAlwaysRefreshCacheOnRemote() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: This method returns true if the ClassDescriptor is configured to always remotely refresh the cache if data is received from the database by any query in a RemoteSession.
shouldAlwaysRefreshCacheOnRemote() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This method returns true if the ClassDescriptor is configured to always remotely refresh the cache if data is received from the database by any query in a RemoteSession.
shouldAlwaysUseExclusiveConnection - Variable in class org.eclipse.persistence.internal.sessions.ExclusiveIsolatedClientSession
If true all classes are read through the exclusive connection, otherwise only the isolated ones.
shouldAlwaysUseOuterJoin - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
shouldAlwaysUseOuterJoin() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: returns if the inheritance policy will always use an outerjoin when selecting class type
shouldAlwaysUseTempStorageForModifyAll() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: That method affects UpdateAllQuery and DeleteAllQuery execution.
shouldAlwaysUseTempStorageForModifyAll() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
shouldAlwaysUseTempStorageForModifyAll() - Method in class org.eclipse.persistence.platform.database.Informix11Platform
Returns true when invoked to force Informix to use temporary storage when constructing bulk UPDATE statements.
shouldAlwaysUseTempStorageForModifyAll() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
shouldAlwaysUseTempStorageForModifyAll() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL supports temp tables for update-all, delete-all queries.
shouldAlwaysUseTempStorageForModifyAll() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Symfoware does not support the default syntax generated for update-all and delete-all queries as they can include the same table in the FROM clause of the main and the sub-queries.
shouldAssumeExistenceForDoesExist() - Method in class org.eclipse.persistence.queries.DoesExistQuery
PUBLIC: Returns true if the does exist check should be based only on whether the primary key of the object is set
shouldAssumeNonExistenceForDoesExist() - Method in class org.eclipse.persistence.queries.DoesExistQuery
PUBLIC: Returns true if the does exist check should assume non existence.
shouldAvoidInstantiation() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Return if add/remove should trigger instantiation or avoid.
shouldAvoidInstantiation() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Return if add/remove should trigger instantiation or avoid.
shouldBeDeleted - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
shouldBeDeleted() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Mark change set for a deleted object.
shouldBeReadOnly - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
shouldBeReadOnly() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return if the descriptor reference class is defined as read-only
shouldBindAllParameters - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Bind all arguments to any SQL statement.
shouldBindAllParameters - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Bind all arguments to the SQL statement.
shouldBindAllParameters() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Bind all arguments to any SQL statement.
shouldBindAllParameters() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Bind all arguments to any SQL statement.
shouldBindAllParameters() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Bind all arguments to any SQL statement.
shouldBindLiterals - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allow user to require literals to be bound.
shouldBindLiterals() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
PUBLIC: Allows platform to choose whether to bind literals in DatabaseCalls or not.
shouldBindLiterals() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
shouldBindLiterals() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
shouldBindLiterals() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Allows platform to choose whether to bind literals in SQL statements or not.
Literal binding is enabled for Symfoware in general.
shouldBindPartialParameters - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Bind some arguments to any SQL statement.
shouldBindPartialParameters() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used to determine if the platform should perform partial parameter binding or not
shouldBindPartialParameters() - Method in class org.eclipse.persistence.platform.database.DB2Platform
Used to determine if the platform should perform partial parameter binding or not Enabled for DB2 and DB2 for zOS to add support for partial binding
shouldBreak - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldBreak() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldBuildDeleteStatementForMapping(ForeignReferenceMapping, boolean, ClassDescriptor) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
 
shouldBuildNullForNullPk - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: If primary key is null ObjectBuilder.buildObject returns null in case this flag is set to true (instead of throwing exception).
shouldBuildNullForNullPk() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: If primary key is null ObjectBuilder.buildObject returns null in case this flag is set to true (instead of throwing exception).
shouldBuildOutputRow - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
shouldBuildOutputRow() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Set whether the call has to build output row
shouldCacheAllStatements - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Cache all prepared statements, this requires full parameter binding as well.
shouldCacheAllStatements() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Cache all prepared statements, this requires full parameter binding as well.
shouldCacheAllStatements() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Cache all prepared statements, this requires full parameter binding as well.
shouldCacheFieldAliases - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
shouldCacheQueryResults() - Method in class org.eclipse.persistence.queries.ReadQuery
PUBLIC: Return if the query should cache the results of the next execution or not.
shouldCacheStatement - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
shouldCacheStatement - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Cache the prepared statement, this requires full parameter binding as well.
shouldCacheStatement() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Cache the prepared statements, this requires full parameter binding as well.
shouldCacheStatement(DatabasePlatform) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Bound calls can use prepared statement caching.
shouldCacheStatement(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Bound calls can use prepared statement caching.
shouldCascade() - Method in class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: Return true if has been configured to CASCADE_ALL_PARTS or CASCADE_PRIVATE_PARTS.
shouldCascadeAllParts() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldCascadeAllParts() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Flag used to determine if all parts should be cascaded
shouldCascadeAllParts() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Flag used to determine if all parts should be cascaded
shouldCascadeAllParts() - Method in class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: Return true if should CASCADE_ALL_PARTS
shouldCascadeByMapping() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Flag used to determine that the mappings should be checked for cascade requirements.
shouldCascadeByMapping() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Mappings should be checked to determined if the current operation should be cascaded to the objects referenced.
shouldCascadeCloneToJoinedRelationship - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
True if the value holder for the joined attribute should be triggered.
shouldCascadeCloneToJoinedRelationship() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: True if the value holder for the joined attribute should be triggered.
shouldCascadeNoParts() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldCascadeOnDelete - Variable in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
shouldCascadeOnDelete() - Method in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
shouldCascadeOnlyDependentParts() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Flag used for unit of works cascade policy.
shouldCascadeParts() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Flag used to determine if any parts should be cascaded
shouldCascadeParts() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Flag used to determine if any parts should be cascaded
shouldCascadePrivateParts() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldCascadePrivateParts() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Flag used to determine if any private parts should be cascaded
shouldCascadePrivateParts() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Flag used to determine if any private parts should be cascaded
shouldCascadePrivateParts() - Method in class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: Return true if should CASCADE_PRIVATE_PARTS
shouldCascadeReferences() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
Refreshes are based on the objects row, so all attributes of the object must be refreshed.
shouldCascadeTree() - Method in class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: Return true if should CASCADE_TREE
shouldCatchExceptions - Variable in class org.eclipse.persistence.exceptions.IntegrityChecker
To know that should we catch all the descriptors exceptions or not
shouldCatchExceptions() - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: This method signifies whether all Descriptor Exceptions should be thrown individually or queued.
shouldCheckCache() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Return if the cache should be checked.
shouldCheckCacheByExactPrimaryKey() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return if cache should be checked.
shouldCheckCacheByPrimaryKey() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return if cache should be checked.
shouldCheckCacheForDoesExist() - Method in class org.eclipse.persistence.queries.DoesExistQuery
PUBLIC: Returns true if the does exist check should be based only on a cache check.
shouldCheckCacheOnly() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Return if cache should be checked.
shouldCheckCacheThenDatabase() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: Return if cache should be checked.
shouldCheckClassLoader - Variable in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
Defines if the session will be refreshed from the file if the class loader requesting the load is different than the loaded session's class loader.
shouldCheckClassLoader() - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: Return if the session will be refreshed from the file if the class loader requesting the load is different than the loaded session's class loader.
shouldCheckConnection - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Back-door to allow isConnect checks.
shouldCheckDatabase - Variable in class org.eclipse.persistence.exceptions.IntegrityChecker
To know that should we check database tables or not
shouldCheckDatabase() - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: This method signifies whether database tables and fields should be checked or not.
shouldCheckDatabaseForDoesExist() - Method in class org.eclipse.persistence.queries.DoesExistQuery
PUBLIC: Returns true if the does exist check should query the database.
shouldCheckDescriptorForCacheUsage() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Return whether the descriptor's disableCacheHits setting should be checked prior to querying the cache.
shouldCheckInstantiationPolicy - Variable in class org.eclipse.persistence.exceptions.IntegrityChecker
To know that should we check InstantiationPolicy or not
shouldCheckInstantiationPolicy() - Method in class org.eclipse.persistence.exceptions.IntegrityChecker
PUBLIC: This method tells us whether we should check InstantiationPolicy or not.
shouldCheckReadLocks - Variable in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMapEnumeration
Value of true if readLocks should be checked or false otherwise.
shouldCheckServiceId() - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL: Return whether a BroadcastConnection should check a ServiceId against its own ServiceId to avoid the processing of Commands with the same ServiceId.
shouldCheckServiceId() - Method in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
INTERNAL: Return whether a BroadcastConnection should check a ServiceId against its own ServiceId to avoid the processing of Commands with the same ServiceId.
shouldCheckWriteLock - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
PERF: Cache the write-lock check to avoid cost of checking in every register/clone.
shouldClearForCloseOnRelease() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Indicates whether clearForClose method should be called by release method.
shouldClearForCloseOnRelease() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Indicates whether clearForClose method should be called by release method.
shouldClearStatementCache - Variable in class org.eclipse.persistence.platform.server.wls.WebLogicPlatform
Indicates whether WLConnection.clearStatementCache() should be called: there is no need to call it in WebLogic Server 10.3.4 or later.
shouldCloneCall - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Used to indicate whether or not the call needs to be cloned.
shouldCloneCall() - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Flag used to determine if the call needs to be cloned.
shouldCompareExistingObjectForChange(Object, UnitOfWorkImpl, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: Return true if the Object should be compared, false otherwise.
shouldCompareExistingObjectForChange(Object, UnitOfWorkImpl, ClassDescriptor) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: Return true if the Object should be compared, false otherwise.
shouldCompareExistingObjectForChange(Object, UnitOfWorkImpl, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.changetracking.ObjectChangeTrackingPolicy
INTERNAL: Return true if the Object should be compared, false otherwise.
shouldConformResultsInUnitOfWork() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Should the results will be checked against the changes within the unit of work and object no longer matching or deleted will be remove, matching new objects will also be added..
shouldConvertDataToStrings - Variable in class org.eclipse.persistence.eis.EISPlatform
Can be used for adapters that only support String data/XML.
shouldConvertDataToStrings() - Method in class org.eclipse.persistence.eis.EISPlatform
Return if all data set into the adapter should be first converted to strings.
shouldCreateDatabaseSchema(Set<String>) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Subclasses who care should override this method, e.g.
shouldCreateDatabaseSchema(Set<String>) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
If this table has a schema (and catalog specified) make sure it is created.
shouldCreateDatabaseSchema(DatabaseObjectDefinition, Set<String>) - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
INTERNAL: Returns true if a database schema should be created during ddl generation for the given databaseObjectDefinition.
shouldCreateIndicesForPrimaryKeys() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for table creation.
shouldCreateIndicesForPrimaryKeys() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Used for table creation.
shouldCreateIndicesOnForeignKeys - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allows auto-indexing for foreign keys to be set.
shouldCreateIndicesOnForeignKeys() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for table creation.
shouldCreateIndicesOnForeignKeys() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Used for table creation.
shouldCreateIndicesOnUniqueKeys() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for table creation.
shouldCreateIndicesOnUniqueKeys() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Used for table creation.
shouldCreateVPDCalls(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
INTERNAL: Subclasses who care should override this method.
shouldCreateVPDCalls(AbstractSession) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
INTERNAL: Subclasses who care should override this method.
shouldDeferExecutionInUOW() - Method in class org.eclipse.persistence.queries.ModifyAllQuery
PUBLIC: Indicates whether execution should be deferred in UOW until commit.
shouldDeferInsert() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
 
shouldDeferInsert() - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
 
shouldDeferInserts - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
 
shouldDisableCacheHits - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
shouldDisableCacheHits() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Return if for cache hits on primary key read object queries to be disabled.
shouldDisableCacheHits() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return if for cache hits on primary key read object queries to be disabled.
shouldDisableCacheHitsOnRemote - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
shouldDisableCacheHitsOnRemote() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Return if the remote server session cache hits on primary key read object queries is aloowed or not.
shouldDisableCacheHitsOnRemote() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return if the remote server session cache hits on primary key read object queries is aloowed or not.
shouldDiscoverNewObjects - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PERF: Allows discover new objects to be skipped if app always calls persist.
shouldDiscoverNewObjects() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Set if this UnitofWork should discover new objects on commit.
shouldDiscoverUnregisteredNewObjectsWithoutPersist() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
 
shouldDisplayData - Variable in class org.eclipse.persistence.logging.AbstractSessionLog
Used to determine if bingdparameters should be logged or hidden.
shouldDisplayData() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return true if SQL logging should log visible bind parameters.
shouldDisplayData() - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC: Return true if SQL logging should log visible bind parameters.
shouldDisplayData() - Method in interface org.eclipse.persistence.logging.SessionLog
Return whether bind parameters should be displayed when logging SQL, default is true.
shouldDistinctBeUsed() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL: If a distinct has been set the DISTINCT clause will be printed.
shouldDistinctBeUsed() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: return true if this query should use a distinct
shouldDropTableDefinition() - Method in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
INTERNAL: Returns true if the table definition should be dropped during buildDeletionWriter.
shouldEnableDistributedIndirectionGarbageCollection - Variable in class org.eclipse.persistence.sessions.remote.RemoteSession
 
shouldEnableDistributedIndirectionGarbageCollection() - Method in class org.eclipse.persistence.sessions.remote.RemoteSession
ADVANCED: Allow the server-side value holders to be cleaned-up when the client-side value holder finalize.
shouldExecuteLocally(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.ExclusiveIsolatedClientSession
INTERNAL: Helper method to calculate whether to execute this query locally or send it to the server session.
shouldExecuteLocally(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSession
INTERNAL: Helper method to calculate whether to execute this query locally or send it to the server session.
shouldExecuteSelectNodes() - Method in class org.eclipse.persistence.internal.oxm.XPathFragment
 
shouldExtendPessimisticLockScope - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Indicates whether pessimistic lock should also be applied to relation tables (ManyToMany and OneToOne mappings), reference tables (DirectCollection and AggregateCollection mapping).
shouldExtendPessimisticLockScope() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Indicates whether pessimistic lock of ObjectLevelReadQuery with isPessimisticLockScopeExtended set to true should be applied through this mapping beyond the tables mapped to the source object.
shouldExtendPessimisticLockScope() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Indicates whether pessimistic lock should also be applied to relation tables (ManyToMany and OneToOne mappings), reference tables (DirectCollection and AggregateCollection mapping).
shouldExtendPessimisticLockScopeInDedicatedQuery() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
 
shouldExtendPessimisticLockScopeInSourceQuery() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
 
shouldExtendPessimisticLockScopeInTargetQuery() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
 
shouldExtractWhereClauseFromSelectCallForExist - Variable in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
shouldExtractWhereClauseFromSelectCallForExist - Variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
shouldExtractWhereClauseFromSelectCallForExist() - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
shouldExtractWhereClauseFromSelectCallForExist() - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
shouldFilterDuplicates - Variable in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Determine if duplicate rows should be filter when using 1-m joining.
shouldFilterDuplicates() - Method in class org.eclipse.persistence.internal.queries.JoinedAttributeManager
Return if duplicate rows should be filter when using 1-m joining.
shouldFilterDuplicates() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Return if duplicate rows should be filter when using 1-m joining.
shouldForceBindAllParameters - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Bind all arguments to any SQL statement.
shouldForceBindAllParameters() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used to enable parameter binding and override platform default
shouldForceCascade() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
This is used to cascade merge even if a clone is already registered.
shouldForceFieldNamesToUpperCase - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Can be used if the app expects upper case but the database is not return consistent case, i.e.
shouldForceFieldNamesToUpperCase() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Can be used if the app expects upper case but the database is not return consistent case, i.e.
shouldForceFieldNamesToUpperCase() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
ADVANCED: Can be used if the app expects upper case but the database is not return consistent case, i.e.
shouldForceInitializationOfSelectionCriteria() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL:
shouldForceReadFromDB(ObjectBuildingQuery, Object) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Calculate whether we should read directly from the database to the UOW.
shouldForceReadFromDB(ObjectBuildingQuery, Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Calculate whether we should read directly from the database to the UOW.
shouldHandleUnmappedFields() - Method in class org.eclipse.persistence.internal.descriptors.CascadeLockingPolicy
INTERNAL:
shouldHandleWrites - Variable in class org.eclipse.persistence.history.HistoryPolicy
 
shouldHandleWrites() - Method in class org.eclipse.persistence.history.HistoryPolicy
Answers if TopLink is responsible for writing history.
shouldIgnoreBindAllParameters() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Local shouldBindAllParameters() should be ignored, Session's shouldBindAllParameters() should be used.
shouldIgnoreCacheStatement() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Local shouldCacheStatement() should be ignored, Session's shouldCacheAllStatements() should be used.
shouldIgnoreCaseOnFieldComparisons - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allow for case in field names to be ignored as some databases are not case sensitive and when using custom this can be an issue.
shouldIgnoreCaseOnFieldComparisons() - Static method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allow for case in field names to be ignored as some databases are not case sensitive and when using custom this can be an issue.
shouldIgnoreCaseOnFieldComparisons() - Static method in class org.eclipse.persistence.sessions.DatabaseLogin
ADVANCED: Allow for case in field names to be ignored as some databases are not case sensitive.
shouldIgnoreDatabaseException() - Method in class org.eclipse.persistence.tools.schemaframework.TableCreator
Return true if DatabaseException is to be ignored.
shouldIgnoreException(SQLException) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allow for the platform to ignore exceptions.
shouldIgnoreException(SQLException) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Allow for the platform to ignore exceptions.
shouldIgnoreException(SQLException) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Allow for the platform to ignore exceptions.
shouldIgnoreFirstRowSetting() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Returns the ignoreFirstRowSetting flag.
shouldIgnoreIndirectionExceptionReturnConformed() - Method in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
shouldIgnoreIndirectionExceptionReturnNotConformed() - Method in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
shouldIgnoreMaxResultsSetting() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Returns the ignoreMaxResultsSetting flag.
shouldIncludeAllSubclassFields(SQLSelectStatement) - Method in class org.eclipse.persistence.internal.queries.ExpressionQueryMechanism
Return whether to include all subclass fields in select statement or not.
shouldIncludeData - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Allow for a complex result to be return including the rows and objects, used for m-m batch reading.
shouldIncludeData() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return if the rows for the result of the query should also be returned using a complex query result.
shouldIncludeInQuery(Class<?>, String, Object) - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
INTERNAL: This method determines whether an attribute pair is be included in the query.
shouldIncludeKeyInDeleteEvent() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return whether data for a map key must be included on a Delete data modification event This will be overridden by subclasses that handle maps.
shouldIncludeKeyInDeleteEvent() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Return whether data for a map key must be included on a Delete datamodification event If the keyMapping is privateOwned, that data should be.
shouldIncrementTargetLockValueOnAddOrRemoveTarget - Variable in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
Indicates whether target's optimistic locking value should be incremented on target being added to / removed from a source.
shouldIncrementTargetLockValueOnAddOrRemoveTarget() - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
PUBLIC: Indicates whether target's optimistic locking value should be incremented on target being added to / removed from a source (default value is true).
shouldIncrementTargetLockValueOnDeleteSource - Variable in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
Indicates whether target's optimistic locking value should be incremented on the source deletion.
shouldIncrementTargetLockValueOnDeleteSource() - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
PUBLIC: Indicates whether target's optimistic locking value should be incremented on the source deletion (default value is true).
shouldInitialize(AbstractSession) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL: This method is called during regular descriptor initialization.
shouldInitializeSelectionCriteria() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
 
shouldInlineBinaryData() - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
 
shouldInlineBinaryData() - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataMapping
 
shouldInlineBinaryData() - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
shouldInlineBinaryData() - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
 
shouldInvalidateCache() - Method in class org.eclipse.persistence.queries.ModifyAllQuery
INTERNAL:
shouldInvalidateObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Indicates whether the object in session cache should be invalidated.
shouldIsolateObjectsInUnitOfWork() - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Return if the unit of work should by-pass the session cache.
shouldIsolateObjectsInUnitOfWork() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if the unit of work should by-pass the session cache.
shouldIsolateObjectsInUnitOfWorkEarlyTransaction() - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Return if the unit of work should by-pass the session cache after an early transaction.
shouldIsolateObjectsInUnitOfWorkEarlyTransaction() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if the unit of work should by-pass the session cache after an early transaction.
shouldIsolateProtectedObjectsInUnitOfWork() - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Return if the unit of work should by-pass the IsolatedSession cache.
shouldIsolateProtectedObjectsInUnitOfWork() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if the unit of work should by-pass the IsolatedSession cache.
shouldIterateOnAggregates - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldIterateOnAggregates() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Return whether the aggregate reference objects themselves should be processed.
shouldIterateOnFetchGroupAttributesOnly - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldIterateOnFetchGroupAttributesOnly() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
If true then if object has a FetchGroup then iterations not performed on mappings that are outside of the FetchGroup.
shouldIterateOnIndirectionObjects - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldIterateOnIndirectionObjects() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Return whether the indirection objects themselves (e.g.
shouldIterateOnPrimitives - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldIterateOnPrimitives() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Return whether to process primitive reference objects (e.g.
shouldIterateOverIndirectionObjects - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldIterateOverIndirectionObjects() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Return whether to process the objects contained by indirection objects (e.g.
shouldIterateOverSubSelects() - Method in class org.eclipse.persistence.internal.expressions.ExpressionIterator
Normally an Iterator will not go into the where clause of an SQLSubSelectExpression.
shouldIterateOverUninstantiatedIndirectionObjects - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldIterateOverUninstantiatedIndirectionObjects() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
Return whether to *instantiate* and process the objects contained by indirection objects (e.g.
shouldIterateOverWrappedObjects - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldIterateOverWrappedObjects() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldKeepRow - Variable in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
PERF: is there a mapping using indirection (could be nested in aggregate(s)), or any other reason to keep row after the object has been created.
shouldKeepRow() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
shouldKeepValues - Variable in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
Indicates whether the values requested while populating object (isPopulatingObject == true) should be saved in valuesArray
shouldKeepValues() - Method in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
 
shouldLoad() - Method in class org.eclipse.persistence.queries.FetchGroup
 
shouldLoadResultIntoSelectionObject - Variable in class org.eclipse.persistence.queries.ReadObjectQuery
Can be used to refresh a specific non-cached instance from the database.
shouldLoadResultIntoSelectionObject() - Method in class org.eclipse.persistence.queries.ReadObjectQuery
PUBLIC: return true if the result should be loaded into the passed in selection Object
shouldLockForClone - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
This flag controls if a UOW should acquire locks for clone or simple clone the instance passed to registerExistingObject.
shouldLockForClone() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
ADVANCED: When set to false, this setting will allow the UOW to avoid locking the shared cache instance in order to perform a clone.
shouldLog(byte) - Method in enum org.eclipse.persistence.logging.LogLevel
Check if a message of the given level ID would actually be logged under this logging level.
shouldLog(int) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
shouldLog(int) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Check if a message of the given level would actually be logged.
shouldLog(int, String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
shouldLog(int, String) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
shouldLog(int, String) - Method in class org.eclipse.persistence.logging.DefaultSessionLog
Check if a message of the given level would actually be logged by the logger with name space built from the given session and category.
shouldLog(int, String) - Method in class org.eclipse.persistence.logging.JavaLog
PUBLIC:
shouldLog(int, String) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: Check if a message of the given level would actually be logged.
shouldLog(int, String) - Method in class org.eclipse.persistence.services.RuntimeServices
Check if a message of the given level would actually be logged.
shouldLog(int, String) - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Check if a message of the given level would actually be logged.
shouldLog(LogLevel) - Method in enum org.eclipse.persistence.logging.LogLevel
Check if a message of the given level would actually be logged under this logging level.
shouldLogDebugMessage() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
shouldLogExceptionStackTrace - Variable in class org.eclipse.persistence.logging.AbstractSessionLog
Allows the printing of the stack to be explicitly disabled/enabled.
shouldLogExceptionStackTrace() - Method in class org.eclipse.persistence.logging.AbstractSessionLog
By default the stack is logged for FINER or less (finest).
shouldLogExceptionStackTrace() - Method in class org.eclipse.persistence.logging.EclipseLinkLogRecord
 
shouldLogExceptionStackTrace() - Method in interface org.eclipse.persistence.logging.SessionLog
By default the stack trace is logged for SEVERE all the time and at FINER level for WARNING or less, this can be turned off.
shouldLogin - Variable in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
Define if the loaded session should be connected, default true.
shouldLogin() - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: Return if the loaded session should be connected.
shouldLogMessage(int) - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
INTERNAL:
shouldLogMessages() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return if logging is enabled (false if log level is OFF)
shouldLogMessages() - Method in interface org.eclipse.persistence.sessions.Session
PUBLIC: Return if logging is enabled (false if log level is OFF)
shouldLogMessages(int) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: RemoteCommandManager method.
shouldLogMessages(int) - Method in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
PUBLIC: Determine whether messages at the specified log level should be logged.
shouldLogProfile - Variable in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
shouldLogProfile() - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
shouldLogWarningMessage() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
 
shouldMaintainCache - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Flag used for a query to bypass the identitymap and unit of work.
shouldMaintainCache() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return if the identity map (cache) should be used or not.
shouldMergeCascadeParts(MergeManager) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Returns true if the merge should cascade to the mappings reference's parts.
shouldMergeCascadeReference(MergeManager) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Returns true if the merge should cascade to the mappings reference.
shouldMergeChangesIntoDistributedCache() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTERNAL: This happens when changes from an UnitOfWork is propagated to a distributed class.
shouldMergeCloneIntoWorkingCopy() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
This can be used by the user for merging clones from RMI into the unit of work.
shouldMergeCloneWithReferencesIntoWorkingCopy() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
This can be used by the user for merging remote EJB objects into the unit of work.
shouldMergeOriginalIntoWorkingCopy() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
This is used to revert changes to objects, or during refreshes.
shouldMergeWorkingCopyIntoOriginal() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
This is used during the unit of work commit to merge changes into the parent.
shouldMergeWorkingCopyIntoRemote() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTERNAL: This happens when serialized remote unit of work has to be merged with local remote unit of work.
shouldModifyVersionField - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
Contains optimisticReadLockObject corresponding to the clone, non-null indicates forced changes
shouldModifyVersionField() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Holds a Boolean indicating whether version field should be modified.
shouldMonitor - Static variable in class org.eclipse.persistence.tools.profiler.FetchGroupMonitor
 
shouldMonitor - Static variable in class org.eclipse.persistence.tools.profiler.QueryMonitor
 
shouldMonitor() - Static method in class org.eclipse.persistence.tools.profiler.FetchGroupMonitor
 
shouldMonitor() - Static method in class org.eclipse.persistence.tools.profiler.QueryMonitor
 
shouldNativeSequenceUseTransaction() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Indicates whether a separate transaction is required for NativeSequence.
shouldNewObjectsBeCached - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Allow for double merges of new objects by putting them into the cache.
shouldNewObjectsBeCached() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: By default new objects are not cached until the exist on the database.
shouldNewObjectsBeCached() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: By default new objects are not cached until the exist on the database.
shouldNotCascade(DatabaseMapping) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator.CascadeCondition
 
shouldObjectModifyCascadeToParts(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
Return whether any process leading to object modification should also affect its parts.
shouldObjectModifyCascadeToParts(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Returns true as any process leading to object modification should also affect its privately owned parts Usually used by write, insert, update and delete.
shouldObjectModifyCascadeToParts(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
Returns true if any process leading to object modification should also affect its parts Usually used by write, insert, update and delete.
shouldObjectModifyCascadeToParts(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
Return whether any process leading to object modification should also affect its parts.
shouldOnlyRefreshCacheIfNewerVersion - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
shouldOnlyRefreshCacheIfNewerVersion() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: This method returns true if the ClassDescriptor is configured to only refresh the cache if the data received from the database by a query is newer than the data in the cache (as determined by the optimistic locking field).
shouldOnlyRefreshCacheIfNewerVersion() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: This method returns true if the ClassDescriptor is configured to only refresh the cache if the data received from the database by a query is newer than the data in the cache (as determined by the optimistic locking field).
shouldOptimizeDataConversion - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allow for driver level data conversion optimization to be disabled, required because some drivers can loose precision.
shouldOptimizeDataConversion() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Return if our driver level data conversion optimization is enabled.
shouldOptimizeDataConversion() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
shouldOptimizeDataConversion() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
shouldOptimizeDataConversion() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Return if our driver level data conversion optimization is enabled.
shouldOptimizeDates - Static variable in class org.eclipse.persistence.internal.helper.Helper
Used to configure JDBC level date optimization.
shouldOptimizeDates() - Static method in class org.eclipse.persistence.internal.helper.Helper
Return if JDBC date access should be optimized.
shouldOptimizeResultSetAccess - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Indicates whether ObjectLevelReadQuery should by default use ResultSet Access optimization.
shouldOptimizeResultSetAccess() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Indicates whether ObjectLevelReadQuery should by default use ResultSet Access optimization.
shouldOrderMappings - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
shouldOrderMappings() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if mappings should be ordered or not.
shouldOuterJoinSubclasses - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
Define if an outer join should be used to read subclasses.
shouldOuterJoinSubclasses - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Define if an outer join should be used to read subclasses.
shouldOuterJoinSubclasses() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Return if an outer join should be used to read subclasses.
shouldOuterJoinSubclasses() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Return if an outer join should be used to read subclasses.
shouldPerformDeletesFirst - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Flag indicating that deletes should be performed before other updates.
shouldPerformDeletesFirst() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: By default all objects are inserted and updated in the database before any object is deleted.
shouldPerformDeletesFirst() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: By default all objects are inserted and updated in the database before any object is deleted.
shouldPerformDTDValidation - Static variable in class org.eclipse.persistence.sessions.factories.SessionManager
 
shouldPerformFullValidation() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not refered in the unit of work cache.
shouldPerformFullValidation() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not referred in the unit of work cache.
shouldPerformNoValidation() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not refered in the unit of work cache.
shouldPerformNoValidation() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not referred in the unit of work cache.
shouldPerformPartialValidation() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not refered after commit, ensures that objects from the parent cache are not refered in the unit of work cache.
shouldPerformPartialValidation() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: The unit of work performs validations such as, ensuring multiple copies of the same object don't exist in the same unit of work, ensuring deleted objects are not referred after commit, ensures that objects from the parent cache are not referred in the unit of work cache.
shouldPrefetchCacheKeys() - Method in class org.eclipse.persistence.descriptors.CachePolicy
 
shouldPrepare - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Allow for the prepare of queries to be turned off, this allow for dynamic non-pre SQL generated queries.
shouldPrepare() - Method in class org.eclipse.persistence.queries.DatabaseQuery
PUBLIC: Return if the query should be prepared.
shouldPrepare(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.queries.DatabaseQuery
INTERNAL: Check if the query should be prepared, or dynamic, depending on the arguments.
shouldPrepare(DatabaseQuery) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Allows query prepare to be disable in the platform.
shouldPreserveDocument() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
Return if unmapped information from the XML document should be maintained for this descriptor By default unmapped data is not preserved.
shouldPreserveDocument() - Method in class org.eclipse.persistence.oxm.documentpreservation.DocumentPreservationPolicy
 
shouldPreserveDocument() - Method in class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: Return if unmapped information from the XML document should be maintained for this descriptor By default unmapped data is not preserved.
shouldPrintAliasForUpdate() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether locking OF clause should print alias for field.
shouldPrintAliasForUpdate() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Indicates whether locking OF clause should print alias for field.
shouldPrintConnection - Variable in class org.eclipse.persistence.logging.AbstractSessionLog
Allows the printing of the connection to be explicitly disabled/enabled.
shouldPrintConnection() - Method in class org.eclipse.persistence.logging.AbstractSessionLog
By default the connection is printed, this can be turned off.
shouldPrintConnection() - Method in interface org.eclipse.persistence.logging.SessionLog
By default the connection is always printed whenever available, this can be turned off.
shouldPrintConstraintNameAfter() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Some Platforms want the constraint name after the constraint definition.
shouldPrintConstraintNameAfter() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Some Platforms want the constraint name after the constraint definition.
shouldPrintDate - Variable in class org.eclipse.persistence.logging.AbstractSessionLog
Allows the printing of the date to be explicitly disabled/enabled.
shouldPrintDate() - Method in class org.eclipse.persistence.logging.AbstractSessionLog
By default the date is always printed, but can be turned off.
shouldPrintDate() - Method in class org.eclipse.persistence.logging.EclipseLinkLogRecord
 
shouldPrintDate() - Method in interface org.eclipse.persistence.logging.SessionLog
By default the date is always printed, this can be turned off.
shouldPrintFieldIdentityClause(AbstractSession, String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
shouldPrintForUpdateClause - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
Whether a FOR UPDATE clause should be printed at the end of the query
shouldPrintForUpdateClause() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
shouldPrintForUpdateClause() - Method in class org.eclipse.persistence.platform.database.DB2Platform
 
shouldPrintForUpdateClause() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL FOR UPDATE clause has to be the last
shouldPrintForUpdateClause() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
 
shouldPrintInnerJoinInWhereClause(ReadQuery) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This allows which clause inner joins are printed into in SQL generation.
shouldPrintInOutputTokenBeforeType() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This is required in the construction of the stored procedures with output parameters
shouldPrintInOutputTokenBeforeType() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
shouldPrintInOutputTokenBeforeType() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
This is required in the construction of the stored procedures with output parameters
shouldPrintInOutputTokenBeforeType() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
shouldPrintInputTokenAtStart() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for stored procedure creation: Some platforms want to print prefix for INPUT arguments BEFORE NAME.
shouldPrintInputTokenAtStart() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
shouldPrintInputTokenAtStart() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Used for stored procedure creation: Some platforms want to print prefix for INPUT arguments BEFORE NAME.
shouldPrintInternalException - Static variable in exception org.eclipse.persistence.exceptions.EclipseLinkException
 
shouldPrintInternalException() - Static method in exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL Check to see if the EclipseLink-stored internal exception should be printed in this a EclipseLinkException's stack trace.
shouldPrintLockingClauseAfterWhereClause() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether locking clause should be printed after where clause by SQLSelectStatement.
shouldPrintLockingClauseAfterWhereClause() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Attempts to remove FOR UPDATE from queries
shouldPrintLockingClauseAfterWhereClause() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Indicates whether locking clause should be printed after where clause by SQLSelectStatement.
shouldPrintLockingClauseAfterWhereClause() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
The sybase syntax for obtaining pessimistic lock is "SELECT ADDRESS_ID, ...
shouldPrintOuterJoinInWhereClause() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Some database require outer joins to be given in the where clause, others require it in the from clause.
shouldPrintOuterJoinInWhereClause() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
shouldPrintOuterJoinInWhereClause() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
shouldPrintOuterJoinInWhereClause() - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
Some database require outer joins to be given in the where clause, others require it in the from clause.
shouldPrintOutputTokenAtStart() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This is required in the construction of the stored procedures with output parameters
shouldPrintOutputTokenAtStart() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: This is required in the construction of the stored procedures with output parameters.
shouldPrintOutputTokenAtStart() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
This is required in the construction of the stored procedures with output parameters
shouldPrintOutputTokenAtStart() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL requires the direction at the start of the argument.
shouldPrintOutputTokenAtStart() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
This is required in the construction of the stored procedures with output parameters
shouldPrintOutputTokenAtStart() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
shouldPrintOutputTokenAtStart() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
This is required in the construction of the stored procedures with output parameters
shouldPrintOutputTokenBeforeType() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
This is required in the construction of the stored procedures with output parameters
shouldPrintOutputTokenBeforeType() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
shouldPrintOutputTokenBeforeType() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
This is required in the construction of the stored procedures with output parameters
shouldPrintOutputTokenBeforeType() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
 
shouldPrintOutputTokenBeforeType() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
This is required in the construction of the stored procedures with output parameters
shouldPrintParameterValues() - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
shouldPrintQualifiedNames - Variable in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
Indicates whether fully qualified field names (owner + table) should be used or not.
shouldPrintQualifiedNames() - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
shouldPrintSession - Variable in class org.eclipse.persistence.logging.AbstractSessionLog
Allows the printing of the session to be explicitly disabled/enabled.
shouldPrintSession() - Method in class org.eclipse.persistence.logging.AbstractSessionLog
By default the session (and its connection is available) are printed, this can be turned off.
shouldPrintSession() - Method in interface org.eclipse.persistence.logging.SessionLog
By default the Session is always printed whenever available, this can be turned off.
shouldPrintStoredProcedureArgumentNameInCall() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Should the variable name of a stored procedure call be printed as part of the procedure call e.g.
shouldPrintStoredProcedureArgumentNameInCall() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
INTERNAL: Should the variable name of a stored procedure call be printed as part of the procedure call e.g.
shouldPrintStoredProcedureArgumentNameInCall() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL stored procedure calls do not require the argument name be printed in the call string e.g.
shouldPrintStoredProcedureArgumentNameInCall() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Should the variable name of a stored procedure call be printed as part of the procedure call e.g.
shouldPrintStoredProcedureArgumentNameInCall() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
INTERNAL: Pervasive SQL stored procedure calls do not require the argument name be printed in the call string e.g.
shouldPrintStoredProcedureArgumentNameInCall() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
shouldPrintStoredProcedureArgumentNameInCall() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Symfoware stored procedure calls do not require the argument name be printed in the call string.
E.g.
shouldPrintStoredProcedureVariablesAfterBeginString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used for stored procedure creation: Some platforms declare variables AFTER the procedure body's BEGIN string.
shouldPrintStoredProcedureVariablesAfterBeginString() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
shouldPrintStoredProcedureVariablesAfterBeginString() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Used for stored procedure creation: Symfoware declares variables AFTER the procedure body's BEGIN string.
shouldPrintThread - Variable in class org.eclipse.persistence.logging.AbstractSessionLog
Allows the printing of the thread to be explicitly disabled/enabled.
shouldPrintThread() - Method in class org.eclipse.persistence.logging.AbstractSessionLog
By default the thread is logged for FINE or less (finer,etc.).
shouldPrintThread() - Method in class org.eclipse.persistence.logging.EclipseLinkLogRecord
 
shouldPrintThread() - Method in interface org.eclipse.persistence.logging.SessionLog
By default the thread is logged at FINE or less level, this can be turned off.
shouldProcessTokenInQuotes - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
 
shouldPropagateAsynchronously() - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
PUBLIC: Return whether this command manager should propagate commands synchronously or asynchronously.
shouldPropagateAsynchronously() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
PUBLIC: Return whether this command manager should propagate commands synchronously or asynchronously.
shouldPropagateChanges - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Determined whether changes should be propagated to an EclipseLink cluster
shouldPropagateChanges() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Return whether changes should be propagated to other sessions or applications in a EclipseLink cluster through the Remote Command Manager mechanism.
shouldPropagateChanges() - Method in interface org.eclipse.persistence.sessions.DatabaseSession
ADVANCED: Return whether changes should be propagated to other sessions or applications in a EclipseLink cluster through the Remote Command Manager mechanism.
shouldPropagateChanges() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Return whether changes should be propagated to TopLink cluster.
shouldQueryToManyRelationship - Variable in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
Is this a query across a 1:many or many:many relationship.
shouldQueryToManyRelationship() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
 
shouldReadAllMappings() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Return if this is a full object query, not partial nor fetch group.
shouldReadAllMappings() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return if this is a full object query, not partial nor fetch group.
shouldReadFromDB() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Indicates whether readObject should return the object read from the db in case there is no object in uow cache (as opposed to fetching the object from parent's cache).
shouldReadMapping(DatabaseMapping, FetchGroup) - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Check if the mapping is part of the partial attributes.
shouldReadMapping(DatabaseMapping, FetchGroup) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Check if the mapping is part of the partial attributes.
shouldReadSubclasses - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
shouldReadSubclasses() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Return true if this descriptor should read instances of itself and subclasses on queries.
shouldReadSubclassesValue() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: Return true if this descriptor should read instances of itself and subclasses on queries.
shouldReadWholeDocument - Variable in class org.eclipse.persistence.mappings.xdb.DirectToXMLTypeMapping
Indicates if we should initialize the whole DOM on a read.
shouldReadWholeDocument() - Method in class org.eclipse.persistence.mappings.xdb.DirectToXMLTypeMapping
PUBLIC:
shouldRecalculateAfterUpdateEvent - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
return whether this change set should be recalculated after an event changes the object
shouldRecalculateAfterUpdateEvent() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
ADVANCED Returns true if this ObjectChangeSet should be recalculated after changes in event
shouldRecalculateAfterUpdateEvent() - Method in interface org.eclipse.persistence.sessions.changesets.ObjectChangeSet
ADVANCED Returns true if this ObjectChangeSet should be recalculated after changes in event
shouldRefresh - Variable in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
Define if the loaded session should be refreshed from the file.
shouldRefresh() - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: Return if the loaded session should be refreshed from the file.
shouldRefreshCascadeParts(MergeManager) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Returns true if the merge should cascade to the mappings reference's parts.
shouldRefreshIdentityMapResult - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
Allows for the resulting objects to be refresh with the data from the database.
shouldRefreshIdentityMapResult() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
PUBLIC: Set to a boolean.
shouldRefreshInvalidObjectsOnClone - Variable in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
Determines if expired object registered in the unit of work should be refreshed, default true.
shouldRefreshInvalidObjectsOnClone() - Method in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
PUBLIC: Return if expired object should be refreshed prior to cloning.
shouldRefreshRemoteIdentityMapResult - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
 
shouldRefreshRemoteIdentityMapResult() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
PUBLIC: Set to a boolean.
shouldRefreshRemoteObject() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTERNAL: This is used to refresh objects on the remote session
shouldRegisterDevelopmentBean - Variable in class org.eclipse.persistence.platform.server.ServerPlatformBase
 
shouldRegisterResultsInUnitOfWork - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
shouldRegisterResultsInUnitOfWork - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: for bug 2612601 allow ability not to register results in UOW.
shouldRegisterResultsInUnitOfWork() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Allows one to do conforming in a UnitOfWork without registering.
shouldRegisterResultsInUnitOfWork() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Allows one to do conforming in a UnitOfWork without registering.
shouldRegisterRuntimeBean - Variable in class org.eclipse.persistence.platform.server.ServerPlatformBase
 
shouldRemoveConnectionOnError - Variable in class org.eclipse.persistence.sessions.coordination.TransportManager
Determines whether a connection should be discarded if an error occurs on it
shouldRemoveConnectionOnError() - Method in class org.eclipse.persistence.sessions.coordination.TransportManager
PUBLIC: Return whether connections to remote services should be disconnected when an error occurs.
shouldRemoveTargetQueryModifyTargetForeignKey() - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL If it's not a map then target foreign key has been already modified (set to null).
shouldRemoveTargetQueryModifyTargetForeignKey() - Method in class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
INTERNAL Target foreign key of the removed object should be modified (set to null).
shouldResetPrimaryKey - Variable in class org.eclipse.persistence.sessions.CopyGroup
 
shouldResetPrimaryKey() - Method in class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: Return if the primary key should be reset to null.
shouldResetVersion - Variable in class org.eclipse.persistence.sessions.CopyGroup
 
shouldResetVersion() - Method in class org.eclipse.persistence.sessions.CopyGroup
PUBLIC: Return if the version should be reset to null.
shouldResumeUnitOfWorkOnTransactionCompletion() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Returns true if this UnitofWork should be resumed after the end of the transaction Used when UnitOfWork is synchronized with external transaction control
shouldRetrieveBypassCache - Variable in class org.eclipse.persistence.queries.DatabaseQuery
JPA flags to control the shared cache
shouldRetrieveBypassCache() - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: JPA flag used to control the behavior of the shared cache.
shouldRetrieveFirstPrimaryKey() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Return if the query results should contain the first primary key of each associated object.
shouldRetrievePrimaryKeys - Variable in class org.eclipse.persistence.queries.ReportQuery
Flag indicating whether the primary key values should also be retrieved for the reference class.
shouldRetrievePrimaryKeys() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Return if the query results should contain the primary keys or each associated object.
shouldReturnArray() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Returns true if results should be returned as an Object array.
ShouldReturnArray - Static variable in class org.eclipse.persistence.queries.ReportQuery
For EJB 3 support returns results as an Object array.
shouldReturnGeneratedKeys - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
shouldReturnGeneratedKeys - Variable in class org.eclipse.persistence.queries.DatabaseQuery
 
shouldReturnGeneratedKeys() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
Indicate that this call should set Statement.RETURN_GENERATED_KEYS when executing
shouldReturnGeneratedKeys() - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: JPA flag used to control the behavior of IDENTITY generation.
shouldReturnMapEntry() - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
 
shouldReturnNameValuePairs() - Method in class org.eclipse.persistence.queries.ResultSetMappingQuery
Indicates whether or not to return populated DatabaseRecord(s) as opposed to raw data when an SQLResultSetMapping is not set.
ShouldReturnReportResult - Static variable in class org.eclipse.persistence.queries.ReportQuery
Default, returns ReportQueryResult objects.
shouldReturnSingleAttribute() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Answer if we are only returning the attribute (as opposed to wrapping in a ReportQueryResult).
ShouldReturnSingleAttribute - Static variable in class org.eclipse.persistence.queries.ReportQuery
Simplifies the result by only returning the single attribute(as opposed to wrapping in a ReportQueryResult).
shouldReturnSingleResult() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by only returning the first result.
ShouldReturnSingleResult - Static variable in class org.eclipse.persistence.queries.ReportQuery
Simplifies the result by only returning the first result.
shouldReturnSingleValue() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by only returning a single value.
ShouldReturnSingleValue - Static variable in class org.eclipse.persistence.queries.ReportQuery
Simplifies the result by only returning one value.
shouldReturnWithoutReportQueryResult() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Simplifies the result by returning a nested list instead of the ReportQueryResult.
ShouldReturnWithoutReportQueryResult - Static variable in class org.eclipse.persistence.queries.ReportQuery
For EJB 3 support returns results without using the ReportQueryResult
shouldSelectBeforeUpdate - Variable in class org.eclipse.persistence.sequencing.QuerySequence
 
shouldSelectBeforeUpdate() - Method in class org.eclipse.persistence.sequencing.QuerySequence
PUBLIC:
shouldSelectDistinctIncludeOrderBy() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Return if the database requires the ORDER BY fields to be part of the select clause.
shouldSelectIncludeOrderBy() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Return if the database requires the ORDER BY fields to be part of the select clause.
shouldSelectIncludeOrderBy() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
Informix seemed to require this at some point.
shouldSelectValue1() - Method in class org.eclipse.persistence.queries.ReportQuery
PUBLIC: Returns true if results should be returned as an Object array.
ShouldSelectValue1 - Static variable in class org.eclipse.persistence.queries.ReportQuery
For example, ...
shouldSkipUpdate - Variable in class org.eclipse.persistence.sequencing.QuerySequence
 
shouldSkipUpdate() - Method in class org.eclipse.persistence.sequencing.QuerySequence
PUBLIC:
shouldStoreBypassCache - Variable in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
Used to determine if we should bypass any merge into the cache.
shouldStoreBypassCache - Variable in class org.eclipse.persistence.queries.DatabaseQuery
 
shouldStoreBypassCache() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Returns true if the UOW should bypass any updated to the shared cache during the merge.
shouldStoreBypassCache() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This is a JPA setting that is off by default in regular EclipseLink.
shouldStoreBypassCache() - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: JPA flag used to control the behavior of the shared cache.
shouldSynchronizedReadOnWrite() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Used for cache isolation.
shouldSynchronizedReadOnWrite() - Method in interface org.eclipse.persistence.sessions.Login
INTERNAL: Used for cache isolation.
shouldSynchronizeObjectLevelReadWrite() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Used for Cache Isolation.
shouldSynchronizeObjectLevelReadWrite() - Method in interface org.eclipse.persistence.sessions.Login
INTERNAL: Used for Cache Isolation.
shouldSynchronizeObjectLevelReadWriteDatabase() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Used for Cache Isolation.
shouldSynchronizeObjectLevelReadWriteDatabase() - Method in interface org.eclipse.persistence.sessions.Login
INTERNAL: Used for Cache Isolation.
shouldSynchronizeWrites() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
INTERNAL: Used for Cache Isolation.
shouldSynchronizeWrites() - Method in interface org.eclipse.persistence.sessions.Login
INTERNAL: Used for Cache Isolation.
shouldTempTableSpecifyPrimaryKeys() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether temporary table can specify primary keys (some platforms don't allow that).
shouldTempTableSpecifyPrimaryKeys() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL: Indicates whether temporary table can specify primary keys (some platforms don't allow that).
shouldTempTableSpecifyPrimaryKeys() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
shouldTerminateTransaction - Variable in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
Used to determine if UnitOfWork should commit and rollback transactions.
shouldThrowConformExceptions - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Flag indicating how to deal with exceptions on conforming queries.
shouldThrowIndirectionException() - Method in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
shouldTolerateInvalidJPQL() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: Indicates whether an invalid NamedQuery will be tolerated at init time.
shouldToStringInstantiate - Static variable in interface org.eclipse.persistence.indirection.ValueHolderInterface
Can be used to have transparent indirection toString instantiate the objects.
shouldTrackCurrentGroup - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldTrackCurrentGroup() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
shouldTrackStack - Static variable in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
shouldTrackStack() - Static method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
shouldTranslate - Variable in class org.eclipse.persistence.logging.SessionLogEntry
 
shouldTranslate() - Method in class org.eclipse.persistence.logging.SessionLogEntry
 
shouldTriggerIndirection() - Method in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
shouldTrimStrings - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Indicates (if true) to remove blanks characters from the right of CHAR strings.
shouldTrimStrings() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
shouldTrimStrings() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: By default CHAR field values have trailing blanks trimmed, this can be configured.
shouldUpdateForeignKeysPostInsert() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Certain types of container policies require an extra update statement after a relationship is inserted.
shouldUpdateForeignKeysPostInsert() - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Certain types of container policies require an extra update statement after a relationship is inserted.
shouldUpdateReadTimeOnUpdate - Variable in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
This will represent objects that do not expire.
shouldUpdateReadTimeOnUpdate() - Method in class org.eclipse.persistence.descriptors.invalidation.CacheInvalidationPolicy
PUBLIC: Return whether objects affected by this CacheInvalidationPolicy should have the read time on their cache keys updated when an update occurs.
shouldUpdateVersionOnMappingChange() - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Returns true if the policy has been set to set an optimistic read lock when any mapping changes.
shouldUpdateVersionOnMappingChange() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Returns true if the policy has been set to set an optimistic read lock when any mapping changes.
shouldUpdateVersionOnMappingChange() - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: Returns true if the policy has been set to set an optimistic read lock when any mapping changes.
shouldUpdateVersionOnOwnedMappingChange() - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Returns true if the policy has been set to set an optimistic read lock when a owning mapping changes.
shouldUpdateVersionOnOwnedMappingChange() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Returns true if the policy has been set to set an optimistic read lock when a owning mapping changes.
shouldUpdateVersionOnOwnedMappingChange() - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: Returns true if the policy has been set to set an optimistic read lock when a owning mapping changes.
shouldUseAdditionalJoinExpression() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor should using an additional join expresison.
shouldUseBatchReading() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Indicates whether the referenced object should always be batch read on read all queries.
shouldUseBatchWriting() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use batch writing.
shouldUseByteArrayBinding() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use parameter binding for large binary data.
shouldUseCacheIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using CacheIdentityMap
shouldUseClassLoaderFromCurrentThread - Variable in class org.eclipse.persistence.internal.helper.ConversionManager
This flag is here if the Conversion Manager should use the class loader on the thread when loading classes.
shouldUseClassLoaderFromCurrentThread() - Method in class org.eclipse.persistence.internal.helper.ConversionManager
ADVANCED: This flag should be set if the current thread classLoader should be used.
shouldUseClassNameAsIndicator - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
shouldUseClassNameAsIndicator() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Return true if the descriptor use the classes full name as the indicator.
shouldUseCustomModifyForCall(DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
shouldUseCustomModifyForCall(DatabaseField) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Used by SQLCall.appendModify(..) If the field should be passed to customModifyInDatabaseCall, retun true, otherwise false.
shouldUseCustomModifyForCall(DatabaseField) - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
Allow for the platform to handle the representation of parameters specially.
shouldUseCustomModifyForCall(DatabaseField) - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
INTERNAL Used by SQLCall.appendModify(..) If the field should be passed to customModifyInDatabaseCall, retun true, otherwise false.
shouldUseDatabaseTime() - Method in class org.eclipse.persistence.history.HistoryPolicy
Answers if the Timestamp used in maintaining history should be the current time according to the database.
shouldUseDefault(String) - Static method in class org.eclipse.persistence.internal.sessions.PropertiesHandler
INTERNAL: Empty String value indicates that the default property value should be used.
shouldUseDefaultFetchGroup - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Flag to turn on/off the use of the default fetch group.
shouldUseDefaultFetchGroup() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Return false if the query does not use the default fetch group defined in the descriptor level.
shouldUseDelimiters() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
shouldUseDelimiters() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
shouldUseDescriptorAliases - Variable in class org.eclipse.persistence.sessions.broker.SessionBroker
 
shouldUseDescriptorAliases() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
PUBLIC: Indicates whether descriptors should use aliasDescriptors map.
shouldUseDriverManager() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: shouldUseDriverManager(): Indicates whether DriverManager should be used while connecting DefaultConnector.
shouldUseDriverManager() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: shouldUseDriverManager(): Indicates whether DriverManager should be used while connecting DefaultConnector.
shouldUseDriverManager(Properties, Session) - Method in class org.eclipse.persistence.sessions.DefaultConnector
INTERNAL: Indicates whether DriverManager should be used.
shouldUseDriverManager(Properties, Session) - Method in class org.eclipse.persistence.sessions.DirectConnector
INTERNAL: Indicates whether DriverManager should be used.
shouldUseDynamicStatements - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
PERF: Backdoor to disabling dynamic statements.
shouldUseEqualityForNulls - Variable in class org.eclipse.persistence.queries.QueryByExamplePolicy
 
shouldUseEqualityForNulls() - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: Matches an included null attribute in the example object either to objects with that attribute also set to null or to any value other than null.
shouldUseExclusiveConnection - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
Added for Exclusive Connection (VPD) support see accessor for information
shouldUseExclusiveConnection() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
ADVANCED: If the user has isolated data and specified that the client session should use an exclusive connection then by setting this condition to true EclipseLink will ensure that the query is executed through the exclusive connection.
shouldUseExternalConnectionPooling() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Return whether EclipseLink uses some external connection pooling (e.g.
shouldUseExternalConnectionPooling() - Method in interface org.eclipse.persistence.sessions.Login
PUBLIC: Return whether EclipseLink uses some externally managed connection pooling.
shouldUseExternalTransactionController() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Return whether EclipseLink uses some external transaction service such as JTS.
shouldUseExternalTransactionController() - Method in interface org.eclipse.persistence.sessions.Login
PUBLIC: Return whether EclipseLink uses some externally managed transaction service such as JTS.
shouldUseFullChangeSetsForNewObjects - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Backdoor for using changes sets for new objects.
shouldUseFullChangeSetsForNewObjects() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if change sets are required for new objects.
shouldUseFullChangeSetsForNewObjects() - Method in class org.eclipse.persistence.eis.EISDescriptor
INTERNAL: Return if change sets are required for new objects.
shouldUseFullIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using FullIdentityMap
shouldUseGeneratedKeysIfPlatformSupports - Variable in class org.eclipse.persistence.sequencing.NativeSequence
true indicates that identity is used and generatedKeys should be used - if the platform supports generatedKeys false indicates that identity is used and generatedKeys should not be used - if the platform does not support generatedKeys
shouldUseGeneratedKeysIfPlatformSupports() - Method in class org.eclipse.persistence.sequencing.NativeSequence
 
shouldUseGetSetNString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Returns true iff: tThe current driver supports calling get/setNString Strings are globally mapped to a national character varying type (useNationalCharacterVarying()).
shouldUseHardCacheWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using HardCacheWeakIdentityMap.
shouldUseIdentityIfPlatformSupports - Variable in class org.eclipse.persistence.sequencing.NativeSequence
true indicates that identity should be used - if the platform supports identity.
shouldUseIdentityIfPlatformSupports() - Method in class org.eclipse.persistence.sequencing.NativeSequence
 
shouldUseInheritedDefaultFetchGroup() - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
PUBLIC: Indicates whether defaultFetchGroup should be copied from the parent if not set.
shouldUseJDBCBatchWriting() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Answers true if EclipseLink has JDBC batch writing enabled.
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
JDBC defines and outer join syntax, many drivers do not support this.
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.platform.database.AccessPlatform
JDBC defines and outer join syntax, many drivers do not support this.
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.platform.database.CloudscapePlatform
JDBC defines an outer join syntax which many drivers do not support.
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: JDBC defines and outer join syntax, many drivers do not support this.
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.platform.database.DBasePlatform
JDBC defines and outer join syntax, many drivers do not support this.
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
JDBC escape syntax for outer joins is not supported (not required).
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: JDBC defines an outer join syntax which many drivers do not support.
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
JDBC defines and outer join syntax, many drivers do not support this.
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
JDBC defines an outer join syntax which many drivers do not support.
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
JDBC defines and outer join syntax, many drivers do not support this.
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
JDBC defines and outer join syntax, many drivers do not support this.
shouldUseJDBCOuterJoinSyntax() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
JDBC defines and outer join syntax, many drivers do not support this.
shouldUseLazyInstantiation() - Method in class org.eclipse.persistence.indirection.IndirectList
Return whether this collection should attempt do deal with adds and removes without retrieving the collection from the dB
shouldUseLazyInstantiation() - Method in class org.eclipse.persistence.indirection.IndirectSet
Return whether this collection should attempt do deal with adds and removes without retrieving the collection from the dB
shouldUseLazyInstantiation() - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
ADVANCED: Returns false unless this is a transparent indirection policy IndirectList and IndirectSet can be configured not to instantiate the list from the database when you add and remove from them.
shouldUseLazyInstantiation() - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
ADVANCED: IndirectList and IndirectSet can be configured not to instantiate the list from the database when you add and remove from them.
shouldUseLazyInstantiationForIndirectCollection() - Method in class org.eclipse.persistence.mappings.CollectionMapping
ADVANCED: This method should only be called after this mapping's indirection policy has been set IndirectList and IndirectSet can be configured not to instantiate the list from the database when you add and remove from them.
shouldUseListOrderFieldTableExpression() - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Indicates whether getListOrderFieldExpression method should create field expression based on table expression.
shouldUseListOrderFieldTableExpression() - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Indicates whether getListOrderFieldExpression method should create field expression on table expression.
shouldUseListOrderFieldTableExpression() - Method in class org.eclipse.persistence.mappings.ManyToManyMapping
INTERNAL: Indicates whether getListOrderFieldExpression method should create field expression on table expression.
shouldUseLocalTime() - Method in class org.eclipse.persistence.history.HistoryPolicy
Answers if the Timestamp used in maintaining history should be System.currentTimeMillis();
shouldUseLocatorForLOBWrite() - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
PUBLIC: Return if the locator is required for the LOB write.
shouldUseNativeSequencing() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use a sequence table or native sequencing to generate unique object IDs.
shouldUseNativeSQL() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use database-specific SQL grammar, as opposed to the JDBC standard grammar.
shouldUseNoIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using NoIdentityMap
shouldUseOptimisticLocking(Object) - Method in class org.eclipse.persistence.queries.DeleteObjectQuery
INTERNAL: Determines whether the query should use optimistic locking with the passed object.
shouldUseOptimization - Variable in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
Indicates whether to use optimization while getting values from result set instead of calling accessor.getObject method.
shouldUseOptimization() - Method in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
 
shouldUseOuterJoin - Variable in class org.eclipse.persistence.internal.expressions.ObjectExpression
Is this query key to be resolved using an outer join or not.
shouldUseOuterJoin() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
shouldUseOuterJoinForMultitableInheritance - Variable in class org.eclipse.persistence.internal.expressions.ObjectExpression
indicates whether subclasses should be joined
shouldUseOuterJoinForMultitableInheritance() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
 
shouldUsePreallocation() - Method in class org.eclipse.persistence.sequencing.DefaultSequence
INTERNAL: Indicates whether several sequencing values should be acquired at a time and be kept by TopLink.
shouldUsePreallocation() - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: Indicates whether several sequencing values should be acquired at a time and be kept by TopLink.
shouldUsePreallocation() - Method in class org.eclipse.persistence.sequencing.UUIDSequence
 
shouldUsePrivilegedAccess() - Static method in class org.eclipse.persistence.internal.security.PrivilegedAccessHelper
This method checks to see if calls should be made to doPrivileged.
shouldUseRemoteCacheIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using CacheIdentityMap
shouldUseRemoteFullIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using FullIdentityMap
shouldUseRemoteHardCacheWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using HardCacheWeakIdentityMap
shouldUseRemoteNoIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using NoIdentityMap
shouldUseRemoteSoftCacheWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using SoftCacheWeakIdentityMap
shouldUseRemoteSoftIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using SoftIdentityMap
shouldUseRemoteWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using WeakIdentityMap
shouldUseRownumFiltering() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
PUBLIC: Return if Oracle ROWNUM pagination should be used for FirstResult and MaxRows settings.
shouldUseSchemaValidation - Static variable in class org.eclipse.persistence.sessions.factories.SessionManager
Allow for usage of schema validation to be configurable.
shouldUseSchemaValidation - Static variable in class org.eclipse.persistence.sessions.factories.XMLProjectReader
Allow for usage of schema validation to be configurable.
shouldUseSchemaValidation() - Static method in class org.eclipse.persistence.sessions.factories.SessionManager
PUBLIC: Return if schema validation will be used when parsing the 10g (10.1.3) sessions XML.
shouldUseSchemaValidation() - Static method in class org.eclipse.persistence.sessions.factories.XMLProjectReader
PUBLIC: Return if schema validation will be used when parsing the deployment XML.
shouldUseSeparateConnection() - Method in interface org.eclipse.persistence.sequencing.SequencingControl
PUBLIC: Indicate whether separate connection(s) for sequencing could be used (by default it couldn't).
shouldUseSerializedObjectPolicy - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Indicates whether the query should use SerializedObjectPolicy if descriptor has it.
shouldUseSerializedObjectPolicy() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Indicates whether the query should use SerializedObjectPolicy if descriptor has it.
shouldUseSerializedObjectPolicy() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Indicates whether the query should use SerializedObjectPolicy if descriptor has it.
shouldUseSerializedObjectPolicyDefault - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
default value for shouldUseSerializedObjectPolicy
shouldUseSessionCacheInUnitOfWorkEarlyTransaction() - Method in class org.eclipse.persistence.descriptors.CachePolicy
INTERNAL: Return if the unit of work should use the session cache after an early transaction.
shouldUseSessionCacheInUnitOfWorkEarlyTransaction() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return if the unit of work should use the session cache after an early transaction.
shouldUseSharedCache() - Method in class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
shouldUseSharedEMF() - Method in class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
shouldUseSoftCacheWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using SoftCacheWeakIdentityMap.
shouldUseSoftIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using SoftIdentityMap
shouldUseStreamsForBinding() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use streams to store large binary data.
shouldUseStringBinding() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to bind large strings.
shouldUseTransaction - Variable in class org.eclipse.persistence.sequencing.QuerySequence
 
shouldUseTransaction() - Method in class org.eclipse.persistence.sequencing.DefaultSequence
INTERNAL: Indicates whether EclipseLink should internally call beginTransaction() before getGeneratedValue/Vector, and commitTransaction after.
shouldUseTransaction() - Method in class org.eclipse.persistence.sequencing.QuerySequence
PUBLIC:
shouldUseTransaction() - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: Indicates whether TopLink should internally call beginTransaction() before getGeneratedValue/Vector, and commitTransaction after.
shouldUseTransaction() - Method in class org.eclipse.persistence.sequencing.StandardSequence
 
shouldUseTransaction() - Method in class org.eclipse.persistence.sequencing.UUIDSequence
 
shouldUseUnwrappedConnection() - Method in class org.eclipse.persistence.internal.databaseaccess.BindCallCustomParameter
Return if unwrapped connection should be used.
shouldUseUpperCaseForIgnoreCase - Static variable in class org.eclipse.persistence.expressions.Expression
Use the upper() function for case insensitive expression operations (default).
shouldUseValueFromRowWithJoin(JoinedAttributeManager, ObjectBuildingQuery) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Indicates whether valueFromRow should call valueFromRowInternalWithJoin (true) or valueFromRowInternal (false)
shouldUseWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if this descriptor is using WeakIdentityMap
shouldUseWrapperPolicy - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Use the WrapperPolicy for the objects returned by the query
shouldUseWrapperPolicy() - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: The wrapper policy can be enabled on a query.
shouldValidateExample() - Method in class org.eclipse.persistence.queries.QueryByExamplePolicy
PUBLIC: Returns true if the example object used with this policy should be validated for attributes with unsupported mappings.
shouldValidateExistence - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Determine if does-exist should be performed on persist.
shouldValidateExistence() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Return the default to determine if does-exist should be performed on persist.
shouldValidateUpdateCallCacheUse - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Allow additional validation to be performed before using the update call cache
shouldValidateUpdateCallCacheUse() - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: Return true if additional validation should be performed before the query uses the update call cache, false otherwise.
shouldVerifyDelete - Variable in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
These are used for non-unit of work modification to check if the value of the 1-1 was changed and a deletion is required.
shouldVerifyDelete - Variable in class org.eclipse.persistence.mappings.OneToOneMapping
These are used for non-unit of work modification to check if the value of the 1-1 was changed and a deletion is required.
shouldVerifyDelete() - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
PUBLIC: Verify delete is used during delete and update outside of a unit of work only.
shouldVerifyDelete() - Method in class org.eclipse.persistence.mappings.OneToOneMapping
PUBLIC: Verify delete is used during delete and update outside of a unit of work only.
shouldWarnOnUnmappedElement() - Method in class org.eclipse.persistence.internal.oxm.Unmarshaller
 
shouldWarnOnUnmappedElement() - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
INTERNAL: Returns true if a warning exception should be generated when an unmapped element is encountered.
shouldWrapObject(Object, String, String, String, boolean) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL:
shouldWriteField(DatabaseField, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: By default returns true.
shouldWriteInto(Object, Object) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Return true if the cached object data should be written in clone.
shouldWriteToDatabase() - Method in class org.eclipse.persistence.tools.schemaframework.SchemaManager
PUBLIC: Return true if this SchemaManager should write to the database directly
shutdown() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: perform any require shutdown tasks.
shutdown() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: perform any require shutdown tasks.
shutdown() - Method in interface org.eclipse.persistence.sessions.coordination.CommandManager
PUBLIC: Shut down the remote command manager.
shutdown() - Method in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
PUBLIC: Shut down the remote command manager.
shutDown() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: Disconnect all connections.
shutDown() - Method in class org.eclipse.persistence.sessions.server.ExternalConnectionPool
INTERNAL: This mehtod is a no-op for external pools.
sign() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
sign(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Sign - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
SIGNAL_ATTEMPTED_BEFORE_WAIT - Static variable in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
signalAttemptedBeforeWait() - Static method in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
SignType - org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
SIMPLE_TYPE - Static variable in interface org.eclipse.persistence.platform.xml.XMLSchemaReference
 
simpleAddChangeSet(Object) - Method in class org.eclipse.persistence.eis.EISCollectionChangeRecord
Add a change set after it has been applied.
simpleAddChangeSet(Object) - Method in class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
Add a change set after it has been applied.
simpleAddToCollectionChangeRecord(Object, Integer, boolean, ObjectChangeSet, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
simpleAddToCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
ADVANCED: This method is used to have an object add to a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleAddToCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMappingHelper
ADVANCED: This method is used to add an object to a collection once the changeSet is applied.
simpleAddToCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
ADVANCED: This method is used to have an object add to a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleAddToCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
ADVANCED: This method is used to have an object add to a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleAddToCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: This method is used to add an object to a collection once the changeSet is applied.
simpleAddToCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
ADVANCED: This method is used to have an object add to a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleAddToCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
ADVANCED: This method is used to have an object add to a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleAddToCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
ADVANCED: This method is used to have an object add to a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleAddToCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
ADVANCED: This method is used to have an object add to a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleAddToCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ArrayCollectionMappingHelper
ADVANCED: This method is used to add an object to a collection once the changeSet is applied.
simpleAggregate(int, String, String) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create an operator for a simple aggregate given a Java name and a single String for the database (parentheses will be added automatically).
SimpleAppendCallCustomParameter - Class in org.eclipse.persistence.internal.databaseaccess
INTERNAL:
SimpleAppendCallCustomParameter(String) - Constructor for class org.eclipse.persistence.internal.databaseaccess.SimpleAppendCallCustomParameter
 
SimpleComponent - Class in org.eclipse.persistence.internal.oxm.schema.model
 
SimpleComponent() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.SimpleComponent
 
SimpleContent - Class in org.eclipse.persistence.internal.oxm.schema.model
 
SimpleContent() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.SimpleContent
 
SimpleDatabaseType - Interface in org.eclipse.persistence.internal.helper
PUBLIC: Marker interface for Simple Database types (e.g.
SimpleDerivation - Interface in org.eclipse.persistence.internal.oxm.schema.model
 
simpleFunction(int, String) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create an operator for a simple function given a Java name and a single String for the database (parentheses will be added automatically).
simpleFunction(int, String, String) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create an operator for a simple function given a Java name and a single String for the database (parentheses will be added automatically).
SimpleFunctionCall - Class in org.eclipse.persistence.internal.sessions.remote
Purpose: RemoteFunctionCall's interface implementors that don't use remoteSessionController parameter in execute method may extend this class
SimpleFunctionCall() - Constructor for class org.eclipse.persistence.internal.sessions.remote.SimpleFunctionCall
 
simpleFunctionNoParentheses(int, String) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create an operator for a simple function call without parentheses
simpleLogical(int, String, String) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create an operator for a simple logical given a Java name and a single String for the database (parentheses will be added automatically).
simpleLogicalNoParens(int, String) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: e.g.: ...
simpleMath(int, String) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create an operator for a simple math operation, i.e.
simpleOrdering(int, String, String) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create an operator for a simple ordering given a Java name and a single String for the database (parentheses will be added automatically).
SimplePLSQLTypeWrapper - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: a helper class that holds DatabaseType's.
SimplePLSQLTypeWrapper() - Constructor for class org.eclipse.persistence.internal.sessions.factories.SimplePLSQLTypeWrapper
 
SimplePLSQLTypeWrapper(DatabaseType) - Constructor for class org.eclipse.persistence.internal.sessions.factories.SimplePLSQLTypeWrapper
 
simpleRelation(int, String) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create an operator for a simple relation given a Java name and a single String for the database (parentheses will be added automatically).
simpleRelation(int, String, String) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create an operator for a simple relation given a Java name and a single String for the database (parentheses will be added automatically).
simpleRemoveChangeSet(Object) - Method in class org.eclipse.persistence.eis.EISCollectionChangeRecord
Remove a change set after it has been applied.
simpleRemoveChangeSet(Object) - Method in class org.eclipse.persistence.eis.EISOrderedCollectionChangeRecord
Remove a change set after it has been applied.
simpleRemoveFromCollectionChangeRecord(Object, Integer, boolean, ObjectChangeSet, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
simpleRemoveFromCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
ADVANCED: This method is used to have an object removed from a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleRemoveFromCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMappingHelper
ADVANCED: This method is used to remove an object from a collection once the changeSet is applied.
simpleRemoveFromCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
ADVANCED: This method is used to have an object removed from a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleRemoveFromCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
ADVANCED: This method is used to have an object removed from a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleRemoveFromCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
ADVANCED: This method is used to remove an object from a collection once the changeSet is applied.
simpleRemoveFromCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
ADVANCED: This method is used to have an object removed from a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleRemoveFromCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
ADVANCED: This method is used to have an object removed from a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleRemoveFromCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
ADVANCED: This method is used to have an object removed from a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleRemoveFromCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
ADVANCED: This method is used to have an object removed from a collection once the changeSet is applied The referenceKey parameter should only be used for direct Maps.
simpleRemoveFromCollectionChangeRecord(Object, Object, ObjectChangeSet, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ArrayCollectionMappingHelper
ADVANCED: This method is used to remove an object from a collection once the changeSet is applied.
SimpleResultSetRecord - Class in org.eclipse.persistence.internal.sessions
PERF: Record used by ObjectLevelReadQuery ResultSet optimization.
SimpleResultSetRecord() - Constructor for class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
 
SimpleResultSetRecord(Vector, DatabaseField[], ResultSet, ResultSetMetaData, DatabaseAccessor, AbstractSession, DatabasePlatform, boolean) - Constructor for class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
 
simpleThreeArgumentFunction(int, String) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
simpleTwoArgumentFunction(int, String) - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
SimpleType - Class in org.eclipse.persistence.internal.oxm.schema.model
 
SimpleType() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.SimpleType
 
sin() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
sin(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Sin - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
SINGLE_TABLE - org.eclipse.persistence.annotations.MultitenantType
Specifies that table(s) the entity maps to includes rows for multiple tenants.
singleArgumentSubstring() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Gets the substring of a string starting from the specified start position.
Builds Symfoware equivalent to SUBSTRING(string_exp, startpos).
Symfoware: SUBSTRING(string_exp FROM startpos)
singleArgumentSubstringOperator() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Override the default SubstringSingleArg operator.
singleArgumentSubstringOperator() - Static method in class org.eclipse.persistence.platform.database.SQLServerPlatform
Override the default SubstringSingleArg operator.
singleArgumentSubstringOperator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
Override the default SubstringSingleArg operator.
SingleTableMultitenantPolicy - Class in org.eclipse.persistence.descriptors
A single table "striped" multitenant policy.
SingleTableMultitenantPolicy(ClassDescriptor) - Constructor for class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
 
SINGLETON - Static variable in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
SINGLETON - Static variable in class org.eclipse.persistence.internal.helper.ExplainDeadLockUtil
 
sinh() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
sinh(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Sinh - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
size - Variable in class org.eclipse.persistence.internal.sessions.AbstractRecord
PERF: Cache the row size.
size - Variable in class org.eclipse.persistence.queries.BatchFetchPolicy
Define the batch size for IN style batch fetching.
size - Variable in class org.eclipse.persistence.queries.Cursor
Cached size of the stream.
size - Variable in class org.eclipse.persistence.sequencing.Sequence
 
size - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
size - Variable in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
 
size() - Method in annotation type org.eclipse.persistence.annotations.BatchFetch
Define the default batch fetch size.
size() - Method in annotation type org.eclipse.persistence.annotations.Cache
(Optional) The size of cache to use.
size() - Method in class org.eclipse.persistence.eis.EISMappedRecord
Forward the request to the record.
size() - Method in class org.eclipse.persistence.indirection.IndirectList
 
size() - Method in class org.eclipse.persistence.indirection.IndirectMap
 
size() - Method in class org.eclipse.persistence.indirection.IndirectSet
 
size() - Method in class org.eclipse.persistence.internal.expressions.TableAliasLookup
size method comment.
size() - Method in class org.eclipse.persistence.internal.helper.IdentityHashSet
 
size() - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
 
size() - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
Returns the number of contents in this list.
size() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
size() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
size() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
size() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
size() - Method in class org.eclipse.persistence.internal.oxm.record.MarshalRecord.CycleDetectionStack
 
size() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.EntrySet
 
size() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Return the number of field/value pairs in the row.
size() - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
PUBLIC: Return the number of field/value pairs in the row.
size() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
Return the number of elements in the DOM.
size() - Method in class org.eclipse.persistence.queries.Cursor
PUBLIC: Retrieve the size of the open cursor by executing a count on the same query as the cursor.
size() - Method in class org.eclipse.persistence.queries.ReportQueryResult.EntrySet
 
size() - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Return the number of name/value pairs in the result.
size(Class<?>) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: A logical expression for the size of collection expression.
size(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: A logical expression for the size of collection attributeName.
SIZE_MISMATCH_OF_FOREIGN_KEYS - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
SIZE_ONLY_SUPPORTED_ON_EXPRESSION_QUERIES - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
sizeFor(Object) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Return the size of container.
sizeFor(Object) - Method in class org.eclipse.persistence.internal.queries.CollectionContainerPolicy
INTERNAL: Return the size of container.
sizeFor(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return the size of container.
sizeFor(Object) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Return the size of container.
sizeFor(Object) - Method in class org.eclipse.persistence.queries.CursorPolicy
INTERNAL: Return the size of container.
sizeMismatchOfForeignKeys(ForeignReferenceMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
sizeOnlySupportedOnExpressionQueries(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
sizeQuery - Variable in class org.eclipse.persistence.queries.CursoredStreamPolicy
 
skippedEntity(String) - Method in class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
skippedEntity(String) - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
skippedEntity(String) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
skippedEntity(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmappedContentHandlerWrapper
 
skippedEntity(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
skippedEntity(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
skippedEntity(String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
skippedEntity(String) - Method in class org.eclipse.persistence.internal.oxm.unmapped.DefaultUnmappedContentHandler
 
skippedEntity(String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
skippedEntity(String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
skippedEntity(String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
skippedEntity(String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
skippedEntity(String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
skippedEntity(String) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
SLASH_N - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
SLASH_R - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
SMALLINT_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
SmartMerge - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Used for merging dependent values without use of WL SessionAccessor
Soft - Static variable in class org.eclipse.persistence.config.CacheType
A Soft cache holds all objects read by the application, but allows any un-referenced objects to be free to garbage collection only when the JVM decides memory is low.
SOFT - org.eclipse.persistence.annotations.CacheType
Similar to the FULL identity map except that the map holds the objects using soft references.
SOFT_WEAK - org.eclipse.persistence.annotations.CacheType
Similar to the WEAK identity map except that it maintains a most-frequently-used sub-cache.
SoftCacheKey - Class in org.eclipse.persistence.internal.identitymaps
Purpose: Container class for storing objects in an IdentityMap.
SoftCacheKey(Object, Object, Object, long, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.SoftCacheKey
Initialize the newly allocated instance of this class.
SoftCacheWeakIdentityMap - Class in org.eclipse.persistence.internal.identitymaps
Purpose: A SoftCacheWeakIdentityMap is identical to the WeakIdentityMap, however the weak reference can be a performance problem for some types of apps because it can cause too much garbage collection of objects read causing them to be re-read and re-built (this defeats the purpose of the cache).
SoftCacheWeakIdentityMap(int, ClassDescriptor, AbstractSession, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.SoftCacheWeakIdentityMap
 
SoftCacheWeakIdentityMap_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
SoftIdentityMap - Class in org.eclipse.persistence.internal.identitymaps
Purpose: A SoftIdentityMap holds all objects referenced by the application.
SoftIdentityMap(int, ClassDescriptor, AbstractSession, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.SoftIdentityMap
 
SoftIdentityMap_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
SoftWeak - Static variable in class org.eclipse.persistence.config.CacheType
A SoftWeak cache holds all objects in use by the application, and a fixed size sub-cache of MRU objects using Soft references.
some() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the SOME operator.
some(boolean[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
some(byte[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that is used with a comparison expression.
some(char[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
some(double[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
some(float[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
some(int[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
some(long[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
some(short[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
some(Object[]) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
some(List) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that checks if the receivers value is contained in the collection.
some(Expression) - Method in class org.eclipse.persistence.expressions.Expression
 
some(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
 
Some - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
SOP_OBJECT_DESERIALIZE_FAILED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
SOP_OBJECT_IS_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
SOP_OBJECT_WRONG_PK - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
SOP_OBJECT_WRONG_VERSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
sopObject - Variable in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL: SerializedObjectPolicy support
sopObjectDeserializeFailed(DatabaseQuery, DatabaseField, AbstractRecord, Exception) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
sopObjectIsNotFound(DatabaseQuery, DatabaseField, AbstractRecord) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
sopObjectWrongPk(DatabaseQuery, Object, DatabaseField, AbstractRecord) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
sopObjectWrongVersion(DatabaseQuery, Object, DatabaseField, AbstractRecord) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
sort(Comparator<? super E>) - Method in class org.eclipse.persistence.indirection.IndirectList
 
sort(Comparator<? super E>) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
SortedCollectionContainerPolicy - Class in org.eclipse.persistence.internal.queries
Purpose: A SortedCollectionContainerPolicy is ContainerPolicy whose container class implements the SortedInterface interface.
SortedCollectionContainerPolicy() - Constructor for class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
INTERNAL: Construct a new policy.
SortedCollectionContainerPolicy(Class<?>) - Constructor for class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
INTERNAL: Construct a new policy for the specified class.
SortedCollectionContainerPolicy(String) - Constructor for class org.eclipse.persistence.internal.queries.SortedCollectionContainerPolicy
INTERNAL: Construct a new policy for the specified class name.
SortedSet_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
sortFields(Vector<DatabaseField>, Vector<DatabaseField>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
This method will sort the fields in correct order based on the column names.
sortImports() - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
sortMappings(Vector<DatabaseMapping>) - Method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
Short the mappings by type.
sortMethods() - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
sortOuterJoinExpressionHolders(List<OuterJoinExpressionHolder>) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
soundex() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
Soundex - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
SOURCE - Variable in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
sourceAttributeName - Variable in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
sourceClassName - Variable in class org.eclipse.persistence.logging.SessionLogEntry
 
sourceExpressionsToPostInitialize - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
Keep a reference to the source and target expressions to post initialize when building a selection criteria early.
sourceExpressionsToPostInitialize - Variable in class org.eclipse.persistence.mappings.OneToOneMapping
Keep a reference to the source and target expressions to post initialize when building a selection criteria early.
sourceFields - Variable in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
sourceFields - Variable in class org.eclipse.persistence.tools.schemaframework.UniqueKeyConstraint
 
sourceForeignKeyFields - Variable in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
The (typically primary) source key fields that are referenced by the targetForeignKeyFields.
sourceForeignKeysToTargetKeys - Variable in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
This maps the source foreign key fields to the corresponding (primary) target key fields.
sourceKeyFields - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
This is a primary key in the source table that is used as foreign key in the target table
sourceKeyFields - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
sourceKeyFields - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
The (typically primary) source key fields that are referenced by the targetForeignKeyFields.
sourceKeyFields - Variable in class org.eclipse.persistence.mappings.RelationTableMechanism
The field in the source table that corresponds to the key in the relation table
sourceKeysToTargetForeignKeys - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
This maps the (primary) source key fields to the corresponding target foreign key fields.
sourceMapping - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Table per class requires multiple query executions.
sourceMethodName - Variable in class org.eclipse.persistence.logging.SessionLogEntry
 
sourceObject - Variable in exception org.eclipse.persistence.exceptions.ConversionException
 
sourceObject - Variable in class org.eclipse.persistence.internal.indirection.QueryBasedValueHolder
 
sourceObject - Variable in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
sourceObject - Variable in class org.eclipse.persistence.internal.oxm.Reference
 
sourceRelationKeyFields - Variable in class org.eclipse.persistence.mappings.RelationTableMechanism
The field in the intermediate table that corresponds to the key in the source table
sourceToTargetKeyFieldAssociations - Variable in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
 
sourceToTargetKeyFields - Variable in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
Maps the source foreign/primary key fields to the target primary/foreign key fields.
sourceToTargetKeyFields - Variable in class org.eclipse.persistence.mappings.OneToOneMapping
Maps the source foreign/primary key fields to the target primary/foreign key fields.
sourceToTargetKeys - Variable in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
 
sourceToTargetQueryKeyNames - Variable in class org.eclipse.persistence.mappings.VariableOneToOneMapping
 
SPACE - Static variable in class org.eclipse.persistence.internal.helper.Helper
formatting strings for indenting
SPACE - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
Space.
SPACE - Static variable in class org.eclipse.persistence.oxm.record.OutputStreamRecord
 
SpatialExpressionOperators - Class in org.eclipse.persistence.internal.expressions
INTERNAL: This class produces a number of ExpressionOperators for spatial classes The static methods in this class are used by Oracle9Platform to initialize these operators.
SpatialExpressionOperators() - Constructor for class org.eclipse.persistence.internal.expressions.SpatialExpressionOperators
 
specialOperations - Variable in class org.eclipse.persistence.queries.QueryByExamplePolicy
 
specified() - Method in annotation type org.eclipse.persistence.annotations.TimeOfDay
Internal use.
SPECIFIED_PARTIAL_ATTRIBUTE_DOES_NOT_EXIST - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
specifiedLockingFieldsNotFoundInDatabase(String) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
specifiedPartialAttributeDoesNotExist(DatabaseQuery, String, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
spliterator() - Method in class org.eclipse.persistence.indirection.IndirectList
 
spliterator() - Method in class org.eclipse.persistence.indirection.IndirectSet
 
spliterator() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
sql(String, List) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Parse the SQL for parameter and return a custom function expression using a custom operator that will print itself as the SQL.
SQL - org.eclipse.persistence.logging.LogCategory
 
SQL - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
SQL_CALL_DEFERRAL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jpa.sqlcall.deferral.default" property defines if SQL calls should be deferred to end of transaction by default or not.
SQL_CAST - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jdbc.sql-cast" property specifies if platform specific CAST SQL operations should be used.
SQL_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
SQL_STATEMENT_NOT_SET_PROPERLY - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
SQLAnywhere - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
SQLAnywherePlatform - Class in org.eclipse.persistence.platform.database
Provides SQL Anywhere specific behaviour.
SQLAnywherePlatform() - Constructor for class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
SQLCall - Class in org.eclipse.persistence.queries
Purpose: Used as an abstraction of an SQL call.
SQLCall() - Constructor for class org.eclipse.persistence.queries.SQLCall
PUBLIC: Create a new SQL call.
SQLCall(String) - Constructor for class org.eclipse.persistence.queries.SQLCall
PUBLIC: Create a new SQL call.
SQLDATE - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
sqlDateFromUtilDate(Date) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a sql.Date from a timestamp.
SQLDeleteAllStatement - Class in org.eclipse.persistence.internal.expressions
Purpose: Print DELETE statement with non trivial WHERE clause
SQLDeleteAllStatement() - Constructor for class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
SQLDeleteAllStatementForTempTable - Class in org.eclipse.persistence.internal.expressions
 
SQLDeleteAllStatementForTempTable() - Constructor for class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatementForTempTable
 
SQLDeleteStatement - Class in org.eclipse.persistence.internal.expressions
Purpose: Print DELETE statement.
SQLDeleteStatement() - Constructor for class org.eclipse.persistence.internal.expressions.SQLDeleteStatement
 
sqlException(SQLException) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
sqlException(SQLException, boolean) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
sqlException(SQLException, Accessor, AbstractSession, boolean) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
sqlException(SQLException, AbstractSession, boolean) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
sqlException(SQLException, Call, Accessor, AbstractSession, boolean) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
SqlGeneration - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
SQLInsertStatement - Class in org.eclipse.persistence.internal.expressions
Purpose: Print INSERT statement.
SQLInsertStatement() - Constructor for class org.eclipse.persistence.internal.expressions.SQLInsertStatement
 
SQLModifyAllStatementForTempTable - Class in org.eclipse.persistence.internal.expressions
 
SQLModifyAllStatementForTempTable() - Constructor for class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
SQLModifyStatement - Class in org.eclipse.persistence.internal.expressions
Purpose: Mirror SQL behavior.
SQLModifyStatement() - Constructor for class org.eclipse.persistence.internal.expressions.SQLModifyStatement
 
SqlPrepare - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
SQLResult - Class in org.eclipse.persistence.queries
Purpose: An abstract superclass that represents the commonalities between the main result types of the SQLResultSetMapping
SQLResult() - Constructor for class org.eclipse.persistence.queries.SQLResult
 
sqlResultSetMapping - Variable in class org.eclipse.persistence.queries.SQLResult
 
SQLResultSetMapping - Class in org.eclipse.persistence.queries
Purpose: Concrete class to represent the SQLResultSetMapping structure as defined by the EJB 3.0 Persistence specification.
SQLResultSetMapping(Class<?>) - Constructor for class org.eclipse.persistence.queries.SQLResultSetMapping
Defaulting constructor.
SQLResultSetMapping(String) - Constructor for class org.eclipse.persistence.queries.SQLResultSetMapping
 
sqlResultSetMappings - Variable in class org.eclipse.persistence.sessions.Project
This a collection of 'maps' that allow users to map custom SQL to query results
SQLSelectStatement - Class in org.eclipse.persistence.internal.expressions
Purpose: Print SELECT statement.
SQLSelectStatement() - Constructor for class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
SQLServer - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
SQLServerPlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides SQL Server specific behavior.
SQLServerPlatform() - Constructor for class org.eclipse.persistence.platform.database.SQLServerPlatform
 
sqlStatement - Variable in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
 
SQLStatement - Class in org.eclipse.persistence.internal.expressions
Purpose: Mirror SQL behavior.
SQLStatement() - Constructor for class org.eclipse.persistence.internal.expressions.SQLStatement
Default constructor.
sqlStatementNotSetProperly(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
sqlStatements - Variable in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Normally only a single statement is used, however multiple table may require multiple statements on write.
sqlString - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
The SQL string to execute.
sqlStrings - Variable in class org.eclipse.persistence.internal.databaseaccess.DynamicSQLBatchWritingMechanism
This variable is used to store the SQLStrings that are being batched
sqlType - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
Respective JDBC type of the field's value.
sqlTypeName - Variable in class org.eclipse.persistence.mappings.structures.ObjectRelationalDatabaseField
 
SQLUpdateAllStatement - Class in org.eclipse.persistence.internal.expressions
 
SQLUpdateAllStatement() - Constructor for class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
SQLUpdateAllStatementForOracleAnonymousBlock - Class in org.eclipse.persistence.internal.expressions
 
SQLUpdateAllStatementForOracleAnonymousBlock() - Constructor for class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
SQLUpdateAllStatementForTempTable - Class in org.eclipse.persistence.internal.expressions
 
SQLUpdateAllStatementForTempTable() - Constructor for class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForTempTable
 
SQLUpdateStatement - Class in org.eclipse.persistence.internal.expressions
Purpose: Print UPDATE statement.
SQLUpdateStatement() - Constructor for class org.eclipse.persistence.internal.expressions.SQLUpdateStatement
 
sqrt() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
sqrt(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Sqrt - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
sqrtOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
stack - Variable in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
StackUnmarshalNamespaceResolver - Class in org.eclipse.persistence.internal.oxm.record.namespaces
This is a complete UnmarshalNamespaceResolver implementation.
StackUnmarshalNamespaceResolver() - Constructor for class org.eclipse.persistence.internal.oxm.record.namespaces.StackUnmarshalNamespaceResolver
 
Standard - Static variable in class org.eclipse.persistence.config.TunerType
 
standardDeviation() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This represents the aggregate function StandardDeviation.
standardDeviation() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
StandardDeviation - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
StandardSequence - Class in org.eclipse.persistence.sequencing
Purpose: An abstract class providing default sequence behavior.
StandardSequence() - Constructor for class org.eclipse.persistence.sequencing.StandardSequence
 
StandardSequence(String) - Constructor for class org.eclipse.persistence.sequencing.StandardSequence
 
StandardSequence(String, int) - Constructor for class org.eclipse.persistence.sequencing.StandardSequence
 
StandardSequence(String, int, int) - Constructor for class org.eclipse.persistence.sequencing.StandardSequence
 
StandardTuner - Class in org.eclipse.persistence.tools.tuning
Default tuner.
StandardTuner() - Constructor for class org.eclipse.persistence.tools.tuning.StandardTuner
 
START_INDEX_OUT_OF_RANGE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
startCallback() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
startCDATA() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
startCDATA() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
startCDATA() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
startCDATA() - Method in class org.eclipse.persistence.oxm.record.NodeRecord.NodeRecordContentHandler
 
startCDATA() - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
startCDATA() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
startCDATA() - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
startCDATA() - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
startCollection() - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
startCollection() - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
 
startCollection() - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
startCollection() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
startCollection() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
This method is used to inform the MarshalRecord that the element events it is about to receive are part of a collection.
startDelimiter - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Delimiter to use for fields and tables using spaces or other special values
startDiscovery() - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
ADVANCED: Announce the local service and join the cluster
startDocument() - Method in class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
startDocument() - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
startDocument() - Method in class org.eclipse.persistence.internal.oxm.record.DOMReader
Trigger a startDocument event on the contenthandler.
startDocument() - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
startDocument() - Method in class org.eclipse.persistence.internal.oxm.record.UnmappedContentHandlerWrapper
 
startDocument() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
startDocument() - Method in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
Trigger a startDocument event on the contenthandler.
startDocument() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
startDocument() - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
startDocument() - Method in class org.eclipse.persistence.internal.oxm.unmapped.DefaultUnmappedContentHandler
 
startDocument() - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
startDocument() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
startDocument() - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
startDocument() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
startDocument() - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
startDocument() - Method in class org.eclipse.persistence.oxm.record.XMLRootRecord
 
startDocument() - Method in class org.eclipse.persistence.oxm.XMLUnmarshallerHandler
 
startDocument() - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
startDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
INTERNAL:
startDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.FormattedOutputStreamRecord
INTERNAL:
startDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.FormattedWriterRecord
 
startDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
 
startDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
startDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
startDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Receive notification that a document is being started.
startDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL:
startDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL:
startDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
startDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL:
startDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
startDocument(String, String) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
startDocument(ErrorHandler) - Method in class org.eclipse.persistence.internal.oxm.IDResolver
Called when unmarshalling begins.
startDTD(String, String, String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
startDTD(String, String, String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
startDTD(String, String, String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
startDTD(String, String, String) - Method in class org.eclipse.persistence.oxm.record.NodeRecord.NodeRecordContentHandler
 
startDTD(String, String, String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
startDTD(String, String, String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
startDTD(String, String, String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
startDTD(String, String, String) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.internal.oxm.record.BinaryDataUnmarshalRecord
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.internal.oxm.record.UnmappedContentHandlerWrapper
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.internal.oxm.SAXFragmentBuilder
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.internal.oxm.unmapped.DefaultUnmappedContentHandler
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryAttachmentHandler
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.oxm.record.NodeRecord.NodeRecordContentHandler
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.oxm.record.XMLRootRecord
 
startElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
startElement(MarshalRecord, XPathFragment, Object, CoreAbstractSession, NamespaceResolver, ObjectBuilder, Object) - Method in class org.eclipse.persistence.internal.oxm.XPathNode
 
startElement(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.ChoiceUnmarshalContext
 
startElement(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectUnmarshalContext
 
startElement(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedUnmarshalContext
 
startElement(UnmarshalRecord) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalContext
An event indicating that startElement has been called on the unmarshalRecord.
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.NodeValue
INTERNAL:
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLAnyObjectMappingNodeValue
 
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLChoiceObjectMappingNodeValue
 
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
 
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
 
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLFragmentMappingNodeValue
 
startElement(XPathFragment, UnmarshalRecord, Attributes) - Method in class org.eclipse.persistence.internal.oxm.XMLVariableXPathMappingNodeValue
 
startEmptyCollection() - Method in class org.eclipse.persistence.oxm.record.JsonGeneratorRecord
 
startEmptyCollection() - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
startEntity(String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
startEntity(String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
startEntity(String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
startEntity(String) - Method in class org.eclipse.persistence.oxm.record.NodeRecord.NodeRecordContentHandler
 
startEntity(String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
startEntity(String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
startEntity(String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
startEntity(String) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
startFields - Variable in class org.eclipse.persistence.history.HistoryPolicy
 
startIndexOutOfRange() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
startIterationOn(Object) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
This is the root method called to start the iteration.
startIterationOn(Object, AttributeGroup) - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
startListening() - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
INTERNAL: This method puts us into the listening mode loop.
startOperationProfile() - Method in class org.eclipse.persistence.sessions.SessionEventManager
INTERNAL: Start call
startOperationProfile(String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Start the operation timing.
startOperationProfile(String) - Method in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
Profile the operation.
startOperationProfile(String) - Method in interface org.eclipse.persistence.sessions.SessionProfiler
INTERNAL: Start the operation timing.
startOperationProfile(String) - Method in class org.eclipse.persistence.sessions.SessionProfilerAdapter
INTERNAL: Start the operation timing.
startOperationProfile(String) - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
INTERNAL: Start the operation timing.
startOperationProfile(String) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
INTERNAL: Start the operation timing.
startOperationProfile(String, DatabaseQuery, int) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Start the operation timing.
startOperationProfile(String, DatabaseQuery, int) - Method in interface org.eclipse.persistence.sessions.SessionProfiler
INTERNAL: Start the operation timing.
startOperationProfile(String, DatabaseQuery, int) - Method in class org.eclipse.persistence.sessions.SessionProfilerAdapter
INTERNAL: Start the operation timing.
startOperationProfile(String, DatabaseQuery, int) - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
INTERNAL: Start the operation timing.
startOperationProfile(String, DatabaseQuery, int) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
INTERNAL: Start the operation timing.
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.internal.oxm.FragmentContentHandler
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.internal.oxm.MarshalRecordContentHandler
 
startPrefixMapping(String, String) - Method in interface org.eclipse.persistence.internal.oxm.record.MarshalRecord
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshallerHandler
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmappedContentHandlerWrapper
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter.ExtendedContentHandlerAdapter
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.internal.oxm.unmapped.DefaultUnmappedContentHandler
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
INTERNAL:
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
Receive notification that a namespace has been declared.
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.oxm.record.NodeRecord.NodeRecordContentHandler
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
startPrefixMapping(String, String) - Method in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
startPrefixMappings(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.ContentHandlerRecord
 
startPrefixMappings(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL: override so we don't iterate over namespaces when startPrefixMapping doesn't do anything
startPrefixMappings(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
startPrefixMappings(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.NodeRecord
INTERNAL: override so we don't iterate over namespaces when startPrefixMapping doesn't do anything
startPrefixMappings(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL: override so we don't iterate over namespaces when startPrefixMapping doesn't do anything
startPrefixMappings(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
startPrefixMappings(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL: override so we don't iterate over namespaces when startPrefixMapping doesn't do anything
startPrefixMappings(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
startPrefixMappings(NamespaceResolver) - Method in class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
startRootLevelCollection() - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord
 
startRootLevelCollection() - Method in class org.eclipse.persistence.oxm.record.JsonGeneratorRecord
 
startRootLevelCollection() - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
startRootObject() - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord
 
startRootObject() - Method in class org.eclipse.persistence.oxm.record.JsonGeneratorRecord
 
startRootObject() - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
startStrings - Variable in class org.eclipse.persistence.expressions.ListExpressionOperator
 
startUnmappedElement(String, String, String, Attributes) - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
startUp() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: Allocate the minimum connections.
startUp() - Method in class org.eclipse.persistence.sessions.server.ExternalConnectionPool
INTERNAL: Build the default connection.
startValue - Variable in class org.eclipse.persistence.descriptors.partitioning.RangePartition
 
startValue() - Method in annotation type org.eclipse.persistence.annotations.RangePartition
The String representation of the range start value.
startValueName - Variable in class org.eclipse.persistence.descriptors.partitioning.RangePartition
 
startWithExpression - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Used for Oracle Hierarchical Queries
startWithExpression - Variable in class org.eclipse.persistence.queries.ReadAllQuery
Used for Oracle HierarchicalQuery support
state - Variable in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
 
STATE_ACTIVE - Static variable in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
 
STATE_CLOSED - Static variable in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
 
STATE_CLOSING - Static variable in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
 
statement - Variable in class org.eclipse.persistence.expressions.ExpressionBuilder
 
statement - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
statement - Variable in class org.eclipse.persistence.internal.expressions.ExpressionIterator
Some iterations require a statement.
statement - Variable in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
The statement being normalized.
statement - Variable in class org.eclipse.persistence.queries.Cursor
The preparedStatement that holds the handle to the database that the results are read from.
STATEMENT_NOT_EXECUTED_IN_BATCH - Static variable in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
statementCache - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
Stores statement handles for common used prepared statements.
statementCacheSize - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
The statement cache size for prepare parameterized statements.
statementCount - Variable in class org.eclipse.persistence.internal.databaseaccess.BatchWritingMechanism
 
StatementExecute - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
StatementQueryMechanism - Class in org.eclipse.persistence.internal.queries
Purpose: Mechanism used for all statement objects.
StatementQueryMechanism() - Constructor for class org.eclipse.persistence.internal.queries.StatementQueryMechanism
 
StatementQueryMechanism(DatabaseQuery) - Constructor for class org.eclipse.persistence.internal.queries.StatementQueryMechanism
INTERNAL: Return a new mechanism for the query
StatementQueryMechanism(DatabaseQuery, SQLStatement) - Constructor for class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Return a new mechanism for the query
statements - Variable in class org.eclipse.persistence.tools.schemaframework.PackageDefinition
 
statements - Variable in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
 
staticMetamodelClasses - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
This map will hold onto class to static metamodel class references from JPA.
StaticWeaveException - Exception in org.eclipse.persistence.exceptions
 
StaticWeaveException() - Constructor for exception org.eclipse.persistence.exceptions.StaticWeaveException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
StaticWeaveException(String) - Constructor for exception org.eclipse.persistence.exceptions.StaticWeaveException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
StaticWeaveException(String, Throwable) - Constructor for exception org.eclipse.persistence.exceptions.StaticWeaveException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
StaticWeaveExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
 
StaticWeaveExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.StaticWeaveExceptionResource
Default constructor.
statusToString_impl(Object) - Method in class org.eclipse.persistence.transaction.AbstractTransactionController
INTERNAL: Convert the status to a string for tracing.
statusToString_impl(Object) - Method in class org.eclipse.persistence.transaction.JTATransactionController
 
staxResultClass - Static variable in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
staxResultGetEventWriterMethod - Static variable in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
staxResultGetStreamWriterMethod - Static variable in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
STOP_INDEX_OUT_OF_RANGE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
stopDiscovery() - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
ADVANCED: Stop accepting announcements from other services becoming available.
stopIndexOutOfRange() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
stopListening - Variable in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
Indicates to the listening thread that it should stop
stopListening() - Method in class org.eclipse.persistence.sessions.coordination.DiscoveryManager
INTERNAL: Signal this instance to stop listening.
storeBypassCache() - Method in class org.eclipse.persistence.queries.DatabaseQuery
ADVANCED: JPA flag used to control the behavior of the shared cache.
storeDatabaseCounts(Object, ContainerPolicy, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
This method will iterate over the collection and store the database counts for the objects within the collection, this is used for minimal updates.
storedBuffer - Variable in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
storeDeferredModifyAllQuery(DatabaseQuery, AbstractRecord) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Store the deferred UpdateAllQuery's from the UoW in the list for execution.
storeDescriptorByQName(DESCRIPTOR, CorePlatform, Set<DESCRIPTOR>) - Method in class org.eclipse.persistence.internal.oxm.Context.ContextState
INTERNAL:
storeDescriptorsByQName(CoreSession) - Method in class org.eclipse.persistence.internal.oxm.Context.ContextState
 
StoredFunctionCall - Class in org.eclipse.persistence.queries
Purpose: Used to define a platform independent function call.
StoredFunctionCall() - Constructor for class org.eclipse.persistence.queries.StoredFunctionCall
 
StoredFunctionCall(int, String, Class<?>) - Constructor for class org.eclipse.persistence.queries.StoredFunctionCall
 
StoredFunctionCall(int, String, Class<?>, DatabaseField) - Constructor for class org.eclipse.persistence.queries.StoredFunctionCall
 
StoredFunctionCall(int, String, String) - Constructor for class org.eclipse.persistence.queries.StoredFunctionCall
 
StoredFunctionCall(int, String, String, DatabaseField) - Constructor for class org.eclipse.persistence.queries.StoredFunctionCall
 
StoredFunctionDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Allow a semi-generic way of creating store function.
StoredFunctionDefinition() - Constructor for class org.eclipse.persistence.tools.schemaframework.StoredFunctionDefinition
 
STOREDPROCEDURE_STATEMENTS_COUNT_PROPERTY - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
 
StoredProcedureCall - Class in org.eclipse.persistence.queries
Purpose: Used to define a platform independent procedure call.
StoredProcedureCall() - Constructor for class org.eclipse.persistence.queries.StoredProcedureCall
 
StoredProcedureDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Allow a semi-generic way of creating stored procedures.
StoredProcedureDefinition() - Constructor for class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
 
StoredProcedureGenerator - Class in org.eclipse.persistence.tools.schemaframework
Purpose: To generate StoredProcedures from EclipseLink Projects
StoredProcedureGenerator(SchemaManager) - Constructor for class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
 
StoredProcedureParameter - Annotation Type in org.eclipse.persistence.annotations
A StoredProcedureParameter annotation is used within a NamedStoredProcedureQuery annotation.
storedProcedureStatementsCount - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Keep track of the number of the storedprocedure statement that being executed.
storedProcedureTerminationToken - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
The delimiter between stored procedures in multiple stored procedure calls.
storeInCache() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
PUBLIC: Configure the version lock value to be stored in the cache.
storeInObject() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
PUBLIC: Configure the version lock value to be stored in the object.
storeModifyAllQuery(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Store the ModifyAllQuery's from the UoW in the list.
storeXMLDescriptorByQName(XMLDescriptor) - Method in class org.eclipse.persistence.oxm.XMLContext
INTERNAL:
str - Variable in class org.eclipse.persistence.internal.databaseaccess.SimpleAppendCallCustomParameter
 
StrBuffer - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
StrBuffer() - Constructor for class org.eclipse.persistence.internal.oxm.StrBuffer
 
StrBuffer(int) - Constructor for class org.eclipse.persistence.internal.oxm.StrBuffer
 
stream() - Method in class org.eclipse.persistence.indirection.IndirectList
 
stream() - Method in class org.eclipse.persistence.indirection.IndirectSet
 
streamForNonExistentFilePrompt() - Method in class org.eclipse.persistence.tools.PackageRenamer
 
STREAMS_FOR_BINDING_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
STRING - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
STRING - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
STRING_BINDING_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
STRING_LOOKUP - Static variable in class org.eclipse.persistence.sessions.JNDIConnector
 
STRING_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
stringBindingSize - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Indicates the size above which strings will be bound NOTE: does not work with ODBC
stringBuffer - Variable in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
stringFromCalendar(Calendar, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
stringFromDataHandler(DataHandler, QName, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
stringFromDataHandler(Object, QName, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
stringFromDate(Date, QName) - Method in class org.eclipse.persistence.internal.oxm.XMLConversionManager
This method returns a string representing a given java.util.Date based on a given schema type QName.
stringFromImage(Image, QName, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
stringFromMultipart(MimeMultipart, QName, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
stringFromSource(Source, QName, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
StringHelper - Class in org.eclipse.persistence.internal.helper
INTERNAL:
StringHelper() - Constructor for class org.eclipse.persistence.internal.helper.StringHelper
 
Struct - Annotation Type in org.eclipse.persistence.annotations
Struct types are extended object-relational data-types supported by some databases.
STRUCT_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
StructConverter - Interface in org.eclipse.persistence.platform.database.converters
PUBLIC: A StuctConverter can be added to a DatabasePlatform It allows custom processing dealing java.sql.Struct types When added to the DatabasePlatform: 1.
StructConverter - Annotation Type in org.eclipse.persistence.annotations
A StructConverter is a special type of converter that handles the conversion of a specific database Struct type.
StructConverterConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.login
 
StructConverterConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.login.StructConverterConfig
 
structConverters - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
The following two maps, provide two ways of looking up StructConverters.
structConverters - Variable in class org.eclipse.persistence.sessions.Project
 
StructConverters - Annotation Type in org.eclipse.persistence.annotations
A StructConverters annotation allows the definition of multiple StructConverter.
StructConverterType - Class in org.eclipse.persistence.config
This class contains predefined StructConverter types.
Structure - Annotation Type in org.eclipse.persistence.annotations
Struct types are extended object-relational data-types supported by some databases.
STRUCTURE_NAME_NOT_SET_IN_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
StructureMapping - Class in org.eclipse.persistence.mappings.structures
Purpose: A structure is an object-relational user-defined data-type or object-type.
StructureMapping() - Constructor for class org.eclipse.persistence.mappings.structures.StructureMapping
Default constructor.
structureName - Variable in class org.eclipse.persistence.mappings.structures.NestedTableMapping
Arrays require a structure name, this is the ADT defined for the VARRAY.
structureName - Variable in class org.eclipse.persistence.mappings.structures.ObjectArrayMapping
Arrays require a structure name, this is the ADT defined for the VARRAY.
structureName - Variable in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
 
structureNameNotSetInMapping(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
SUB_SESSION_NOT_DEFINED_FOR_BROKER - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
SUBCLASS_ATTEMPTED_TO_OVERRIDE_NAMESPACE_DECLARATION - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
SUBCLASS_CANNOT_HAVE_XMLVALUE - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
subclassAttemptedToOverrideNamespaceDeclaration(String, String, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
subClasses - Variable in class org.eclipse.persistence.core.queries.CoreAttributeGroup
This attribute references the immediate subclass groups for this attributeGroup.
subclassSubgraphs() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNamedObjectGraph
Optional: a list of named subgraphs for any subclasses of this class.
subgraph() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNamedAttributeNode
optional: if this property referenced another JAXB Object, specify the name of the object graph to use for that nested object.
subgraphs() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNamedObjectGraph
Optional: a list of named subgraphs that are referenced from the property entries.
subGroups - Variable in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
subList(int, int) - Method in class org.eclipse.persistence.indirection.IndirectList
 
subList(int, int) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
subList(int, int) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
subList(int, int) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
If index is missing wait until reached or complete.
subQuery - Variable in class org.eclipse.persistence.internal.expressions.SubSelectExpression
 
subQuery(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a sub query expression.
subscriber - Variable in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
 
subSelect - Variable in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
Allows a sub-select to be defined from clause.
SubSelectDatabaseTable - Class in org.eclipse.persistence.internal.expressions
INTERNAL: Allow a table to reference a sub-select to support sub-selects in the from clause.
SubSelectDatabaseTable(Expression) - Constructor for class org.eclipse.persistence.internal.expressions.SubSelectDatabaseTable
 
SubSelectExpression - Class in org.eclipse.persistence.internal.expressions
This is used to support subselects.
SubSelectExpression() - Constructor for class org.eclipse.persistence.internal.expressions.SubSelectExpression
 
SubSelectExpression(ReportQuery, Expression) - Constructor for class org.eclipse.persistence.internal.expressions.SubSelectExpression
 
subSelectExpressions - Variable in class org.eclipse.persistence.internal.expressions.ExpressionNormalizer
Subselect expressions found in the course of normalization.
subSequence(int, int) - Method in class org.eclipse.persistence.internal.oxm.StrBuffer
 
subSize - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
substring() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
substring() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
INTERNAL: Build FB equivalent to SUBSTR(x, y) FB: SUBSTRING(x FROM y)
substring() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Gets the substring of source bounded by start location to end location.
substring(int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the substring from the source string.
substring(int, int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the substring from the source string.
substring(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the substring from the source string.
substring(Object, Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the substring from the source string.
Substring - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
substring2() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
INTERNAL: Build FB equivalent to SUBSTR(x, y, z) FB: SUBSTRING(x FROM y FOR z)
substringSingleArg() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
SubstringSingleArg - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
subtract() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
subtract(Expression, int) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
subtract(Expression, Object) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Subtract - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
subtractOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Derby requires that at least one argument be a known type
SUFFIX - org.eclipse.persistence.annotations.TenantTableDiscriminatorType
Apply the tenant table discriminator as a suffix to all multitenant tables.
sum() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: This represents the aggregate function Sum.
sum() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the SUM operator.
Sum - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
sumOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
sumOperator() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Disable binding support.
SunAS9PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
SunAS9PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.SunAS9PlatformConfig
 
SunCORBATransportManagerConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.transport
INTERNAL:
SunCORBATransportManagerConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.transport.SunCORBATransportManagerConfig
 
superClass - Variable in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
superClassGroup - Variable in class org.eclipse.persistence.core.queries.CoreAttributeGroup
To add inheritance support the two following attrbutes are used to create a model of the inheritance tree This attribute points to the parent AttributeGroup of this attribute group.
supportsANSIInnerJoinSyntax() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Indicates whether the ANSI syntax for inner joins (e.g.
supportsANSIInnerJoinSyntax() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Indicates whether the ANSI syntax for inner joins (e.g.
supportsAutoCommit - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Some JDBC drivers do not support AutoCommit in the way EclipseLink expects.
supportsAutoCommit() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
supportsAutoCommit must sometimes be set to false for JDBC drivers which do not support autocommit.
supportsAutoConversionToNumericForArithmeticOperations() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Some db allow VARCHAR db field to be used in arithmetic operations automatically converting them to numeric: UPDATE OL_PHONE SET PHONE_ORDER_VARCHAR = (PHONE_ORDER_VARCHAR + 1) WHERE ...
supportsAutoConversionToNumericForArithmeticOperations() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
Some db allow VARCHAR db field to be used in arithmetic operations automatically converting them to numeric: UPDATE OL_PHONE SET PHONE_ORDER_VARCHAR = (PHONE_ORDER_VARCHAR + 1) WHERE ...
supportsAutoConversionToNumericForArithmeticOperations() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Some db allow VARCHAR db field to be used in arithmetic operations automatically converting them to numeric: UPDATE OL_PHONE SET PHONE_ORDER_VARCHAR = (PHONE_ORDER_VARCHAR + 1) WHERE ...
supportsChangeTracking(Project) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Returns whether this descriptor is capable of supporting weaved change tracking.
supportsConnectionUserName() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Override this method if the platform supports storing JDBC connection user name during DatabasePlatform.initializeConnectionData(Connection).
supportsCountDistinctWithMultipleFields() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether the platform supports the count distinct function with multiple fields.
supportsCountDistinctWithMultipleFields() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Indicates whether the platform supports the count distinct function with multiple fields.
supportsDeleteOnCascade() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
supportsDeleteOnCascade() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Setting this to false (cf.
supportsDeleteOnCascade() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
SQL Anywhere does support cascade on delete, unlike Sybase.
supportsDeleteOnCascade() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Sybase (as of Sybase ASE 15, does not support delete on cascade).
supportsForeignKeyConstraints() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
supportsForeignKeyConstraints() - Method in class org.eclipse.persistence.platform.database.AttunityPlatform
Attunity Connect does not support creating foreign key constraints with the ALTER TABLE syntax.
supportsForeignKeyConstraints() - Method in class org.eclipse.persistence.platform.database.DBasePlatform
 
supportsForeignKeyConstraints() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
 
supportsForeignKeyConstraints() - Method in class org.eclipse.persistence.platform.database.H2Platform
 
supportsForeignKeyConstraints() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
supportsForeignKeyConstraints() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Symfoware does not support foreign key constraint syntax, so returns false.
supportsForeignKeyConstraints() - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
 
supportsGlobalTempTables() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether the platform supports global temporary tables.
supportsGlobalTempTables() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 supports temp tables.
supportsGlobalTempTables() - Method in class org.eclipse.persistence.platform.database.H2Platform
 
supportsGlobalTempTables() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
supportsGlobalTempTables() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
 
supportsGlobalTempTables() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL supports temp tables for update-all, delete-all queries.
supportsGlobalTempTables() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
 
supportsGlobalTempTables() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL:
supportsGlobalTempTables() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Indicates whether the platform supports global temporary tables.
supportsIdentity - Variable in class org.eclipse.persistence.platform.database.OraclePlatform
Advanced attribute indicating whether identity is supported, see comment to setSupportsIdentity method.
supportsIdentity() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Indicates whether the platform supports identity.
supportsIdentity() - Method in class org.eclipse.persistence.platform.database.AccessPlatform
INTERNAL: Indicates whether the platform supports identity.
supportsIdentity() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: Indicates whether the platform supports identity.
supportsIdentity() - Method in class org.eclipse.persistence.platform.database.H2Platform
 
supportsIdentity() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
 
supportsIdentity() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
INTERNAL: Indicates whether the platform supports identity.
supportsIdentity() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Indicates whether the platform supports identity.
supportsIdentity() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Indicates whether the platform supports identity.
supportsIdentity() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Indicates whether the platform supports identity.
supportsIdentity() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Indicates whether the platform supports identity.
supportsIdentity() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
supportsIdentity() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Indicates whether the platform supports identity.
supportsIdentity() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Indicates whether the platform supports identity.
supportsIndexes() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Return if this database support index creation.
supportsIndividualTableLocking() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether locking clause could be selectively applied only to some tables in a ReadQuery.
supportsIndividualTableLocking() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
supportsIndividualTableLocking() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
supportsIndividualTableLocking() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Indicates whether locking clause could be selectively applied only to some tables in a ReadQuery.
supportsIndividualTableLocking() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Indicates whether locking clause could be selectively applied only to some tables in a ReadQuery.
Symfoware platform currently only supports FOR UPDATE locking, which cannot be applied to queries that select from multiple tables.
supportsLocalTempTables() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether the platform supports local temporary tables.
supportsLocalTempTables() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
supportsLocalTempTables() - Method in class org.eclipse.persistence.platform.database.Informix11Platform
Returns true when invoked to indicate that Informix does indeed support local temporary tables.
supportsLocalTempTables() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
supportsLocalTempTables() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
INTERNAL:
supportsLocalTempTables() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL:
supportsLocalTempTables() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
supportsLocalTempTables() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL:
supportsLocalTransactions - Variable in class org.eclipse.persistence.eis.EISPlatform
Allows for usage of transaction to be disabled if not supported.
supportsLocalTransactions() - Method in class org.eclipse.persistence.eis.EISPlatform
Return if this platform supports local transactions.
supportsLockingQueriesWithMultipleTables() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether locking clause could be applied to the query that has more than one table
supportsLockingQueriesWithMultipleTables() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 does not seem to allow FOR UPDATE on queries with multiple tables.
supportsLockingQueriesWithMultipleTables() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
INTERNAL: Indicates whether locking clause could be applied to the query that has more than one table
supportsLockingQueriesWithMultipleTables() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Indicates whether locking clause could be applied to the query that has more than one table.
Symfoware platform currently only supports FOR UPDATE locking, which cannot be applied to queries that select from multiple tables.
supportsMediaType(MediaType) - Method in class org.eclipse.persistence.oxm.NamespacePrefixMapper
Return true if this prefix mapper applies to the media type provided.
supportsNativeSequenceNumbers() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
supportsNativeSequenceNumbers() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
supportsNativeSequenceNumbers() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
supportsNestingOuterJoins() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Return if nesting outer joins is supported, i.e.
supportsNestingOuterJoins() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
Does not allow nesting outer joins, i.e.
supportsOrderByParameters() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Used to determine if the platform supports untyped parameters, as ordinal variables, within the Order By clause
supportsOrderByParameters() - Method in class org.eclipse.persistence.platform.database.DB2Platform
DB2 disables single parameter usage in ORDER BY clause.
supportsOuterJoinsWithBrackets() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Return if brackets can be used in the ON clause for outer joins.
supportsOuterJoinsWithBrackets() - Method in class org.eclipse.persistence.platform.database.DB2MainframePlatform
INTERNAL: Return if brackets can be used in the ON clause for outer joins.
supportsPrimaryKeyConstraint() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
supportsPrimaryKeyConstraint() - Method in class org.eclipse.persistence.platform.database.AttunityPlatform
Attunity Connect does not support specifying the primary key in the create table syntax.
supportsPrimaryKeyConstraint() - Method in class org.eclipse.persistence.platform.database.DBasePlatform
 
supportsResultSetAccessOptimizationOnExecute() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Indicates whether the query can use ResultSet optimization.
supportsResultSetAccessOptimizationOnExecute() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Indicates whether the query can use ResultSet optimization.
supportsResultSetAccessOptimizationOnPrepare() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Indicates whether the query can use ResultSet optimization.
supportsResultSetAccessOptimizationOnPrepare() - Method in class org.eclipse.persistence.queries.ReadAllQuery
INTERNAL: Indicates whether the query can use ResultSet optimization.
supportsReturnGeneratedKeys - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
This property configures if the database platform will use Statement.getGeneratedKeys(), or a separate query, in order to obtain javax.persistence.GenerationType.IDENTITY generated values.
supportsReturnGeneratedKeys() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Indicates whether the platform supports the use of Statement.RETURN_GENERATED_KEYS.
supportsSelectForUpdateNoWait() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Returns true if the database supports SQL syntax not to wait on a SELECT..FOR UPADTE (i.e.
supportsSequenceObjects() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Indicates whether the platform supports sequence objects.
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 added SEQUENCE support as of (I believe) v8.
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL: Derby supports sequence objects as of 10.6.1.
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.FirebirdPlatform
 
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.H2Platform
 
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
 
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.InformixPlatform
INTERNAL: Indicates whether the platform supports sequence objects.
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.MariaDBPlatform
INTERNAL: Indicates whether the platform supports sequence objects.
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Indicates whether the platform supports sequence objects.
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Indicates whether the platform supports sequence objects.
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL:
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Indicates whether the platform supports sequence objects.
Symfoware does through global sequence objects.
supportsSequenceObjects() - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
INTERNAL: Indicates whether the platform supports sequence objects.
supportsStoredFunctions() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
supportsStoredFunctions() - Method in class org.eclipse.persistence.platform.database.H2Platform
 
supportsStoredFunctions() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
supportsStoredFunctions() - Method in class org.eclipse.persistence.platform.database.MaxDBPlatform
 
supportsStoredFunctions() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
 
supportsStoredFunctions() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: Return if database stored functions are supported.
supportsStoredFunctions() - Method in class org.eclipse.persistence.platform.database.SQLAnywherePlatform
 
supportsStoredFunctions() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Indicates whether the platform supports stored functions.
Although Symfoware supports some stored functions as function routines, their functionality is incompatible with the one EclipseLink provides.
supportsTempTables() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether the platform supports temporary tables.
supportsUniqueColumns() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allows unique columns to be defined as constraint if the UNIQUE keyword is not support on a column defintion.
supportsUniqueColumns() - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
HSQL (1.8.1) does not support the UNIQUE key word in a column, but does support unique constraints defined separately.
supportsUniqueKeyConstraints() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
supportsUniqueKeyConstraints() - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Symfoware supports unique key constraints, so returns true.
Do note that unique constraints cannot be added/removed using "ALTER TABLE ADD/DROP CONSTRAINT" syntax.
supportsVPD() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
By default, platforms do not support VPD.
supportsVPD() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Oracle db supports VPD.
supportsWaitForUpdate() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Indicates whether the platform supports timeouts on For Update
supportsWaitForUpdate() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
 
supportsWriteLockValuesComparison() - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Indicates whether compareWriteLockValues method is supported by the policy.
supportsWriteLockValuesComparison() - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Indicates that compareWriteLockValues method is supported by the policy.
supportsWriteLockValuesComparison() - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: Indicates whether compareWriteLockValues method is supported by the policy.
SWA_REF - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
SWA_REF_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
SWAREF_LOCATION - Static variable in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
 
SWAREF_XSD - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
switchMechanisms(AbstractSession, DatabaseCall) - Method in class org.eclipse.persistence.internal.databaseaccess.DynamicSQLBatchWritingMechanism
INTERNAL: This method is used to switch from this mechanism to the alternate automatically
switchMechanisms(AbstractSession, DatabaseCall) - Method in class org.eclipse.persistence.internal.databaseaccess.ParameterizedSQLBatchWritingMechanism
INTERNAL: Swaps out the Mechanism for the other Mechanism
Sybase - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
sybaseAddMonthsOperator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Function, to add months to a date.
sybaseInStringOperator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Build instring operator
sybaseLocate2Operator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Build the Sybase equivalent to Locate with a start index.
sybaseLocateOperator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Build the Sybase equivalent to Locate
SybasePlatform - Class in org.eclipse.persistence.platform.database
Purpose: Provides Sybase ASE specific behavior.
SybasePlatform() - Constructor for class org.eclipse.persistence.platform.database.SybasePlatform
 
sybaseToCharOperator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Build Sybase equivalent to TO_CHAR.
sybaseToCharWithFormatOperator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Build Sybase equivalent to TO_CHAR.
sybaseToDateOperator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Build Sybase equivalent to TO_DATE.
sybaseToDateToStringOperator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Build Sybase equivalent to TO_CHAR.
sybaseToNumberOperator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Build Sybase equivalent to TO_NUMBER.
Symfoware - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
SymfowarePlatform - Class in org.eclipse.persistence.platform.database
Symfoware Server
SymfowarePlatform() - Constructor for class org.eclipse.persistence.platform.database.SymfowarePlatform
 
SynchronizationListenerFactory - Interface in org.eclipse.persistence.transaction
Purpose: Generate synchronization listener objects of the appropriate type.
synchronizeAndResume() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL Synchronize the clones and update their backup copies.
synchronizeAndResume() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL Synchronize the clones and update their backup copies.
SYNCHRONIZED_READ_ON_WRITE - Static variable in class org.eclipse.persistence.sessions.DatasourceLogin
Reads and unit of work merges will be serialized.
SYNCHRONIZED_UNITOFWORK_DOES_NOT_SUPPORT_COMMITANDRESUME - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
SYNCHRONIZED_WRITE - Static variable in class org.eclipse.persistence.sessions.DatasourceLogin
Reads can occur concurrently but unit of work merges will be serialized.
synchronizedUnitOfWorkDoesNotSupportCommitAndResume() - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
synchronousPropagateCommand() - Method in class org.eclipse.persistence.internal.sessions.coordination.CommandPropagator
INTERNAL: Synchronously propagate the command
SYNCRONIZED_OBJECT_LEVEL_READ_WRITE - Static variable in class org.eclipse.persistence.sessions.DatasourceLogin
Writes to the cache (merge, object build/refresh will be synchronized as will cache access (cloning) based on when access is required.
SYNCRONIZED_OBJECT_LEVEL_READ_WRITE_DATABASE - Static variable in class org.eclipse.persistence.sessions.DatasourceLogin
Writes to the cache (merge, object build/refresh will be synchronized as will cache access (cloning) based on database transaction.
syntaxError - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
syntaxError(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
syntaxErrorAt - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
syntaxErrorAt(String, int, int, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
SYSTEM_OUT - Static variable in class org.eclipse.persistence.tools.PackageRenamer
 
systemBug(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Can be used to mark code if a workaround is added for a JDBC driver or other bug.
SystemProperties - Class in org.eclipse.persistence.config
This class provides the list of System properties that are recognized by EclipseLink.
SystemProperties() - Constructor for class org.eclipse.persistence.config.SystemProperties
 
systemTime - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
Stored so that all objects merged by a merge manager can have the same readTime.

T

tab - Static variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
tab() - Method in class org.eclipse.persistence.internal.codegen.CodeGenerator
 
tab(int) - Method in class org.eclipse.persistence.internal.codegen.CodeGenerator
 
TAB - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
Horizontal tab.
table - Variable in class org.eclipse.persistence.internal.expressions.SQLModifyStatement
 
table - Variable in class org.eclipse.persistence.internal.expressions.TableExpression
 
table - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
Fields table (encapsulates name + creator).
table - Variable in class org.eclipse.persistence.sequencing.TableSequence
Hold the database table
table - Variable in class org.eclipse.persistence.tools.schemaframework.TableDefinition
 
table() - Method in annotation type org.eclipse.persistence.annotations.Index
The table to define the index on, defaults to entities primary table.
table() - Method in annotation type org.eclipse.persistence.annotations.TenantDiscriminatorColumn
(Optional) The name of the table that contains the column.
TABLE_CREATION_SUFFIX - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.ddl.table-creation-suffix" property is used in conjunction with DDL generation options to append a string to the end of generated CREATE Table statements.
TABLE_GENERATOR_RESERVED_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
TABLE_IS_NOT_PRESENT_IN_DATABASE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TABLE_NAME_IS_NOT_SET - Static variable in exception org.eclipse.persistence.eis.EISException
 
TABLE_NOT_PRESENT - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TABLE_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TABLE_PER_TENANT - org.eclipse.persistence.annotations.MultitenantType
Specifies that different tables are used for each tenant and used in conjunction with the tenant table discriminator which describes how the tables are uniquely identified, that is, using a suffix/prefix or a separate schema.
tableAliases - Variable in class org.eclipse.persistence.internal.expressions.DataExpression
 
tableAliases - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
 
tableAliasesDescription() - Method in class org.eclipse.persistence.internal.expressions.DataExpression
 
tableAliasInSelectCallForExist - Variable in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
tableAliasInSelectCallForExist - Variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
tableAliasInSelectCallForNotExist - Variable in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
TableAliasLookup - Class in org.eclipse.persistence.internal.expressions
INTERNAL: Represents the aliased tables an ObjectExpression will be translated to, along with any of its derived TableExpressions.
TableAliasLookup() - Constructor for class org.eclipse.persistence.internal.expressions.TableAliasLookup
TableAliasLookup constructor comment.
TableAliasLookup(int) - Constructor for class org.eclipse.persistence.internal.expressions.TableAliasLookup
TableAliasLookup constructor comment.
tableCreationSuffix - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
String used on all table creation statements generated from the DefaultTableGenerator with a session using this project.
tableCreator - Variable in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
 
TableCreator - Class in org.eclipse.persistence.tools.schemaframework
Purpose: This class is responsible for creating the tables defined in the project.
TableCreator() - Constructor for class org.eclipse.persistence.tools.schemaframework.TableCreator
 
TableCreator(List<TableDefinition>) - Constructor for class org.eclipse.persistence.tools.schemaframework.TableCreator
 
TableCreatorClassGenerator - Class in org.eclipse.persistence.sessions.factories
Purpose: Allow for a class storing a TopLink table creator's tables (meta-data) to be generated.
TableCreatorClassGenerator() - Constructor for class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Create a new generator.
TableCreatorClassGenerator(TableCreator) - Constructor for class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Create a new generator to output the table creator.
TableCreatorClassGenerator(TableCreator, String, Writer) - Constructor for class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Create a new generator to output the table creator.
TableCreatorClassGenerator(TableCreator, String, String) - Constructor for class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Create a new generator to output the table creator.
tableDefinition - Variable in class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
 
TableDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Allow a generic way of creating tables on the different platforms.
TableDefinition() - Constructor for class org.eclipse.persistence.tools.schemaframework.TableDefinition
 
tableDefinitions - Variable in class org.eclipse.persistence.tools.schemaframework.TableCreator
 
TableExpression - Class in org.eclipse.persistence.internal.expressions
A TableExpression allows for a raw database table to be referenced in a query.
TableExpression() - Constructor for class org.eclipse.persistence.internal.expressions.TableExpression
 
TableExpression(DatabaseTable) - Constructor for class org.eclipse.persistence.internal.expressions.TableExpression
 
tableGeneratorUsingAReservedName(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
tableIsNotPresentInDatabase(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
tableMap - Variable in class org.eclipse.persistence.tools.schemaframework.DefaultTableGenerator
Used to track the table definition: keyed by the table name, and valued by the table definition object.
tableNameIsNotSet() - Static method in exception org.eclipse.persistence.eis.EISException
 
tableNotPresent(String, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
tableNotSpecified(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
TablePerClassPolicy - Class in org.eclipse.persistence.descriptors
Purpose: Provides the functionality to support a TABLE_PER_CLASS inheritance strategy.
TablePerClassPolicy(ClassDescriptor) - Constructor for class org.eclipse.persistence.descriptors.TablePerClassPolicy
INTERNAL: Create a new policy.
TablePerMultitenantPolicy - Class in org.eclipse.persistence.descriptors
A table per tenant multitenant policy.
TablePerMultitenantPolicy(ClassDescriptor) - Constructor for class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
 
tablePerTenantDescriptors - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
PERF: cache table per tenant descriptors needing to be initialized per EM
tablePerTenantQueries - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
PERF: cache table per tenant queries needing to be initialized per EM
tablePerTenantTables - Variable in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
 
tableQualifier - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Supporting name scopes in database by prefixing the table names with the table qualifier/creator.
tableQualifier - Variable in class org.eclipse.persistence.internal.helper.DatabaseTable
 
tables - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
tables - Variable in class org.eclipse.persistence.exceptions.IntegrityChecker
To load the tables from database
tables - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Tables being selected from.
tables_databaseFieldsToValues - Variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
TableSequence - Class in org.eclipse.persistence.sequencing
Purpose: Defines sequencing through using a SEQUENCE table.
TableSequence() - Constructor for class org.eclipse.persistence.sequencing.TableSequence
 
TableSequence(String) - Constructor for class org.eclipse.persistence.sequencing.TableSequence
Create a new sequence with the name.
TableSequence(String, int) - Constructor for class org.eclipse.persistence.sequencing.TableSequence
Create a new sequence with the name and sequence pre-allocation size.
TableSequence(String, int, int) - Constructor for class org.eclipse.persistence.sequencing.TableSequence
 
TableSequence(String, int, String) - Constructor for class org.eclipse.persistence.sequencing.TableSequence
 
TableSequence(String, int, String, String, String) - Constructor for class org.eclipse.persistence.sequencing.TableSequence
 
TableSequence(String, String) - Constructor for class org.eclipse.persistence.sequencing.TableSequence
Create a new sequence with the name, and the sequence table name.
TableSequence(String, String, String, String) - Constructor for class org.eclipse.persistence.sequencing.TableSequence
Create a new sequence with the name, and the sequence table information.
TableSequenceConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.sequencing
INTERNAL:
TableSequenceConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.sequencing.TableSequenceConfig
 
TableSequenceDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Allow a generic way of creating sequences on the different platforms, and allow optional parameters to be specified.
TableSequenceDefinition(Sequence, boolean) - Constructor for class org.eclipse.persistence.tools.schemaframework.TableSequenceDefinition
INTERNAL: Should be a sequence defining table sequence in the db: either TableSequence DefaultSequence (only if case platform.getDefaultSequence() is a TableSequence).
tablesJoinExpressions - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
tablesToPrimaryKeyFields - Variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
tableToFieldsForGenerationMap - Variable in class org.eclipse.persistence.descriptors.ReturningPolicy
maps ClassDescriptor's tables into Vectors of fields to be used for call generation.
tan() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
tan(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Tan - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
tanh() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
tanh(Expression) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Tanh - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
TARGET_DATABASE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.target-database" property configures the database that will be used controlling custom operations and SQL generation for the specified database.
TARGET_DATABASE_PROPERTIES - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.target-database-properties" property configures additional properties for the configured target-database.
TARGET_FOREIGN_KEYS_SIZE_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_INVOCATION_WHILE_CLONING - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_INVOCATION_WHILE_CONSTRUCTOR_INSTANTIATION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_INVOCATION_WHILE_CONSTRUCTOR_INSTANTIATION_OF_FACTORY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_INVOCATION_WHILE_EVENT_EXECUTION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_INVOCATION_WHILE_GETTING_VALUE_THRU_METHOD_ACCESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_INVOCATION_WHILE_INSTANTIATING_METHOD_BASED_PROXY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_INVOCATION_WHILE_INVOKING_ATTRIBUTE_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_INVOCATION_WHILE_INVOKING_FIELD_TO_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_INVOCATION_WHILE_INVOKING_ROW_EXTRACTION_METHOD - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_INVOCATION_WHILE_METHOD_INSTANTIATION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_INVOCATION_WHILE_METHOD_INSTANTIATION_OF_FACTORY - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_INVOCATION_WHILE_OBSOLETE_EVENT_EXECUTION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_INVOCATION_WHILE_SETTING_VALUE_THRU_METHOD_ACESSOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
TARGET_NAMESPACE_PREFIX - Static variable in class org.eclipse.persistence.oxm.XMLConstants
 
TARGET_SERVER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.target-server" property configures the ServerPlatform that will be used to enable integration with a host container.
TARGET_SHORT_PREFIX - Static variable in interface org.eclipse.persistence.internal.helper.DatabaseType
 
TARGET_SUFFIX - Static variable in interface org.eclipse.persistence.internal.helper.DatabaseType
 
targetClass - Variable in class org.eclipse.persistence.internal.oxm.Reference
 
targetClass - Variable in class org.eclipse.persistence.queries.ConstructorResult
 
targetClass() - Method in annotation type org.eclipse.persistence.annotations.Array
(Optional) The basic or embeddable class that is the element type of the collection.
targetClassName - Variable in class org.eclipse.persistence.queries.ConstructorResult
Stores the class of result
TargetDatabase - Class in org.eclipse.persistence.config
Target database persistence property values.
TargetDatabase() - Constructor for class org.eclipse.persistence.config.TargetDatabase
 
targetExpressionsToPostInitialize - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
 
targetExpressionsToPostInitialize - Variable in class org.eclipse.persistence.mappings.OneToOneMapping
 
targetFields - Variable in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
targetForeignKeyFields - Variable in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
The target foreign key fields that reference the sourceKeyFields.
targetForeignKeyFields - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
This is a key in the target table which is a foreign key in the target table.
targetForeignKeyFields - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
The target foreign key fields that reference the sourceKeyFields.
targetForeignKeysSizeMismatch(ForeignReferenceMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetForeignKeysToSourceKeys - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
This maps the target foreign key fields to the corresponding (primary) source key fields.
targetForeignKeyTable - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
All targetForeignKeyFields should have the same table.
targetForeignKeyToSourceKeys - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Foreign keys in the target table to the related keys in the source table
targetIdentityMap - Variable in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
This attribute stores the actual IdentityMap as configured by the user.
targetInterface() - Method in annotation type org.eclipse.persistence.annotations.VariableOneToOne
(Optional) The interface class that is the target of the association.
targetInvocationWhileCloning(Object, String, ClassDescriptor, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetInvocationWhileConstructorInstantiation(ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetInvocationWhileConstructorInstantiationOfFactory(ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetInvocationWhileEventExecution(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetInvocationWhileGettingValueThruMethodAccessor(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetInvocationWhileInstantiatingMethodBasedProxy(Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetInvocationWhileInvokingAttributeMethod(DatabaseMapping, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetInvocationWhileInvokingFieldToMethod(String, DatabaseMapping, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetInvocationWhileInvokingRowExtractionMethod(AbstractRecord, Method, ClassDescriptor, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetInvocationWhileMethodInstantiation(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetInvocationWhileMethodInstantiationOfFactory(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetInvocationWhileObsoleteEventExecute(String, ClassDescriptor, Exception) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetInvocationWhileSettingValueThruMethodAccessor(String, Object, Throwable) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
targetKeyFields - Variable in class org.eclipse.persistence.mappings.RelationTableMechanism
The field in the target table that corresponds to the key in the relation table
targetObjectPrimaryKeys - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
 
targetPrimaryKeyFields - Variable in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatementForTempTable
 
targetPrimaryKeyFields - Variable in class org.eclipse.persistence.mappings.OneToManyMapping
Primary keys of targetForeignKeyTable: the same as referenceDescriptor().getPrimaryKeyFields() in case the table is default table of reference descriptor; otherwise contains secondary table's primary key fields in the same order as default table primary keys mapped to them.
targetRelationKeyFields - Variable in class org.eclipse.persistence.mappings.RelationTableMechanism
The field in the intermediate table that corresponds to the key in the target table
TargetServer - Class in org.eclipse.persistence.config
Target server persistence property values.
TargetServer() - Constructor for class org.eclipse.persistence.config.TargetServer
 
targetTable - Variable in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatementForTempTable
 
targetTable - Variable in class org.eclipse.persistence.tools.schemaframework.ForeignKeyConstraint
 
targetTable - Variable in class org.eclipse.persistence.tools.schemaframework.IndexDefinition
 
targetToSourceKeyFields - Variable in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
Maps the target primary/foreign key fields to the source foreign/primary key fields.
targetToSourceKeyFields - Variable in class org.eclipse.persistence.mappings.OneToOneMapping
Maps the target primary/foreign key fields to the source foreign/primary key fields.
TEMP_DIRECTORY - Static variable in class org.eclipse.persistence.internal.helper.Helper
Prime the platform-dependent temporary directory
TEMP_TABLES_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
tempDirectory() - Static method in class org.eclipse.persistence.internal.helper.Helper
Return the name of the "temporary directory".
tempInitSession - Variable in class org.eclipse.persistence.mappings.ForeignReferenceMapping
The session is temporarily used for initialization.
TEMPORAL_MUTABLE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.temporal.mutable" property configures the default for detecting changes to temporal field (Date, Calendar).
temporaryCachedQueryResults - Variable in class org.eclipse.persistence.queries.ReadQuery
Optimization: temporarily stores cached query results while they are being built in a cloned query
tempTablesNotSupported(DatabaseQuery, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
TenantDiscriminatorColumn - Annotation Type in org.eclipse.persistence.annotations
Tenant discriminator column(s) are used with a SINGLE_TABLE multitenant strategy.
TenantDiscriminatorColumns - Annotation Type in org.eclipse.persistence.annotations
A TenantDiscriminatorColumns annotation allows the definition of multiple TenantDiscriminatorColumn.
tenantDiscriminatorFields - Variable in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
 
tenantDiscriminatorFieldsKeyedOnContext - Variable in class org.eclipse.persistence.descriptors.SingleTableMultitenantPolicy
 
TenantTableDiscriminator - Annotation Type in org.eclipse.persistence.annotations
A tenant table discriminator is used with a TABLE_PER_TENANT multitenant strategy.
TenantTableDiscriminatorType - Enum in org.eclipse.persistence.annotations
An enum that is used within the TenantTableDiscriminator annotation.
terminationStrings - Variable in class org.eclipse.persistence.expressions.ListExpressionOperator
 
TEXT - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
TEXT - Static variable in class org.eclipse.persistence.internal.oxm.schema.SchemaModelGenerator
 
TEXT_FRAGMENT - Static variable in class org.eclipse.persistence.internal.oxm.XPathFragment
 
textWrapperFragment - Variable in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
textWrapperFragment - Variable in class org.eclipse.persistence.oxm.record.MarshalRecord
 
thread - Variable in class org.eclipse.persistence.logging.SessionLogEntry
 
THREAD - org.eclipse.persistence.logging.LogCategory
 
THREAD - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
THREAD_EXTENDED_LOGGING - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.thread.extended.logging" property control (enable/disable) some additional logging messages like print error message if cached Entity is picked by different thread, or if EntityManager/UnitOfWork is reused/passed to different thread.
THREAD_EXTENDED_LOGGING_THREADDUMP - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.thread.extended.logging.threaddump" property control (enable/disable) store and display thread dump.
THREAD_STRING - Static variable in class org.eclipse.persistence.logging.AbstractSessionLog
Thread string
ThreadCursoredList<E> - Class in org.eclipse.persistence.internal.helper
Special List/Vector subclass that allows concurrent population of the contents while the list is in use.
ThreadCursoredList() - Constructor for class org.eclipse.persistence.internal.helper.ThreadCursoredList
Construct an empty list so that its internal data array has size 10 and its standard capacity increment is zero.
ThreadCursoredList(int) - Constructor for class org.eclipse.persistence.internal.helper.ThreadCursoredList
Construct an empty list with the specified initial capacity and with its capacity increment equal to zero.
ThreadCursoredList(int, int) - Constructor for class org.eclipse.persistence.internal.helper.ThreadCursoredList
Construct an empty list with the specified initial capacity and capacity increment.
threadDepth - Variable in class org.eclipse.persistence.internal.helper.DeferredLockManager
 
threadPool - Variable in class org.eclipse.persistence.platform.server.ServerPlatformBase
Allow pooling of threads for asynchronous processing in RCM and other areas.
threadPoolSize - Variable in class org.eclipse.persistence.platform.server.ServerPlatformBase
Allow the thread pool size to be configured.
threshold - Variable in class org.eclipse.persistence.internal.helper.IdentityHashSet
 
threshold - Variable in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
 
THROW_ALL_CONFORM_EXCEPTIONS - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
THROW_EXCEPTIONS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.orm.throw.exceptions" property specifies if the first exception that occurs during deployment should be thrown, or if all exceptions should be caught and summary thrown at end of deployment attempt.
throwable - Variable in class org.eclipse.persistence.logging.SessionLogEntry
 
throwException(RuntimeException) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Record that the population thread hit an exception, that should be thrown to the processing thread on the next access.
throwIndirectionException() - Method in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
throwing(Throwable) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
throwing(Throwable) - Method in class org.eclipse.persistence.logging.JavaLog
PUBLIC:
throwing(Throwable) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: This method is called when a throwable at finer level needs to be logged.
throwInitObjectException(Exception, Class<?>, String, boolean) - Method in class org.eclipse.persistence.mappings.converters.ObjectTypeConverter
INTERNAL:
TIME - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
TIME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
TIME_LDATE - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
TIME_LDATETIME - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
TIME_LTIME - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
TIME_ODATETIME - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
TIME_OTIME - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
TIME_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
TIME_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
timeFromCalendar(Calendar) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a sql.Time from a Calendar.
timeFromDate(Date) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Time from a Date This implementation is based on the java.sql.Date class, not java.util.Date.
timeFromHourMinuteSecond(int, int, int) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Time with the hour, minute, second.
timeFromLong(Long) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Time from a long
timeFromString(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Time from a string representation.
timeFromTimestamp(Timestamp) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Time from a Timestamp Usus the Hours, Minutes, Seconds instead of getTime() ms value.
TimeOfDay - Annotation Type in org.eclipse.persistence.annotations
A TimeOfDay annotation is used to specify a specific time of day using a Calendar instance which is to be used within an OptimisticLocking annotation.
timeOfDeath - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
TIMEOUT - Static variable in exception org.eclipse.persistence.eis.EISException
 
timeoutOccurred() - Static method in exception org.eclipse.persistence.eis.EISException
 
TIMER - Static variable in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
TIMESTAMP - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
TIMESTAMP_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
timestampFromCalendar(Calendar) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Timestamp from a Calendar.
timestampFromDate(Date) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Timestamp from a java.util.Date.
timestampFromLong(long) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Time from a long
timestampFromLong(Long) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Time from a long
timestampFromString(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Timestamp from a string representation.
timestampFromYearMonthDateHourMinuteSecondNanos(int, int, int, int, int, int, int) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Timestamp with the year, month, day, hour, minute, second.
TimestampLockingPolicy - Class in org.eclipse.persistence.descriptors
Purpose: Used to allow a single version timestamp to be used for optimistic locking.
TimestampLockingPolicy() - Constructor for class org.eclipse.persistence.descriptors.TimestampLockingPolicy
PUBLIC: Create a new TimestampLockingPolicy.
TimestampLockingPolicy(String) - Constructor for class org.eclipse.persistence.descriptors.TimestampLockingPolicy
PUBLIC: Create a new TimestampLockingPolicy.
TimestampLockingPolicy(DatabaseField) - Constructor for class org.eclipse.persistence.descriptors.TimestampLockingPolicy
INTERNAL: Create a new TimestampLockingPolicy.
timestampQuery - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Store the query use to query the current server time.
TimesTen - Static variable in class org.eclipse.persistence.config.TargetDatabase
 
TimesTen7Platform - Class in org.eclipse.persistence.platform.database
Purpose: Provides TimesTen 7 specific behavior.
TimesTen7Platform() - Constructor for class org.eclipse.persistence.platform.database.TimesTen7Platform
Default constructor.
TimesTenPlatform - Class in org.eclipse.persistence.platform.database
Database platform for the TimesTen database product.
TimesTenPlatform() - Constructor for class org.eclipse.persistence.platform.database.TimesTenPlatform
 
timeToLive - Variable in class org.eclipse.persistence.descriptors.invalidation.TimeToLiveCacheInvalidationPolicy
Number of milliseconds before invalidation.
TimeToLiveCacheInvalidationPolicy - Class in org.eclipse.persistence.descriptors.invalidation
PUBLIC: A CacheInvalidationPolicy which allows objects to live for a specific amount of time after they are read.
TimeToLiveCacheInvalidationPolicy() - Constructor for class org.eclipse.persistence.descriptors.invalidation.TimeToLiveCacheInvalidationPolicy
INTERNAL: Default Constructor for Project XML Unless the timeToLive is set by method, objects will expire immediately
TimeToLiveCacheInvalidationPolicy(long) - Constructor for class org.eclipse.persistence.descriptors.invalidation.TimeToLiveCacheInvalidationPolicy
PUBLIC: Construct a TimeToLiveCacheInvalidationPolicy
timeWithRoundMiliseconds() - Static method in class org.eclipse.persistence.internal.helper.Helper
 
timeZone - Variable in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
TimeZoneHolder - Interface in org.eclipse.persistence.internal.helper
 
timeZoneQualified - Variable in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
TINYINT_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
tmpresolverMap - Variable in class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
 
toArray() - Method in class org.eclipse.persistence.indirection.IndirectList
 
toArray() - Method in class org.eclipse.persistence.indirection.IndirectSet
 
toArray() - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
toArray() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
toArray() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
toArray() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
toArray() - Method in class org.eclipse.persistence.queries.ReportQueryResult
INTERNAL: Converts the ReportQueryResult to a simple array of values.
toArray(Object[]) - Method in class org.eclipse.persistence.internal.helper.linkedlist.ExposedNodeLinkedList
 
toArray(T[]) - Method in class org.eclipse.persistence.indirection.IndirectList
 
toArray(T[]) - Method in class org.eclipse.persistence.indirection.IndirectSet
 
toArray(T[]) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedSubVector
 
toArray(T[]) - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
toArray(T[]) - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
toBytes() - Method in class org.eclipse.persistence.internal.sessions.coordination.ServiceAnnouncement
INTERNAL: Convert the instance attributes to serialized bytes.
toChar() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that represents the receiver value converted to a character string.
toChar() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
toChar(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that represents the receiver value converted to a character string, with the database formating options (i.e.
ToChar - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
toCharacter() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the single character string with the ascii or character set value.
toCharOperator() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Build MySQL equivalent to TO_CHAR.
toCharOperator() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Cloned from MySQLPlatform.java
toCharOperator() - Static method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Build Sybase equivalent to TO_CHAR.
toCharWithFormat() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
ToCharWithFormat - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
toCompositeData(CompositeType) - Method in class org.eclipse.persistence.services.ClassSummaryDetailBase
Convert an instance of this model specific type to a CompositeData.
toCompositeType() - Static method in class org.eclipse.persistence.services.ClassSummaryDetailBase
Returns the CompositeType that describes this model specific class
toCopyGroup() - Method in class org.eclipse.persistence.queries.AttributeGroup
Convert the group to a CopyGroup for usage with the copy() API.
toCopyGroup(Map<AttributeGroup, CopyGroup>, Map) - Method in class org.eclipse.persistence.queries.AttributeGroup
INTERNAL: This method is used internally when converting to a copy group.
toCopyGroup(Map<AttributeGroup, CopyGroup>, CopyGroup, Map) - Method in class org.eclipse.persistence.internal.queries.AttributeItem
 
toDate() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns date from the string using the default format.
toDate() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
toDate() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Converts the character value expression of the conversion source to the DATE type in accordance.
Builds Symfoware equivalent to toDate(Date, format).
Symfoware: CNV_DATE(Date, 'YYYY-MM-DD')
ToDate - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
toDateOperator() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Build MySQL equivalent to TO_DATE.
toDateOperator() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
Cloned from MySQLPlatform.java
toDateOperator() - Static method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Build Sybase equivalent to TO_DATE.
toDateToStringOperator() - Static method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Build Sybase equivalent to TO_CHAR.
today() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
today() - Static method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: MySQL specific today operator.
Today - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
Function to obtain the current timestamp on the database including date and time components.
toDo(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Can be used to mark code as need if something strange is seen.
toFetchGroup() - Method in class org.eclipse.persistence.queries.AttributeGroup
Convert the group to a FetchGroup for usage with queries.
toFetchGroup(Map<AttributeGroup, FetchGroup>) - Method in class org.eclipse.persistence.queries.AttributeGroup
INTERNAL: This method is used internally when converting to a copy group.
toFetchGroup(Map<AttributeGroup, FetchGroup>, FetchGroup) - Method in class org.eclipse.persistence.internal.queries.AttributeItem
 
toggleAdditionalTablePrimaryKeyFields() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Eclipselink needs additionalTablePKFields entries to be associated with tables other than the main (getTables.get(0)) one.
tokensIterator() - Method in class org.eclipse.persistence.internal.mappings.converters.AttributeNameTokenizer
INTERNAL: Returns an TokensIterator over attribute name tokens.
TokensIterator(String) - Constructor for class org.eclipse.persistence.internal.mappings.converters.AttributeNameTokenizer.TokensIterator
INTERNAL: Creates an instance of attribute name tokenizer iterator.
TokensIterator(String, boolean) - Constructor for class org.eclipse.persistence.internal.mappings.converters.AttributeNameTokenizer.TokensIterator
INTERNAL: Creates an instance of attribute name tokenizer iterator.
tolerateInvalidJPQL - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Indicates whether Session creation should tolerate an invalid NamedQuery.
toList() - Method in class org.eclipse.persistence.queries.ReportQueryResult
INTERNAL: Converts the ReportQueryResult to a simple list of values.
toLoadGroup() - Method in class org.eclipse.persistence.queries.AttributeGroup
Convert the group to a LoadGroup for usage with queries.
toLoadGroup(Map<AttributeGroup, LoadGroup>, boolean) - Method in class org.eclipse.persistence.queries.AttributeGroup
 
toLoadGroup(Map<AttributeGroup, LoadGroup>, boolean) - Method in class org.eclipse.persistence.queries.FetchGroup
 
toLoadGroup(Map<AttributeGroup, LoadGroup>, LoadGroup, boolean) - Method in class org.eclipse.persistence.internal.queries.AttributeItem
 
toLoadGroupLoadOnly() - Method in class org.eclipse.persistence.queries.FetchGroup
 
toLowerCase() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that represents the receiver value converted to lower case.
toLowerCase() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the toLowerCase operator.
ToLowerCase - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
toNumber() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the number converted from the string.
toNumber() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
toNumber() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Returns the number converted from the string.
Builds Symfoware equivalent to ToNumber(string_exp).
Symfoware: CAST(string_exp AS SMALLINT)
ToNumber - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
toNumberOperator() - Static method in class org.eclipse.persistence.platform.database.FirebirdPlatform
INTERNAL: Use CONVERT function for toNumber.
toNumberOperator() - Static method in class org.eclipse.persistence.platform.database.H2Platform
INTERNAL: Use CONVERT function for toNumber.
toNumberOperator() - Static method in class org.eclipse.persistence.platform.database.HSQLPlatform
INTERNAL: Use CONVERT function for toNumber.
toNumberOperator() - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Build MySQL equivalent to TO_NUMBER.
toNumberOperator() - Method in class org.eclipse.persistence.platform.database.PervasivePlatform
 
toNumberOperator() - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: Postgres to_number has two arguments, as fix format argument.
toNumberOperator() - Static method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Build Sybase equivalent to TO_NUMBER.
tooMuchTimeHasElapsed(long, long) - Method in class org.eclipse.persistence.internal.helper.ConcurrencyUtil
 
topic - Variable in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
 
TOPIC_CONNECTION_FACTORY_NAME_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
TOPIC_NAME_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
topicConnection - Variable in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
 
topicConnectionFactory - Variable in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
 
topicName - Variable in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
 
topicName - Variable in class org.eclipse.persistence.sessions.coordination.broadcast.BroadcastTransportManager
 
topicSession - Variable in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
 
toPlatform() - Method in class org.eclipse.persistence.internal.helper.JavaVersion
Return JavaSEPlatform matching this Java SE specification version.
TOPLINK_10_SCHEMA - Static variable in class org.eclipse.persistence.sessions.factories.XMLProjectReader
 
TOPLINK_11_SCHEMA - Static variable in class org.eclipse.persistence.sessions.factories.XMLProjectReader
 
TOPLINK_INDIRECTION_PACKAGE_NAME - Static variable in class org.eclipse.persistence.internal.codegen.CodeDefinition
 
TOPLINK_NAMESPACE - Static variable in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
TOPLINK_NAMESPACE - Static variable in class org.eclipse.persistence.logging.JavaLog
Stores the default session name in case there is the session name is missing.
TOPLINK_PREFIX - Static variable in class org.eclipse.persistence.internal.sessions.factories.NamespaceResolvableProject
 
TOPLINK_PREFIX - Static variable in class org.eclipse.persistence.logging.AbstractSessionLog
Cached TopLink prefix string.
toSlashedClassName(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
Convert dotted format class name to slashed format class name.
toString() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
toString() - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
toString() - Method in class org.eclipse.persistence.descriptors.CacheIndex
 
toString() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Returns a brief string representation of the receiver.
toString() - Method in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
 
toString() - Method in class org.eclipse.persistence.descriptors.copying.InstantiationCopyPolicy
 
toString() - Method in class org.eclipse.persistence.descriptors.copying.PersistenceEntityCopyPolicy
 
toString() - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
INTERNAL:
toString() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL:
toString() - Method in class org.eclipse.persistence.dynamic.DynamicClassWriter
 
toString() - Method in class org.eclipse.persistence.eis.EISConnectionSpec
PUBLIC: Print data source info.
toString() - Method in class org.eclipse.persistence.eis.EISMappedRecord
Print all of the record keys and values.
toString() - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
 
toString() - Method in exception org.eclipse.persistence.exceptions.EclipseLinkException
INTERNAL:
toString() - Method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
toString() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Print a debug form of the expression tree.
toString() - Method in class org.eclipse.persistence.expressions.ExpressionOperator
Print a debug representation of this operator.
toString() - Method in class org.eclipse.persistence.history.AsOfClause
 
toString() - Method in class org.eclipse.persistence.indirection.IndirectList
PUBLIC: Use the java.util.Vector#toString(); but wrap it with braces to indicate there is a bit of indirection.
toString() - Method in class org.eclipse.persistence.indirection.IndirectMap
PUBLIC: Use the Hashtable.toString(); but wrap it with braces to indicate there is a bit of indirection.
toString() - Method in class org.eclipse.persistence.indirection.IndirectSet
Use the delegate's #toString(); but wrap it with braces to indicate there is a bit of indirection.
toString() - Method in class org.eclipse.persistence.indirection.ValueHolder
INTERNAL:
toString() - Method in class org.eclipse.persistence.internal.codegen.CodeDefinition
 
toString() - Method in class org.eclipse.persistence.internal.codegen.CodeGenerator
 
toString() - Method in class org.eclipse.persistence.internal.codegen.HierarchyNode
 
toString() - Method in class org.eclipse.persistence.internal.databaseaccess.BindCallCustomParameter
 
toString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
 
toString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Print the SQL string.
toString() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
 
toString() - Method in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
toString() - Method in class org.eclipse.persistence.internal.databaseaccess.InOutputParameterForCallableStatement
 
toString() - Method in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
toString() - Method in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
 
toString() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
toString() - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
 
toString() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl.PropertyWrapper
 
toString() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
String representation of the dynamic entity using the entity type name and the primary key values - something like {Emp 10} or {Phone 234-5678 10}.
toString() - Method in class org.eclipse.persistence.internal.dynamic.DynamicTypeImpl
 
toString() - Method in class org.eclipse.persistence.internal.expressions.SQLStatement
Try to print the SQL.
toString() - Method in class org.eclipse.persistence.internal.expressions.TableAliasLookup
 
toString() - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
toString() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
Print the nested depth.
toString() - Method in class org.eclipse.persistence.internal.helper.DatabaseField
 
toString() - Method in class org.eclipse.persistence.internal.helper.DatabaseTable
 
toString() - Method in class org.eclipse.persistence.internal.helper.IndexedObject
 
toString() - Method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Return Java SE platform version as human readable String.
toString() - Method in class org.eclipse.persistence.internal.helper.JavaSEPlatform.Version
Return version as human readable String.
toString() - Method in class org.eclipse.persistence.internal.helper.JavaVersion
Return String representation of Java VM version object.
toString() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
toString() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
toString() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
toString() - Method in class org.eclipse.persistence.internal.helper.type.DeadLockComponent
 
toString() - Method in class org.eclipse.persistence.internal.helper.type.ReadLockAcquisitionMetadata
 
toString() - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
 
toString() - Method in class org.eclipse.persistence.internal.identitymaps.CacheId
 
toString() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
toString() - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
 
toString() - Method in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
 
toString() - Method in enum org.eclipse.persistence.internal.mappings.converters.AttributeNamePrefix
INTERNAL: Get instance value in human readable form.
toString() - Method in class org.eclipse.persistence.internal.oxm.StrBuffer
 
toString() - Method in class org.eclipse.persistence.internal.oxm.XMLAccessor
Call #toString(PrintWriter), to allow subclasses to insert additional information.
toString() - Method in class org.eclipse.persistence.internal.oxm.XPathQName
 
toString() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
toString() - Method in class org.eclipse.persistence.internal.queries.ReportItem
 
toString() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord.RecordEntry
 
toString() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
INTERNAL:
toString() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
Print the connection status with the session.
toString() - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
 
toString() - Method in class org.eclipse.persistence.internal.sessions.ChangeRecord
 
toString() - Method in class org.eclipse.persistence.internal.sessions.CommitManager
Print the in progress depth.
toString() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
toString() - Method in class org.eclipse.persistence.internal.sessions.coordination.broadcast.BroadcastRemoteConnection
INTERNAL:
toString() - Method in class org.eclipse.persistence.internal.sessions.coordination.RemoteConnection
 
toString() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
toString() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
Avoid the toString printing the accessor and platform.
toString() - Method in class org.eclipse.persistence.internal.sessions.remote.Transporter
 
toString() - Method in class org.eclipse.persistence.logging.SessionLogEntry
 
toString() - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Print the mapping attribute name, this is used in error messages.
toString() - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL:
toString() - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL:
toString() - Method in class org.eclipse.persistence.mappings.querykeys.QueryKey
INTERNAL: return a string representation of this instance of QueryKey
toString() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
INTERNAL: Print the dom XML string.
toString() - Method in class org.eclipse.persistence.oxm.XMLLogin
Return a String representation of the object.
toString() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
toString() - Method in class org.eclipse.persistence.queries.ConstructorReportItem
 
toString() - Method in class org.eclipse.persistence.queries.DatabaseQuery
 
toString() - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: Print the JPQL string.
toString() - Method in class org.eclipse.persistence.queries.ObjectLevelModifyQuery
 
toString() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
toString() - Method in class org.eclipse.persistence.queries.ReportQueryResult.RecordEntry
 
toString() - Method in class org.eclipse.persistence.queries.ReportQueryResult
 
toString() - Method in class org.eclipse.persistence.queries.StoredProcedureCall
 
toString() - Method in class org.eclipse.persistence.sequencing.Sequence
 
toString() - Method in class org.eclipse.persistence.sessions.coordination.ServiceId
 
toString() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Print all of the connection information.
toString() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Print all of the connection information.
toString() - Method in class org.eclipse.persistence.sessions.DefaultConnector
PUBLIC: Print connection string.
toString() - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
 
toString() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
toString() - Method in class org.eclipse.persistence.sessions.JNDIConnector
PUBLIC: Print data source info.
toString() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL:
toString() - Method in class org.eclipse.persistence.sessions.remote.DistributedSession
PUBLIC: Avoid printing the accessor and platform.
toString() - Method in class org.eclipse.persistence.sessions.serializers.AbstractSerializer
 
toString() - Method in class org.eclipse.persistence.sessions.serializers.JavaSerializer
 
toString() - Method in class org.eclipse.persistence.sessions.serializers.JSONSerializer
 
toString() - Method in class org.eclipse.persistence.sessions.serializers.XMLSerializer
 
toString() - Method in class org.eclipse.persistence.sessions.server.ClientSession
INTERNAL: Print the connection status with the session.
toString() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
INTERNAL: return a string representation of this ConnectionPolicy
toString() - Method in class org.eclipse.persistence.sessions.server.ConnectionPool
INTERNAL: return a string representation of this connection pool
toString() - Method in class org.eclipse.persistence.tools.profiler.Profile
 
toString() - Method in class org.eclipse.persistence.tools.schemaframework.DatabaseObjectDefinition
 
toString() - Method in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
 
toString(BufferedWriter, int) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Print a debug form of the expression tree.
toString(PrintWriter) - Method in class org.eclipse.persistence.eis.EISConnectionSpec
INTERNAL: Print something useful on the log.
toString(PrintWriter) - Method in class org.eclipse.persistence.internal.oxm.XMLAccessor
Append more information to the writer.
toString(PrintWriter) - Method in interface org.eclipse.persistence.sessions.Connector
INTERNAL: Print something useful on the log.
toString(PrintWriter) - Method in class org.eclipse.persistence.sessions.DefaultConnector
INTERNAL: Print something useful on the log.
toString(PrintWriter) - Method in class org.eclipse.persistence.sessions.JNDIConnector
INTERNAL: Print something useful on the log.
toStringAdditionalInfo() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Used by toString to print additional info for derived classes.
toStringAdditionalInfo() - Method in class org.eclipse.persistence.sessions.CopyGroup
INTERNAL:
toStringAditional() - Method in class org.eclipse.persistence.internal.sessions.ArrayRecord
 
toStringAditional() - Method in class org.eclipse.persistence.internal.sessions.ResultSetRecord
 
toStringAditional() - Method in class org.eclipse.persistence.internal.sessions.SimpleResultSetRecord
 
toStringInfo() - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
 
toStringInfo() - Method in class org.eclipse.persistence.internal.queries.InterfaceContainerPolicy
 
toStringInfo() - Method in class org.eclipse.persistence.queries.CursorPolicy
 
toStringItems() - Method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
Used by toString to print attribute items.
ToStringLocalization - Class in org.eclipse.persistence.internal.localization
Purpose: This is for any toString messages
ToStringLocalization() - Constructor for class org.eclipse.persistence.internal.localization.ToStringLocalization
 
toStringNoClassName() - Method in class org.eclipse.persistence.core.queries.CoreAttributeItem
 
toStringPath(String[], int) - Static method in class org.eclipse.persistence.core.queries.CoreAttributeGroup
 
TOTAL_MS_DIGITS - Static variable in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
TOTAL_NS_DIGITS - Static variable in class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
totalTime - Variable in class org.eclipse.persistence.tools.profiler.Profile
 
toUpperCase() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that represents the receiver value converted to upper case.
toUpperCase() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the TOUPPERCASE operator.
ToUpperCase - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
Function operators
toUppercaseCasedWords() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the string with the first letter of each word capitalized.
toURI(URL) - Static method in class org.eclipse.persistence.internal.helper.Helper
Convert the URL into a URI allowing for special chars.
toValue(int) - Static method in enum org.eclipse.persistence.logging.LogLevel
Returns LogLevel object holding the value of the specified LogLevel ID.
toValue(int, int) - Static method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Returns a JavaSEPlatform matching provided major and minor version numbers.
toValue(int, LogLevel) - Static method in enum org.eclipse.persistence.logging.LogLevel
Returns LogLevel object holding the value of the specified LogLevel ID.
toValue(String) - Static method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Returns a JavaSEPlatform with a value represented by the specified String.
toValue(String) - Static method in enum org.eclipse.persistence.internal.mappings.converters.AttributeNamePrefix
INTERNAL: Returns an AttributeNamePrefix instance with name equal to the specified String.
toValue(String) - Static method in enum org.eclipse.persistence.logging.LogCategory
Returns LogCategory object holding the value of the specified String.
toValue(String) - Static method in enum org.eclipse.persistence.logging.LogLevel
Returns LogLevel object holding the value of the specified String.
toValue(String, LogLevel) - Static method in enum org.eclipse.persistence.logging.LogLevel
Returns LogLevel object holding the value of the specified String.
TRACE_LOCALIZATION_STRING - Static variable in class org.eclipse.persistence.logging.JavaLog
 
TraceLocalization - Class in org.eclipse.persistence.internal.localization
Purpose: This is for any trace related messages Messages are not currently translated by default here.
TraceLocalization() - Constructor for class org.eclipse.persistence.internal.localization.TraceLocalization
 
transactedSessionTestError() - Static method in exception org.eclipse.persistence.eis.EISException
 
transaction - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PERF: Stores the JTA transaction to optimize activeUnitOfWork lookup.
transaction - Variable in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
The global transaction object.
Transaction - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
TRANSACTION - org.eclipse.persistence.logging.LogCategory
 
TRANSACTION - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
TRANSACTION_MANAGER_NOT_SET_FOR_JTS_DRIVER - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
TRANSACTION_NONE - Static variable in class org.eclipse.persistence.sessions.DatabaseLogin
Transactions are not supported.
TRANSACTION_READ_COMMITTED - Static variable in class org.eclipse.persistence.sessions.DatabaseLogin
Dirty reads are prevented; non-repeatable reads and phantom reads can occur.
TRANSACTION_READ_UNCOMMITTED - Static variable in class org.eclipse.persistence.sessions.DatabaseLogin
Dirty reads, non-repeatable reads and phantom reads can occur.
TRANSACTION_REPEATABLE_READ - Static variable in class org.eclipse.persistence.sessions.DatabaseLogin
Dirty reads and non-repeatable reads are prevented; phantom reads can occur.
TRANSACTION_SERIALIZABLE - Static variable in class org.eclipse.persistence.sessions.DatabaseLogin
Dirty reads, non-repeatable reads and phantom reads are prevented.
TRANSACTION_TYPE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.transactionType" property specifies the transaction type for the persistence unit.
Transactional - org.eclipse.persistence.sessions.server.ConnectionPolicy.ExclusiveMode
 
Transactional - Static variable in class org.eclipse.persistence.config.ExclusiveConnectionMode
The value causes creation of IsolatedClientSession in isolated case and ClientSession otherwise.
TransactionException - Exception in org.eclipse.persistence.exceptions
 
TransactionException(String) - Constructor for exception org.eclipse.persistence.exceptions.TransactionException
 
TransactionException(String, Exception) - Constructor for exception org.eclipse.persistence.exceptions.TransactionException
 
TransactionExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for TransactionException messages.
TransactionExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.TransactionExceptionResource
Default constructor.
transactionId - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
The ID of the database transaction that last wrote the object.
transactionIsActive() - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
transactionIsolation - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
The transaction isolation level to be set on the connection (optional).
transactionKey - Variable in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
The global transaction key.
transactionManager - Variable in class org.eclipse.persistence.transaction.JTATransactionController
 
transactionManagerNotSetForJTSDriver() - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
 
transactionMutex - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
Ensure mutual exclusion of the session's transaction state across multiple threads.
transactionNotActive() - Static method in exception org.eclipse.persistence.exceptions.TransactionException
 
transform(Source, Result) - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
transform(Document, Node, URL) - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
transform(Node, OutputStream) - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
transform(Node, Writer) - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
transform(Node, Result) - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
transform(Node, ContentHandler) - Method in interface org.eclipse.persistence.platform.xml.XMLTransformer
 
Transformation - Annotation Type in org.eclipse.persistence.annotations
Transformation is an optional annotation for org.eclipse.persistence.mappings.TransformationMapping.
TransformationMapping - Class in org.eclipse.persistence.mappings
Purpose: A transformation mapping is used for a specialized translation between how a value is represented in Java and its representation on the databae.
TransformationMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​TRANSFORMATION_RECORD extends TransformationRecord,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
TransformationMapping() - Constructor for class org.eclipse.persistence.mappings.TransformationMapping
PUBLIC: Default constructor.
TransformationMappingChangeRecord - Class in org.eclipse.persistence.internal.sessions
Purpose: To record the changes for attributes that can be represented as Transformation Mapping
TransformationMappingChangeRecord - Interface in org.eclipse.persistence.sessions.changesets
Purpose: To Provide API to the TransformationMappingChangeRecord.
TransformationMappingChangeRecord() - Constructor for class org.eclipse.persistence.internal.sessions.TransformationMappingChangeRecord
This default constructor.
TransformationMappingChangeRecord(ObjectChangeSet) - Constructor for class org.eclipse.persistence.internal.sessions.TransformationMappingChangeRecord
This is the basic constructor for this change Record.
TransformationRecord - Interface in org.eclipse.persistence.internal.oxm.record
 
transformAttributeName(String) - Method in interface org.eclipse.persistence.oxm.XMLNameTransformer
Method called when creating an attribute from a Java field
transformElementName(String) - Method in interface org.eclipse.persistence.oxm.XMLNameTransformer
Method called when creating an element from a Java field or method
transformer - Variable in class org.eclipse.persistence.internal.descriptors.TransformerBasedFieldTransformation
 
transformer - Variable in class org.eclipse.persistence.internal.indirection.TransformerBasedValueHolder
Stores the method to be executed.
transformer - Variable in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
TRANSFORMER_CLASS_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
TransformerBasedFieldTransformation - Class in org.eclipse.persistence.internal.descriptors
INTERNAL: An implementation of FieldTransformation which holds onto a transformer class-name which will be instantiated to do transformations
TransformerBasedFieldTransformation() - Constructor for class org.eclipse.persistence.internal.descriptors.TransformerBasedFieldTransformation
 
TransformerBasedFieldTransformation(FieldTransformer) - Constructor for class org.eclipse.persistence.internal.descriptors.TransformerBasedFieldTransformation
 
TransformerBasedValueHolder<T> - Class in org.eclipse.persistence.internal.indirection
 
TransformerBasedValueHolder(AttributeTransformer, Object, AbstractRecord, AbstractSession) - Constructor for class org.eclipse.persistence.internal.indirection.TransformerBasedValueHolder
Initialize the method-based value holder.
transformerClass - Variable in class org.eclipse.persistence.internal.descriptors.TransformerBasedFieldTransformation
 
transformerClass() - Method in annotation type org.eclipse.persistence.annotations.ReadTransformer
User-defined class that must implement the org.eclipse.persistence.mappings.transformers.AttributeTransformer interface.
transformerClass() - Method in annotation type org.eclipse.persistence.annotations.WriteTransformer
User-defined class that must implement the org.eclipse.persistence.mappings.transformers.FieldTransformer interface.
transformerClass() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlReadTransformer
User-defined class that must implement the org.eclipse.persistence.mappings.transformers.AttributeTransformer interface.
transformerClass() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlWriteTransformer
User-defined class that must implement the org.eclipse.persistence.mappings.transformers.FieldTransformer interface.
transformerClassName - Variable in class org.eclipse.persistence.internal.descriptors.TransformerBasedFieldTransformation
 
transformerClassNotFound(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: Transformer class could not be loaded.
TransformerHelper - Class in org.eclipse.persistence.internal.helper
Transformer helper class.
TransformerHelper() - Constructor for class org.eclipse.persistence.internal.helper.TransformerHelper
 
transformFromXML(Reader) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
Set the XML from an XML reader.
transformFromXML(String) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
Set the XML from an XML string.
transformRootElementName(String) - Method in interface org.eclipse.persistence.oxm.XMLNameTransformer
Method called when creating a simpletype or complextype from a class
transformToWriter(Writer) - Method in class org.eclipse.persistence.oxm.record.DOMRecord
Write the XML string representation of the DOM.
transformToXML() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
transformToXML() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
Return the XML string representation of the DOM.
transformToXML() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
 
transformToXML() - Method in class org.eclipse.persistence.oxm.record.NodeRecord
 
transformToXML() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
transformToXML() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
transformToXML() - Method in class org.eclipse.persistence.oxm.record.XMLRecord
Return the XML string representation of the DOM.
transformTypeName(String) - Method in interface org.eclipse.persistence.oxm.XMLNameTransformer
Method called when creating a simpletype or complextype from a class
TRANSIENT_IN_PROP_ORDER - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
TRANSIENT_REF_CLASS - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
TransientCompatibleAnnotations - Class in org.eclipse.persistence.annotations
PUBLIC: This class is used by our JPA annotation processing to discover which annotations may coexist with a jakarta.persistence.Transient annotation.
transientInProporder(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
transitionToDeferredLock() - Method in class org.eclipse.persistence.internal.helper.ConcurrencyManager
 
transitionToDeferredLocks() - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTERNAL: Records that this merge manager has transitioned to use deferred locks during the merge.
transitionToDeferredLocks(MergeManager) - Method in class org.eclipse.persistence.internal.helper.WriteLockManager
INTERNAL: This method will transition the previously acquired active locks to deferred locks in the case a readlock could not be acquired for a related object.
translate() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
translate(Object, Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the string with each char from the from string converted to the char in the to string.
translate(AbstractRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.eis.interactions.EISInteraction
Arguments to the interaction can be passed two ways.
translate(AbstractRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.eis.interactions.QueryStringInteraction
Allow the call to translate the query arguments.
translate(AbstractRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.eis.interactions.XQueryInteraction
INTERNAL: Allow the call to translate the XQuery arguments.
translate(AbstractRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
INTERNAL: Allow the call to translate from the translation for predefined calls.
translate(AbstractRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Allow the call to translate from the translation for predefined calls.
translate(AbstractRecord, AbstractRecord, AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
Allow the call to translate from the translation for predefined calls.
translate(AbstractRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
Translate the PLSQL procedure translation row, into the row expected by the SQL procedure.
translate(AbstractRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.queries.JPQLCall
INTERNAL: translate method comment.
translate(PLSQLargument, AbstractRecord, AbstractRecord, List<DatabaseField>, List<DatabaseField>, List, StoredProcedureCall) - Method in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
translate(PLSQLargument, AbstractRecord, AbstractRecord, List<DatabaseField>, List<DatabaseField>, List, StoredProcedureCall) - Method in enum org.eclipse.persistence.internal.helper.DatabaseType.DatabaseTypeHelper
 
translate(PLSQLargument, AbstractRecord, AbstractRecord, List<DatabaseField>, List<DatabaseField>, List, StoredProcedureCall) - Method in interface org.eclipse.persistence.internal.helper.DatabaseType
 
translate(PLSQLargument, AbstractRecord, AbstractRecord, List<DatabaseField>, List<DatabaseField>, List, StoredProcedureCall) - Method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
translate(PLSQLargument, AbstractRecord, AbstractRecord, List<DatabaseField>, List<DatabaseField>, List, StoredProcedureCall) - Method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
INTERNAL: Translate the argument value from the query translation row to call translation row.
translate(PLSQLargument, AbstractRecord, AbstractRecord, List<DatabaseField>, List<DatabaseField>, List, StoredProcedureCall) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLrecord
 
Translate - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
translateCustomQuery() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: Parse the query string for # markers for custom query based on a query language.
translateCustomQuery() - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
Parse the query string for # markers for custom query based on a query language.
translateCustomQuery() - Method in class org.eclipse.persistence.queries.SQLCall
INTERNAL: Keep track of the fact that this call has been translated.
translateExpression(Expression) - Method in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
Translate an expression i.e.
translateField(DatabaseField, DatabaseField, ClassDescriptor) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Apply the field translation from the sourceField to the mappingField.
translateFields(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: If field names are different in the source and aggregate objects then the translation is done here.
translateLoggingLevelToString(int) - Static method in class org.eclipse.persistence.logging.AbstractSessionLog
INTERNAL: Translate the string value of the log level to the constant value.
translateNestedFields(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: If field names are different in the source and aggregate objects then the translation is done here.
translatePureSQLCustomQuery() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: Parse the query string for ? markers for custom query based on a query language.
translatePureSQLCustomQuery() - Method in class org.eclipse.persistence.queries.SQLCall
INTERNAL: Only translate the call if it was not previously translated This code ensures the translation code for a custom SQLCall is only run once In the case of inheritance we will try to call the translation code once to get the list of types and again for each subclass
translateQueryString(AbstractRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: Allow the call to translate from the translation for predefined calls.
translateQueryString(AbstractRecord, AbstractRecord, AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.QueryStringCall
Allow the call to translate from the translation for predefined calls.
translateQueryStringAndBindParameters(AbstractRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: Allow the call to translate from the translation for predefined calls.
translateQueryStringForParameterizedIN(AbstractRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: Translate only IN() parameter values (List parameters).
translateStringToLoggingLevel(String) - Static method in class org.eclipse.persistence.logging.AbstractSessionLog
INTERNAL: Translate the string value of the log level to the constant value.
translateTablesAndFields(ClassDescriptor, HashMap<DatabaseField, DatabaseField>, HashMap<DatabaseTable, DatabaseTable>) - Static method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Called in case fieldTranslation != null Sets new primary keys, tables, appends fieldTranslation to fieldMap so that all fields in mappings, inheritance etc.
TRANSLATION - org.eclipse.persistence.internal.databaseaccess.DatasourceCall.ParameterType
 
translationRow - Variable in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
Stores the row.
translationRow - Variable in class org.eclipse.persistence.internal.expressions.SQLStatement
 
translationRow - Variable in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
Translation row stored after translation on the call clone, used only for logging.
translationRow - Variable in class org.eclipse.persistence.queries.Cursor
 
translationRow - Variable in class org.eclipse.persistence.queries.DatabaseQuery
Mappings and the descriptor use parameterized mechanisms that will be translated with the data from the row.
TransparentIndirectionPolicy - Class in org.eclipse.persistence.internal.indirection
Purpose
TransparentIndirectionPolicy() - Constructor for class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Construct a new indirection policy.
Transporter - Class in org.eclipse.persistence.internal.sessions.remote
As the name signifies the object is responsible for carrying read objects from the server to the client.
Transporter() - Constructor for class org.eclipse.persistence.internal.sessions.remote.Transporter
 
Transporter(Object) - Constructor for class org.eclipse.persistence.internal.sessions.remote.Transporter
 
transportManager - Variable in class org.eclipse.persistence.sessions.coordination.RemoteCommandManager
Manages the transport level connections between command managers
TransportManager - Class in org.eclipse.persistence.sessions.coordination
Purpose: Provide an abstract class that offers a common API to handling remote command connections.
TransportManager() - Constructor for class org.eclipse.persistence.sessions.coordination.TransportManager
Default constructor.
TransportManagerConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.transport
INTERNAL:
TransportManagerConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.transport.TransportManagerConfig
 
traversalState - Variable in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
traverseRelatedLocks(Object, Map, Map, ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.internal.helper.WriteLockManager
INTERNAL: Traverse the object and acquire locks on all related objects.
traverseSourceDirectory(File) - Method in class org.eclipse.persistence.tools.PackageRenamer
This traverseSourceDirectory() traverse source-root-directory, creating an corresponding output directory, and calling another method for replacing old TopLink package name.
treat(Class<?>) - Method in class org.eclipse.persistence.expressions.Expression
ADVANCED: Return an expression that allows you to treat its base as if it were a subclass of the class returned by the base This can only be called on an ExpressionBuilder, the result of expression.get(String), expression.getAllowingNull(String), the result of expression.anyOf("String") or the result of expression.anyOfAllowingNull("String") downcast uses Expression.type() internally to guarantee the results are of the specified class.
treat(Class<?>) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
Return an expression that allows you to treat its base as if it were a subclass of the class returned by the base This can only be called on an ExpressionBuilder, the result of expression.get(String), expression.getAllowingNull(String), the result of expression.anyOf("String") or the result of expression.anyOfAllowingNull("String") downcast uses Expression.type() internally to guarantee the results are of the specified class.
treat(Class<?>) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
ADVANCED: Return an expression that allows you to treat its base as if it were a subclass of the class returned by the base This can only be called on an ExpressionBuilder, the result of expression.get(String), expression.getAllowingNull(String), the result of expression.anyOf("String") or the result of expression.anyOfAllowingNull("String") downcast uses Expression.type() internally to guarantee the results are of the specified class.
TreatAsExpression - Class in org.eclipse.persistence.internal.expressions
 
TreatAsExpression(Class<?>, ObjectExpression) - Constructor for class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
TreeObjectBuilder - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
TreeObjectBuilder(ClassDescriptor) - Constructor for class org.eclipse.persistence.internal.oxm.TreeObjectBuilder
 
Trigger - Static variable in class org.eclipse.persistence.config.CacheUsageIndirectionPolicy
If conforming encounters an uninstantiated indirection/lazy object it is triggered.
triggerIndirection() - Method in class org.eclipse.persistence.queries.InMemoryQueryIndirectionPolicy
 
triggerMetadataRefresh(Map) - Method in interface org.eclipse.persistence.sessions.coordination.MetadataRefreshListener
 
trim() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the string trimmed for white space.
trim() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
trim(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, returns the string right and left trimmed for the substring.
Trim - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
TRIM_STRINGS_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
trim2() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build Trim operator.
trim2() - Method in class org.eclipse.persistence.platform.database.DB2Platform
DB2 does not support untyped parameter binding for <operand2>
trim2() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
trim2() - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
Enable binding since DB2 disables it
Trim2 - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
trim2Operator() - Static method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Build Trim operator.
trim2Operator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Build Trim operator.
trimFieldsForInsert() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
INTERNAL Remove a potential sequence number field and invoke the ReturningPolicy trimModifyRowsForInsert method
trimFieldsForInsert(AbstractSession, AbstractRecord) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL Remove a potential sequence number field and invoke the ReturningPolicy trimModifyRowsForInsert method
trimModifyRow(AbstractRecord, int) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
 
trimModifyRowForInsert(AbstractRecord) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
trimOperator() - Method in class org.eclipse.persistence.platform.database.DB2ZPlatform
Disable binding support.
trimOperator() - Static method in class org.eclipse.persistence.platform.database.HSQLPlatform
INTERNAL: Use TRIM(FROM ?) function for trim.
trimOperator() - Static method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL: Use RTRIM(LTRIM(?)) function for trim.
trimOperator() - Static method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL: Use RTRIM(LTRIM(?)) function for trim.
trimRowForJoin(AbstractRecord, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return a sub-partition of the row starting at the index.
trimRowForJoin(AbstractRecord, JoinedAttributeManager, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return a sub-partition of the row starting at the index for the mapping.
trimToSize() - Method in class org.eclipse.persistence.indirection.IndirectList
 
trimToSize() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedVector
 
trimToSize() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
First wait until complete.
trpltab - Static variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
TRUE - Static variable in class org.eclipse.persistence.config.HintValues
 
TRUE - Static variable in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
 
TRUE - Static variable in class org.eclipse.persistence.oxm.record.MarshalRecord
 
trunc() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
trunc(Expression, int) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
trunc(Expression, Object) - Static method in class org.eclipse.persistence.expressions.ExpressionMath
PUBLIC: Return a new expression that applies the function to the given expression.
Trunc - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
truncate(String, int) - Static method in class org.eclipse.persistence.internal.helper.Helper
If the size of the original string is larger than the passed in size, this method will remove the vowels from the original string.
truncateDate() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
truncateDate() - Static method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Truncates a date by using the truncating unit.
Builds Symfoware equivalent to truncateDate(date, unit).
Symfoware: TRUNC_DATE(date, unit)
truncateDate(String) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: return the date truncated to the indicated datePart.
truncateDate(Date) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return a sql.Date with time component zeroed out.
TruncateDate - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
truncateDateIgnoreMilliseconds(Date) - Static method in class org.eclipse.persistence.internal.helper.Helper
Return a sql.Date with time component zeroed out (with possible exception of milliseconds).
tsr - Variable in class org.eclipse.persistence.transaction.JTA11TransactionController
Primary point of integration with JTA 1.1.
tuneDeploy(Session) - Method in class org.eclipse.persistence.tools.tuning.SafeModeTuner
Allow any Session configuration to be tune after meta-data has been processed, but before connecting the session.
tuneDeploy(Session) - Method in interface org.eclipse.persistence.tools.tuning.SessionTuner
Allow any Session configuration to be tune after meta-data has been processed, but before connecting the session.
tuneDeploy(Session) - Method in class org.eclipse.persistence.tools.tuning.StandardTuner
Allow any Session configuration to be tune after meta-data has been processed, but before connecting the session.
tunePostDeploy(Session) - Method in class org.eclipse.persistence.tools.tuning.SafeModeTuner
Allow any Session configuration to be tune after deploying and connecting the session.
tunePostDeploy(Session) - Method in interface org.eclipse.persistence.tools.tuning.SessionTuner
Allow any Session configuration to be tune after deploying and connecting the session.
tunePostDeploy(Session) - Method in class org.eclipse.persistence.tools.tuning.StandardTuner
Allow any Session configuration to be tune after deploying and connecting the session.
tunePreDeploy(Map) - Method in class org.eclipse.persistence.tools.tuning.SafeModeTuner
Allow any JPA persistence unit properties to be configured, prior to deployment.
tunePreDeploy(Map) - Method in interface org.eclipse.persistence.tools.tuning.SessionTuner
Allow any JPA persistence unit properties to be configured, prior to deployment.
tunePreDeploy(Map) - Method in class org.eclipse.persistence.tools.tuning.StandardTuner
Allow any JPA persistence unit properties to be configured, prior to deployment.
tuner - Variable in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
Stores the tuner used to tune the configuration of this session.
TunerType - Class in org.eclipse.persistence.config
Tuning persistence property values.
TunerType() - Constructor for class org.eclipse.persistence.config.TunerType
 
TUNING - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.tuning"property configures the type of tuner to use to configure the persistence unit.
twist(Expression, Expression) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: We are given an expression that comes from a different context than the one in which this was built, e.g.
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Rebuild myself against the base, with the values of parameters supplied by the context expression.
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Rebuild myself against the base, with the values of parameters supplied by the context expression.
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
 
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTRENAL: Used to change an expression off of one base to an expression off of a different base.
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: Rebuild myself against the base, with the values of parameters supplied by the context expression.
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: Rebuild myself against the base, with the values of parameters supplied by the context expression.
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
INTERNAL: Rebuild myself against the base, with the values of parameters supplied by the context expression.
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Rebuild myself against the base, with the values of parameters supplied by the context expression.
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
INTERNAL: Rebuild myself against the base, with the values of parameters supplied by the context expression.
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.ManualQueryKeyExpression
INTERNAL: Rebuild myself against the base, with the values of parameters supplied by the context expression.
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Rebuild against the base, with the values of parameters supplied by the context expression.
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Rebuild myself against the base, with the values of parameters supplied by the context expression.
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
 
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.TableExpression
INTERNAL: Rebuild myself against the base, with the values of parameters supplied by the context expression.
twistedForBaseAndContext(Expression, Expression, Expression) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
TWO_STRUCT_CONVERTERS_ADDED_FOR_SAME_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
twoStructConvertersAddedForSameClass(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
TX_SESSION_TEST_ERROR - Static variable in exception org.eclipse.persistence.eis.EISException
 
type - Variable in class org.eclipse.persistence.core.queries.CoreAttributeGroup
The class represented by this AttrbuteGroup.
type - Variable in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
 
type - Variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
type - Variable in class org.eclipse.persistence.internal.codegen.ClassDefinition
 
type - Variable in class org.eclipse.persistence.internal.codegen.NonreflectiveAttributeDefinition
 
type - Variable in class org.eclipse.persistence.internal.codegen.ReflectiveAttributeDefinition
 
type - Variable in class org.eclipse.persistence.internal.codegen.ReflectiveMethodDefinition
 
type - Variable in class org.eclipse.persistence.internal.descriptors.QueryArgument
The type of the query argument
type - Variable in class org.eclipse.persistence.internal.dynamic.DynamicPropertiesManager
 
type - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
Respective Java type desired for the field's value, used to optimize performance and for binding.
type - Variable in class org.eclipse.persistence.oxm.schema.XMLSchemaReference
Indicates if a simple/complex type definition, element, or group is being referenced
type - Variable in class org.eclipse.persistence.queries.BatchFetchPolicy
Define the type of batch fetching to use.
type - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
Java type class for the field.
type - Variable in class org.eclipse.persistence.tools.schemaframework.NestedTableDefinition
 
type - Variable in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
 
type() - Method in annotation type org.eclipse.persistence.annotations.Cache
(Optional) The type of cache to use.
type() - Method in annotation type org.eclipse.persistence.annotations.OptimisticLocking
(Optional) The type of optimistic locking policy to use.
type() - Method in annotation type org.eclipse.persistence.annotations.StoredProcedureParameter
(Optional) The type of Java class desired back from the procedure, this is dependent on the type returned from the procedure.
type() - Method in annotation type org.eclipse.persistence.annotations.TenantTableDiscriminator
(Optional) The type of tenant table discriminator to use with the tables of the persistence unit.
type() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression that wraps the inheritance type field in an expression.
type() - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
PUBLIC: Return an expression that wraps the inheritance type field in an expression.
type() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNamedSubgraph
optional: only required for inheritance or with ChoiceMappings to specify which of the possible targets this subgraph is to be applied to.
type() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlParameter
 
type() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlVariableNode
The class being referenced
TYPE_CANNOT_BE_OPEN_AND_DATATYPE - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
TYPE_FORWARD_ONLY - Static variable in class org.eclipse.persistence.queries.ScrollableCursorPolicy
JDBC 2.0 The type for a ResultSet object whose cursor may move only forward.
TYPE_MISMATCH_BETWEEN_ATTRIBUTE_AND_CONSTANT_ON_EXPRESSION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
TYPE_NAME - Static variable in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
 
TYPE_NAME_NOT_SET - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
TYPE_NOT_FOUND - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
TYPE_NOT_FOUND_FOR_INTERFACE - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
TYPE_PROPERTY_MUST_BE_A_TYPE - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
TYPE_REFERENCED_BUT_NEVER_DEFINED - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
TYPE_SCROLL_INSENSITIVE - Static variable in class org.eclipse.persistence.queries.ScrollableCursorPolicy
JDBC 2.0 The type for a ResultSet object that is scrollable but generally not sensitive to changes made by others.
TYPE_SCROLL_SENSITIVE - Static variable in class org.eclipse.persistence.queries.ScrollableCursorPolicy
JDBC 2.0 The type for a ResultSet object that is scrollable and generally sensitive to changes made by others.
typeCannotBeOpenAndDataType(String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to set a type to be both open and dataType
TypeConversionConverter - Class in org.eclipse.persistence.mappings.converters
Purpose: Type conversion converters are used to explicitly map a database type to a Java type.
TypeConversionConverter() - Constructor for class org.eclipse.persistence.mappings.converters.TypeConversionConverter
PUBLIC: Default constructor.
TypeConversionConverter(DatabaseMapping) - Constructor for class org.eclipse.persistence.mappings.converters.TypeConversionConverter
PUBLIC: Default constructor.
TypeConverter - Annotation Type in org.eclipse.persistence.annotations
The TypeConverter annotation is used to specify an EclipseLink org.eclipse.persistence.mappings.converters.TypeConversionConverter for modification of the data value(s) during the reading and writing of a mapped attribute.
typeConverters - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
TypeConverters - Annotation Type in org.eclipse.persistence.annotations
A TypeConverters annotation allows the definition of multiple TypeConverter.
TypedAssociation - Class in org.eclipse.persistence.mappings
Purpose: Generic association object.
TypedAssociation() - Constructor for class org.eclipse.persistence.mappings.TypedAssociation
Default constructor.
TypedAssociation(Object, Object) - Constructor for class org.eclipse.persistence.mappings.TypedAssociation
PUBLIC: Create an association.
typeDefinition - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
Database-specific complete type definition like "VARCHAR2(50) UNIQUE NOT NULL".
TypeDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Allow for Oracle 8 object-relational user defined type to be created.
TypeDefinition() - Constructor for class org.eclipse.persistence.tools.schemaframework.TypeDefinition
 
TypeDefParticle - Class in org.eclipse.persistence.internal.oxm.schema.model
Purpose: Base class for Sequence, Choice and All
TypeDefParticle() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.TypeDefParticle
 
TypeDefParticleOwner - Interface in org.eclipse.persistence.internal.oxm.schema.model
Purpose: Class to represent an object that can be the owner of sequence, choice, all in a Schema
typeExpression - Variable in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
typeExpressionBase - Variable in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
typeField - Variable in class org.eclipse.persistence.mappings.VariableOneToOneMapping
 
typeIndicatorNameTranslation - Variable in class org.eclipse.persistence.mappings.VariableOneToOneMapping
parallel table typeIndicatorTranslation used prior to initialization to avoid type indicators on Mapping Workbench
typeIndicatorTranslation - Variable in class org.eclipse.persistence.mappings.VariableOneToOneMapping
 
typeIsValid(Class<?>) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return whether the type is appropriate for the indirection policy.
typeIsValid(Class<?>) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return whether the type is appropriate for the indirection policy.
typeIsValid(Class<?>) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return whether the type is appropriate for the indirection policy.
typeIsValid(Class<?>) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return whether the type is appropriate for the indirection policy.
TypeMapping - Class in org.eclipse.persistence.internal.descriptors
Purpose: Used to define object-type converter object->data values mapping.
TypeMapping() - Constructor for class org.eclipse.persistence.internal.descriptors.TypeMapping
Default constructor.
TypeMapping(Object, Object) - Constructor for class org.eclipse.persistence.internal.descriptors.TypeMapping
Create an association.
typeMismatchBetweenAttributeAndConstantOnExpression(Class<?>, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
typeName - Variable in class org.eclipse.persistence.core.queries.CoreAttributeGroup
The name of the class represented by this AttrbuteGroup.
typeName - Variable in class org.eclipse.persistence.internal.databaseaccess.OutputParameterForCallableStatement
 
typeName - Variable in class org.eclipse.persistence.internal.descriptors.QueryArgument
 
typeName - Variable in class org.eclipse.persistence.internal.helper.ComplexDatabaseType
 
typeName - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
 
typeName - Variable in class org.eclipse.persistence.tools.schemaframework.FieldDefinition
Generic database type name for the field, which can be used instead of the Java class 'type'.
typeName - Variable in class org.eclipse.persistence.tools.schemaframework.NestedTableDefinition
 
typeName - Variable in class org.eclipse.persistence.tools.schemaframework.TypeTableDefinition
The name of the type that this table is of.
typeName - Variable in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
 
typeNameNotSet(DatabaseType) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
TypeNodeValue - Class in org.eclipse.persistence.internal.oxm
 
TypeNodeValue() - Constructor for class org.eclipse.persistence.internal.oxm.TypeNodeValue
 
typeNotFound(String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to lookup a type with the given uri and name
typeNotFoundForInterface(String, boolean) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception trying to lookup a type with the given interface
typePropertyMustBeAType(Exception) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: thrown from SDOXMLHelperDelegate
typeReferencedButNotDefined(String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
 
typeSize - Variable in class org.eclipse.persistence.tools.schemaframework.NestedTableDefinition
 
typeSize - Variable in class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
 
typeStrings - Variable in class org.eclipse.persistence.platform.database.SybasePlatform
 
typesuffix - Variable in class org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition
 
typeSuffix - Static variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
TypeTableDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Allow for tabels of Oracle 8 object-relational user defined type to be created.
TypeTableDefinition() - Constructor for class org.eclipse.persistence.tools.schemaframework.TypeTableDefinition
 
typeValueFromObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
INTERNAL This method returns the inheritance field value for an object to conform in an in-memory query.

U

UN_EXPECTED_VALUE_OF_TAG - Static variable in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
UNABLE_TO_ACQUIRE_CONNECTION_FROM_DRIVER - Static variable in exception org.eclipse.persistence.exceptions.DatabaseException
 
UNABLE_TO_CONNECT - Static variable in exception org.eclipse.persistence.exceptions.CommunicationException
 
UNABLE_TO_DETERMINE_MAP_KEY_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
UNABLE_TO_DETERMINE_TARGET_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
UNABLE_TO_DETERMINE_TARGET_ENTITY - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
UNABLE_TO_LOAD_CLASS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
UNABLE_TO_LOAD_METADATA_FROM_LOCATION - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
UNABLE_TO_LOAD_PROJECT_CLASS - Static variable in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
UNABLE_TO_PARSE_XML - Static variable in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
UNABLE_TO_PROCESS_TAG - Static variable in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
UNABLE_TO_PROPAGATE_CHANGES - Static variable in exception org.eclipse.persistence.exceptions.CommunicationException
 
UNABLE_TO_SET_PROPERTIES - Static variable in exception org.eclipse.persistence.exceptions.ConversionException
 
UNABLE_TO_SET_REDIRECTOR_FROM_HINT - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
unableToAcquireConnectionFromDriverException(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
The connection returned from this driver was null, the driver may be missing(using the default) or the wrong one for the database.
unableToAcquireConnectionFromDriverException(SQLException, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.DatabaseException
The connection returned from this driver was null, the driver may be missing(using the default) or the wrong one for the database.
unableToConnect(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.CommunicationException
 
unableToDetermineMapKeyClass(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
unableToDetermineTargetClass(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
unableToDetermineTargetEntity(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Possible cause: the type of the attribute is Map, Set, List or Collection, and no target-entity is defined.
unableToLoadClass(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
unableToLoadMetadataFromLocation(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
unableToMapDataHandlerDueToMissingDependency(String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
 
unableToPropagateChanges(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.CommunicationException
 
unableToPropagateCommand(String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.RemoteCommandManagerException
 
unableToSetRedirectorOnQueryFromHint(DatabaseQuery, String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
UnaryTableSequence - Class in org.eclipse.persistence.sequencing
Purpose: Defines sequencing through using a singleton sequence table.
UnaryTableSequence() - Constructor for class org.eclipse.persistence.sequencing.UnaryTableSequence
 
UnaryTableSequence(String) - Constructor for class org.eclipse.persistence.sequencing.UnaryTableSequence
Create a new sequence with the name.
UnaryTableSequence(String, int) - Constructor for class org.eclipse.persistence.sequencing.UnaryTableSequence
Create a new sequence with the name and sequence pre-allocation size.
UnaryTableSequence(String, int, String) - Constructor for class org.eclipse.persistence.sequencing.UnaryTableSequence
 
UnaryTableSequence(String, String) - Constructor for class org.eclipse.persistence.sequencing.UnaryTableSequence
 
UnaryTableSequenceConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.sequencing
INTERNAL:
UnaryTableSequenceConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.sequencing.UnaryTableSequenceConfig
 
UnaryTableSequenceDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Creates / drops an unary sequence table: the name of the table is sequence name; its only field is named unarySequenceCounterFieldName
UnaryTableSequenceDefinition(Sequence) - Constructor for class org.eclipse.persistence.tools.schemaframework.UnaryTableSequenceDefinition
INTERNAL: Should be a sequence defining unary table sequence in the db: either UnaryTableSequence DefaultSequence (only if case platform.getDefaultSequence() is an UnaryTableSequence).
UnaryTableSequenceDefinition(Sequence, boolean) - Constructor for class org.eclipse.persistence.tools.schemaframework.UnaryTableSequenceDefinition
 
UNBOUNDED - Static variable in class org.eclipse.persistence.internal.oxm.schema.model.Occurs
 
UNCOMPUTED_DISTINCT - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
unconvertedProperties - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
Allow the user to defined un-converted properties which will be initialized at runtime.
unconvertedProperties - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
Allow the user to defined un-converted properties which will be initialized at runtime.
UNDEFINED - org.eclipse.persistence.mappings.DatabaseMapping.WriteType
 
UNDEFINED - Static variable in class org.eclipse.persistence.descriptors.CMPPolicy
undefined if it is non-deferred issue sql at create
UNDEFINED - Static variable in interface org.eclipse.persistence.internal.sequencing.Sequencing
 
UNDEFINED_ISOLATATION - Static variable in class org.eclipse.persistence.descriptors.CachePolicy
 
UNDEFINED_ISOLATATION - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
UNDEFINED_LOOKUP - Static variable in class org.eclipse.persistence.sessions.JNDIConnector
 
UNDEFINED_OBJECT_CHANGE_BEHAVIOR - Static variable in class org.eclipse.persistence.descriptors.CachePolicy
 
UNDEFINED_OBJECT_CHANGE_BEHAVIOR - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
undeleteObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This method is used to transition an object from the deleted objects list to be simply be register.
UNEXPECTED_INVOCATION - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
unexpectedChar - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
unexpectedChar(String, int, int, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
unexpectedEOF - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
unexpectedEOF(String, int, int, Exception) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
unexpectedInvocation(String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
unexpectedToken - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
unexpectedToken(String, int, int, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
unexpectedValueOfTag(String, String) - Static method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
UNFETCHED_ATTRIBUTE_NOT_EDITABLE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
unfetchedAttributeNotEditable(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
UNI_DIRECTIONAL_ONE_TO_MANY_HAS_JOINCOLUMN_ANNOTATIONS - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
uniDirectionalOneToManyHasJoinColumnAnnotations(String, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
UnidirectionalOneToManyMapping - Class in org.eclipse.persistence.mappings
Purpose: UnidirectionalOneToManyMapping doesn't have 1:1 back reference mapping.
UnidirectionalOneToManyMapping() - Constructor for class org.eclipse.persistence.mappings.UnidirectionalOneToManyMapping
PUBLIC: Default constructor.
UNINITIALIZED - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
The following are the [initializationStage] states the descriptor passes through during the initialization.
union() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the UNION operator.
union(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a union expression with the subquery.
union(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a union expression with the subquery.
union(ReportQuery) - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PUBLIC: Union the query results with the other query.
Union - Class in org.eclipse.persistence.internal.oxm.schema.model
 
Union - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
Union operators
Union() - Constructor for class org.eclipse.persistence.internal.oxm.schema.model.Union
 
unionAll() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Create the UNION ALL operator.
unionAll(Expression) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a union all expression with the subquery.
unionAll(ReportQuery) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return a union all expression with the subquery.
UnionAll - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
unionEntityFetchGroupIntoObject(Object, EntityFetchGroup, AbstractSession, boolean) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Union the fetch group of the domain object with the new fetch group.
unionExpressions - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Union clause.
unionExpressions - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
Allow a query's results to be unioned (UNION, INTERSECT, EXCEPT) with another query results.
unionFetchGroups(FetchGroup, FetchGroup) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Union two fetch groups.
UnionField<CONVERSION_MANAGER extends ConversionManager,​NAMESPACE_RESOLVER extends NamespaceResolver> - Interface in org.eclipse.persistence.internal.oxm.mappings
Subclass of Field for fields that are mapped to unions.
UnionPartitioning - Annotation Type in org.eclipse.persistence.annotations
UnionPartitioning sends queries to all connection pools and unions the results.
UnionPartitioningPolicy - Class in org.eclipse.persistence.descriptors.partitioning
PUBLIC: UnionPartitionPolicy sends queries to all connection pools and unions the results.
UnionPartitioningPolicy() - Constructor for class org.eclipse.persistence.descriptors.partitioning.UnionPartitioningPolicy
 
UnionPartitioningPolicy(boolean) - Constructor for class org.eclipse.persistence.descriptors.partitioning.UnionPartitioningPolicy
 
UnionPartitioningPolicy(String...) - Constructor for class org.eclipse.persistence.descriptors.partitioning.UnionPartitioningPolicy
 
UnionPartitioningPolicy(List<String>) - Constructor for class org.eclipse.persistence.descriptors.partitioning.UnionPartitioningPolicy
 
unionUnpartitionableQueries - Variable in class org.eclipse.persistence.descriptors.partitioning.FieldPartitioningPolicy
If query does not have the partition field in it, should the query be sent to all databases.
unionUnpartitionableQueries() - Method in annotation type org.eclipse.persistence.annotations.HashPartitioning
Defines if queries that do not contain the partition field should be sent to every database and have the result unioned.
unionUnpartitionableQueries() - Method in annotation type org.eclipse.persistence.annotations.RangePartitioning
Defines if queries that do not contain the partition field should be sent to every database and have the result unioned.
unionUnpartitionableQueries() - Method in annotation type org.eclipse.persistence.annotations.ValuePartitioning
Defines if queries that do not contain the partition field should be sent to every database and have the result unioned.
unique() - Method in annotation type org.eclipse.persistence.annotations.Index
 
uniqueConstraints - Variable in class org.eclipse.persistence.internal.helper.DatabaseTable
Contains the user specified unique constraints.
uniqueConstraints() - Method in annotation type org.eclipse.persistence.annotations.CollectionTable
Deprecated.
(Optional) Unique constraints that are to be placed on the table.
UniqueKeyConstraint - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Define a unique key constraint for a table.
UniqueKeyConstraint() - Constructor for class org.eclipse.persistence.tools.schemaframework.UniqueKeyConstraint
 
UniqueKeyConstraint(String, String) - Constructor for class org.eclipse.persistence.tools.schemaframework.UniqueKeyConstraint
 
UniqueKeyConstraint(String, String[]) - Constructor for class org.eclipse.persistence.tools.schemaframework.UniqueKeyConstraint
 
uniqueKeys - Variable in class org.eclipse.persistence.tools.schemaframework.TableDefinition
 
UNIT_OF_WORK_AFTER_WRITE_CHANGES_FAILED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
UNIT_OF_WORK_IN_TRANSACTION_COMMIT_PENDING - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
UNIT_OF_WORK_ISOLATED_OBJECTS_ACCESSED_IN_SESSION - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
unitOfWork - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteSessionController
Use the temporary unit of work to isolate queries after an early transaction.
unitOfWork - Variable in class org.eclipse.persistence.transaction.AbstractSynchronizationListener
The unit of work associated with the global txn that this listener is bound to.
UnitOfWork - Interface in org.eclipse.persistence.sessions
Purpose: To allow object level transactions.
UnitOfWork.CommitOrderType - Enum in org.eclipse.persistence.sessions
Defines the ordering of updates and deletes of a set of the same entity type during a commit or flush operation.
unitOfWorkAfterWriteChangesFailed(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
unitOfWorkCacheIsolationLevel - Variable in class org.eclipse.persistence.descriptors.CachePolicy
Configures how the unit of work uses the session cache.
unitOfWorkChangeSet - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
This member variable holds the reference to the parent UnitOfWork Change Set
unitOfWorkChangeSet - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
This method is used to store the current changeSet for this UnitOfWork.
UnitOfWorkChangeSet - Class in org.eclipse.persistence.internal.sessions
Purpose: This is the overall collection of changes.
UnitOfWorkChangeSet - Interface in org.eclipse.persistence.sessions.changesets
Purpose: To Provide API to the UnitOfWorkChangeSet.
UnitOfWorkChangeSet() - Constructor for class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Create a ChangeSet
UnitOfWorkChangeSet(AbstractSession) - Constructor for class org.eclipse.persistence.internal.sessions.UnitOfWorkChangeSet
INTERNAL: Create a ChangeSet
UnitOfWorkIdentityMap - Class in org.eclipse.persistence.internal.identitymaps
Unit of work specific identity map which avoid additional overhead not required in unit of work, such as locking and synchronization.
UnitOfWorkIdentityMap() - Constructor for class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
 
UnitOfWorkIdentityMap(int, ClassDescriptor, AbstractSession, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.UnitOfWorkIdentityMap
 
UnitOfWorkIdentityMapAccessor - Class in org.eclipse.persistence.internal.sessions
INTERNAL: IdentityMapAccessor subclass for UnitOfWork Overrides some initialization functionality and some behavior having to do with getting objects from identity maps.
UnitOfWorkIdentityMapAccessor() - Constructor for class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
 
UnitOfWorkIdentityMapAccessor(AbstractSession, IdentityMapManager) - Constructor for class org.eclipse.persistence.internal.sessions.UnitOfWorkIdentityMapAccessor
 
UnitOfWorkImpl - Class in org.eclipse.persistence.internal.sessions
Implementation of org.eclipse.persistence.sessions.UnitOfWork The public interface should be used.
UnitOfWorkImpl() - Constructor for class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL:
UnitOfWorkImpl(AbstractSession, ReferenceMode) - Constructor for class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Create and return a new unit of work with the session as its parent.
unitOfWorkInTransactionCommitPending() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
unitOfWorkInTransactionCommitPending(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
unitOfWorkIsolatedObjectsAccessedInSession(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
UnitOfWorkQueryValueHolder<T> - Class in org.eclipse.persistence.internal.indirection
UnitOfWorkQueryValueHolder wraps a database-stored object and implements behavior to access it.
UnitOfWorkQueryValueHolder() - Constructor for class org.eclipse.persistence.internal.indirection.UnitOfWorkQueryValueHolder
 
UnitOfWorkQueryValueHolder(ValueHolderInterface<T>, Object, DatabaseMapping, UnitOfWorkImpl) - Constructor for class org.eclipse.persistence.internal.indirection.UnitOfWorkQueryValueHolder
 
UnitOfWorkQueryValueHolder(ValueHolderInterface<T>, Object, ForeignReferenceMapping, AbstractRecord, UnitOfWorkImpl) - Constructor for class org.eclipse.persistence.internal.indirection.UnitOfWorkQueryValueHolder
 
UnitOfWorkTransformerValueHolder<T> - Class in org.eclipse.persistence.internal.indirection
UnitOfWorkTransformerValueHolder wraps a database-stored object and implements behavior to access it.
UnitOfWorkTransformerValueHolder(ValueHolderInterface<T>, Object, Object, AbstractTransformationMapping, UnitOfWorkImpl) - Constructor for class org.eclipse.persistence.internal.indirection.UnitOfWorkTransformerValueHolder
 
UnitOfWorkTransformerValueHolder(ValueHolderInterface<T>, Object, DatabaseMapping, UnitOfWorkImpl) - Constructor for class org.eclipse.persistence.internal.indirection.UnitOfWorkTransformerValueHolder
 
unitOfWorkValueHolder - Variable in class org.eclipse.persistence.internal.indirection.BackupValueHolder
Stores the original uow clone's value holder.
UnitOfWorkValueHolder<T> - Class in org.eclipse.persistence.internal.indirection
A UnitOfWorkValueHolder is put in a clone object.
UnitOfWorkValueHolder() - Constructor for class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
UnitOfWorkValueHolder(ValueHolderInterface<T>, Object, DatabaseMapping, UnitOfWorkImpl) - Constructor for class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
unitsOfWork - Variable in class org.eclipse.persistence.transaction.AbstractTransactionController
Table of external transaction object keys and unit of work values
Unknown - Static variable in class org.eclipse.persistence.config.ResultSetType
The order in which rows in a result set will be processed is unknown.
UNKNOWN_ATTRIBUTE_OF_TAG - Static variable in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
UNKNOWN_INTERACTION_SPEC_TYPE - Static variable in exception org.eclipse.persistence.eis.EISException
 
UNKNOWN_OR_TRANSIENT_CLASS - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
UNKNOWN_PROPERTY_FOR_VARIABLE_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
UNKNOWN_PROXY_TYPE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
UNKNOWN_TAG - Static variable in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
UNKNOWN_TYPE_FOR_VARIABLE_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
UNKNOWN_XSI_TYPE - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
unknownAttribute - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
unknownAttribute(String, int, int, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
unknownAttributeOfTag(String) - Static method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
unknownInteractionSpecType() - Static method in exception org.eclipse.persistence.eis.EISException
 
unknownPropertyForVariableNode(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
unknownProxyType(int, String, String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Proxy property corresponding to the specified proxy type was not found.
unknownTypeForVariableNode(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
unknownXsiTypeValue(String, Mapping) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
unknownXsiTypeValue(String, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
unkownTagAtNode(String, String, Throwable) - Static method in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
UNMAPPED - Static variable in class org.eclipse.persistence.descriptors.ReturningPolicy
 
UNMAPPED_CONTENTHANDLER_DOESNT_IMPLEMENT - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
unmappedContent() - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalRecord
 
unmappedContent() - Method in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
unmappedContent() - Method in class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
unmappedContent(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.ChoiceUnmarshalContext
 
unmappedContent(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.record.ObjectUnmarshalContext
 
unmappedContent(UnmarshalRecord) - Method in class org.eclipse.persistence.internal.oxm.record.SequencedUnmarshalContext
 
unmappedContent(UnmarshalRecord) - Method in interface org.eclipse.persistence.internal.oxm.record.UnmarshalContext
This method is called when unmapped content (XML content that does not correspond to any specified mapping, policy, etc.) is encountered during the unmarshal process.
UnmappedContentHandler<UNMARSHAL_RECORD extends UnmarshalRecord> - Interface in org.eclipse.persistence.internal.oxm.unmapped
Purpose:Provide an interface that can be implemented for handling unmapped content during unmarshal operations with SAXPlatform.
UnmappedContentHandler - Interface in org.eclipse.persistence.oxm.unmapped
Purpose:Provide an interface that can be implemented for handling unmapped content during unmarshal operations with SAXPlatform.
unmappedContentHandlerDoesntImplement(Exception, String) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
UnmappedContentHandlerWrapper - Class in org.eclipse.persistence.internal.oxm.record
INTERNAL: This class delegates all events corresponding to the UnmappedContentHandler.
UnmappedContentHandlerWrapper(UnmarshalRecord, UnmappedContentHandler) - Constructor for class org.eclipse.persistence.internal.oxm.record.UnmappedContentHandlerWrapper
 
UnmappedContentHandlerWrapper(UnmappedContentHandler, SAXUnmarshallerHandler) - Constructor for class org.eclipse.persistence.internal.oxm.record.UnmappedContentHandlerWrapper
 
unmarshal(File) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(File) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(File) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(File) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Read and parse the XML document from the file and map the XML data into an object.
unmarshal(File, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(File, Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(File, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(File, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Read and parse the XML document from the file and map the XML data into an object.
unmarshal(InputStream) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(InputStream) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(InputStream) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(InputStream) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Read and parse the XML document from the inputStream and map the XML data into an object.
unmarshal(InputStream, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(InputStream, Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(InputStream, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(InputStream, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Read and parse the XML document from the inputStream and map the XML data into an object.
unmarshal(Reader) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(Reader) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(Reader) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(Reader) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Read and parse the XML document from the reader and map the XML data into an object.
unmarshal(Reader, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(Reader, Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(Reader, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(Reader, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Read and parse the XML document from the reader and map the XML data into an object.
unmarshal(String) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(String, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(URL) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(URL) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(URL) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(URL) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Read and parse the XML document from the url and map the XML data into an object.
unmarshal(URL, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(URL, Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(URL, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(URL, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Read and parse the XML document from the url and map the XML data into an object.
unmarshal(Source) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(Source) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(Source) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(Source) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Read and parse the XML document from the source and map the XML data into an object.
unmarshal(Source, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(Source, Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(Source, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(Source, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Read and parse the XML document from the source and map the XML data into an object.
unmarshal(DOMReader, Node) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(DOMReader, Node, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(Node) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(Node) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(Node) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(Node) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Map the XML node into an object.
unmarshal(Node) - Method in class org.eclipse.persistence.oxm.XMLBinder
This method will unmarshal the provided node into mapped java objects.
unmarshal(Node, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(Node, Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(Node, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(Node, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Map the XML node into an object.
unmarshal(Node, Class<?>) - Method in class org.eclipse.persistence.oxm.XMLBinder
 
unmarshal(InputSource) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(InputSource) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(InputSource) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(InputSource) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Read and parse the XML document from the inputSource and map the XML data into an object.
unmarshal(InputSource, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(InputSource, Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(InputSource, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(InputSource, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
PUBLIC: Read and parse the XML document from the inputSource and map the XML data into an object.
unmarshal(InputSource, Class<?>, XMLReader) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(InputSource, XMLReader) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(XMLReader, InputSource) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(XMLReader, InputSource) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(XMLReader, InputSource) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(XMLReader, InputSource) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
unmarshal(XMLReader, InputSource, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
 
unmarshal(XMLReader, InputSource, Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.record.PlatformUnmarshaller
 
unmarshal(XMLReader, InputSource, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.SAXUnmarshaller
 
unmarshal(XMLReader, InputSource, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
UNMARSHAL_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
UNMARSHAL_FROM_STRING_FAILED - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
UnmarshalContext - Interface in org.eclipse.persistence.internal.oxm.record
The UnmarshalContext allows mappings to be unmarshalled differently depending on the type of object.
unmarshalException() - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
unmarshalException(Exception) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
unmarshalFromStringException(String, Exception) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
UnmarshalKeepAsElementPolicy - Enum in org.eclipse.persistence.oxm.mappings
Purpose: Used in conjunction with XMLAnyObject/CollectionMapping and XMLCompositeObject/CollectionMapping to specify when (if at all) to keep parts of the unmarshalled document as nodes.
UnmarshalKeepAsElementPolicy - Interface in org.eclipse.persistence.internal.oxm.mappings
 
unmarshaller - Variable in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
unmarshaller - Variable in class org.eclipse.persistence.oxm.record.XMLRecord
 
Unmarshaller<ABSTRACT_SESSION extends CoreAbstractSession,​CONTEXT extends Context,​DESCRIPTOR extends Descriptor,​ID_RESOLVER extends IDResolver,​MEDIA_TYPE extends MediaType,​ROOT extends Root,​UNMARSHALLER_HANDLER extends UnmarshallerHandler,​UNMARSHALLER_LISTENER extends Unmarshaller.Listener> - Class in org.eclipse.persistence.internal.oxm
 
Unmarshaller(CONTEXT) - Constructor for class org.eclipse.persistence.internal.oxm.Unmarshaller
 
Unmarshaller(Unmarshaller) - Constructor for class org.eclipse.persistence.internal.oxm.Unmarshaller
Copy constructor
Unmarshaller.Listener - Interface in org.eclipse.persistence.internal.oxm
An implementation of UnmarshalListener can be set on an Unmarshaller to provide additional behaviour during unmarshal operations.
UnmarshallerHandler - Interface in org.eclipse.persistence.internal.oxm
Class used to unmarshal SAX events to objects.
UnmarshalNamespaceContext - Class in org.eclipse.persistence.internal.oxm.record.namespaces
An UnmarshalNamespaceResolver that delegates all work to a NamespaceContext.
UnmarshalNamespaceContext() - Constructor for class org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceContext
 
UnmarshalNamespaceContext(XMLStreamReader) - Constructor for class org.eclipse.persistence.internal.oxm.record.namespaces.UnmarshalNamespaceContext
 
UnmarshalNamespaceResolver - Interface in org.eclipse.persistence.internal.oxm.record.namespaces
An abstraction to represent a namespace resolver for unmarshalling based on the XML input.
UnmarshalRecord - Class in org.eclipse.persistence.oxm.record
 
UnmarshalRecord<ABSTRACT_SESSION extends CoreAbstractSession,​FIELD extends CoreField,​ID_RESOLVER extends IDResolver,​OBJECT_BUILDER extends ObjectBuilder,​TRANSFORMATION_RECORD extends TransformationRecord,​UNMARSHALLER extends Unmarshaller> - Interface in org.eclipse.persistence.internal.oxm.record
This class represents unmarshal record behaviour that is specific to the SAX platform.
UnmarshalRecord(UnmarshalRecord) - Constructor for class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
UnmarshalRecord(TreeObjectBuilder) - Constructor for class org.eclipse.persistence.oxm.record.UnmarshalRecord
 
UnmarshalRecordImpl<TRANSFORMATION_RECORD extends TransformationRecord> - Class in org.eclipse.persistence.internal.oxm.record
Purpose:Provide an implementation of ContentHandler that is used by TopLink OXM to build mapped Java Objects from SAX events.
UnmarshalRecordImpl() - Constructor for class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
UnmarshalRecordImpl(ObjectBuilder) - Constructor for class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
UnmarshalXPathEngine<XML_FIELD extends Field> - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
UnmarshalXPathEngine() - Constructor for class org.eclipse.persistence.internal.oxm.UnmarshalXPathEngine
The default constructor creates a platform instance
unmodifiableVector(Vector<? extends T>) - Static method in class org.eclipse.persistence.internal.oxm.VectorUtils
Returns an unmodifiable view of the specified vector.
UNNAMED_ARG_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
UNNAMED_QUERY_ON_SESSION_BROKER - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
unnamedArgumentsNotSupported() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
unnamedQueryOnSessionBroker(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
unprepare() - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Unprepare the call if required.
unprepare() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Unprepare the call if required.
UNQUALIFIED - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
unregisteredDeletedObjectsCloneToBackupAndOriginal - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Used to store objects already deleted from the db and unregistered
unregisteredExistingObjects - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
unregisteredNewObjects - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
unregisteredNewObjectsCache - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
 
unregisteredNewObjectsInParent - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
unregisterMBean() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: unregisterMBean(): Unregister the JMX MBean that was providing runtime services for my databaseSession.
unregisterMBean() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: unregisterMBean(): Unregister the JMX MBean that was providing runtime services for my databaseSession.
unregisterObject(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
PUBLIC: Unregister the object with the unit of work.
unregisterObject(Object) - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Unregister the object with the unit of work.
unregisterObject(Object, int) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Unregister the object with the unit of work.
unregisterObject(Object, int, boolean) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Unregister the object with the unit of work.
UNSIGNED_BYTE - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
UNSIGNED_BYTE_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
UNSIGNED_INT - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
UNSIGNED_INT_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
UNSIGNED_LONG - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
UNSIGNED_LONG_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
UNSIGNED_SHORT - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
UNSIGNED_SHORT_QNAME - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
UNSPECIFIED_COMPOSITE_PK_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
unspecifiedCompositePKNotSupported(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
UNSUPPORTED_CASCADE_LOCKING_DESCRIPTOR - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
UNSUPPORTED_CASCADE_LOCKING_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
UNSUPPORTED_CASCADE_LOCKING_MAPPING_WITH_CUSTOM_QUERY - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
UNSUPPORTED_MAPPING_FOR_OBJECT_COMPARISON - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
UNSUPPORTED_MAPPING_FOR_QUERYBYEXAMPLE - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
UNSUPPORTED_NODE_CLASS - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
UNSUPPORTED_TYPE_FOR_BIDIRECTIONAL_RELATIONSHIP_MAINTENANCE - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
unsupportedCascadeLockingDescriptor(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
unsupportedCascadeLockingMapping(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
unsupportedCascadeLockingMappingWithCustomQuery(DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
unsupportedMappingForObjectComparison(DatabaseMapping, Expression) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
unsupportedMappingQueryByExample(String, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
unsupportedMediaTypeForPlatform() - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
unsupportedMessageInInputRecord() - Static method in exception org.eclipse.persistence.eis.EISException
 
unsupportedMessageInOutputRecord() - Static method in exception org.eclipse.persistence.eis.EISException
 
unsupportedNodeClass(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
unsupportedTypeForBidirectionalRelationshipMaintenance(DatabaseMapping, ContainerPolicy) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
unsupportJoinArgument - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
unsupportJoinArgument(String, int, int, String, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
unwrap(Class<T>) - Method in interface org.eclipse.persistence.internal.databaseaccess.DatabaseJsonPlatform
Unwrap this DatabaseJsonPlatform instance as provided class.
unwrapConnection(Connection) - Method in class org.eclipse.persistence.platform.server.glassfish.GlassfishPlatform
 
unwrapConnection(Connection) - Method in class org.eclipse.persistence.platform.server.NoServerPlatform
INTERNAL: When there is no server, the original connection will be returned
unwrapConnection(Connection) - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: This method is used to unwrap the oracle connection wrapped by the application server.
unwrapConnection(Connection) - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: This method is used to unwrap the connection wrapped by the application server.
unwrapConnection(Connection) - Method in class org.eclipse.persistence.platform.server.was.WebSphere_Liberty_Platform
This method overrides functionality exposed in the base WebSpherePlatform as Liberty doesn't provide the same support.
unwrapConnection(Connection) - Method in class org.eclipse.persistence.platform.server.was.WebSpherePlatform
Unwraps the WebSphere JDBC connection wrapping using the WebLogic API reflectively.
unwrapConnection(Connection) - Method in class org.eclipse.persistence.platform.server.wls.WebLogicPlatform
Unwraps the WebLogic JDBC connection wrapping using the WebLogic API reflectively.
unwrapElement(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: MapContainerPolicy's iterator iterates on the Entries of a Map.
unwrapElement(Object) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: MapContainerPolicy's iterator iterates on the Entries of a Map.
unwrapIteratorResult(Object) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Depending on the container, the entries returned of iteration using the ContainerPolicy.iteratorFor() method may be wrapped.
unwrapIteratorResult(Object) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: MapContainerPolicy's iterator iterates on the Entries of a Map.
unwrapKey(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: Allow the key to be unwrapped.
unwrapKey(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Allow the key to be unwrapped.
unwrapKey(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Allow the key mapping to unwrap the object.
unwrapKey(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Allow the key mapping to unwrap the object.
unwrapKey(Object, AbstractSession) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Allow the key mapping to unwrap the object
unwrapKey(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Allow the key mapping to unwrap the object.
unwrapObject(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Unwrap the object if required.
unwrapObject(Object, AbstractSession) - Method in interface org.eclipse.persistence.descriptors.WrapperPolicy
PUBLIC: Required: Unwrap the object to return the implementation that is meant to be used by EclipseLink.
unwrapObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Unwrap the object if required.
unwrapOracleConnection(Connection) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: If can unwrap returns unwrapped Oracle connection, otherwise original connection.
UNWRAPPING_OBJECT_DELETED_SINCE_LAST_READ - Static variable in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
unwrappingObjectDeletedSinceLastRead(Vector, String) - Static method in exception org.eclipse.persistence.exceptions.OptimisticLockException
 
unwrapType(DatabaseTypeWrapper) - Static method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
Unwrap the type from a type wrapper to handle XML conversion.
uow - Variable in class org.eclipse.persistence.internal.descriptors.changetracking.AttributeChangeListener
 
UowCommit - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
UowCommits - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
UowCreated - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
UowReleased - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
UowRollbacks - Static variable in interface org.eclipse.persistence.sessions.SessionProfiler
 
Updatable - Static variable in class org.eclipse.persistence.config.ResultSetConcurrency
The concurrency mode for a ResultSet object that may be updated.
updatableFields - Variable in class org.eclipse.persistence.mappings.OneToOneMapping
 
update() - Method in annotation type org.eclipse.persistence.annotations.QueryRedirectors
A Default Update Query Redirector will be applied to any executing UpdateObjectQuery or UpdateAllQuery that does not have a redirector set directly on the query.
update(String, Object) - Method in interface org.eclipse.persistence.sessions.SessionProfiler
INTERNAL: Update the value of the State sensor.(DMS)
update(String, Object) - Method in class org.eclipse.persistence.sessions.SessionProfilerAdapter
INTERNAL: Update the value of the State sensor.(DMS)
update(String, Object) - Method in class org.eclipse.persistence.tools.profiler.PerformanceMonitor
 
update(Accessor, AbstractSession, String, Number) - Method in class org.eclipse.persistence.sequencing.QuerySequence
INTERNAL:
update(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Update the private owned part.
UPDATE - org.eclipse.persistence.mappings.DatabaseMapping.WriteType
 
UPDATE - Static variable in class org.eclipse.persistence.descriptors.ReturningPolicy
 
UPDATE_ALL_FIELDS_NOT_SET - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
UPDATE_ALL_QUERY_ADD_UPDATE_DEFINES_WRONG_FIELD - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
UPDATE_ALL_QUERY_ADD_UPDATE_DOES_NOT_DEFINE_FIELD - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
UPDATE_ALL_QUERY_ADD_UPDATE_FIELD_IS_NULL - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
UPDATE_MODIFICATIONS - Static variable in class org.eclipse.persistence.descriptors.CMPPolicy
defer updates
UPDATE_ORIGINAL_TABLE - Static variable in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
UPDATE_STATEMENTS_NOT_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.QueryException
 
updateable() - Method in annotation type org.eclipse.persistence.annotations.CacheIndex
Specify if the indexed field is updateable.
updateAccess() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
Notifies that cache key that it has been accessed.
updateAccess() - Method in class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap.ReferenceCacheKey
Notifies that cache key that it has been accessed.
updateAccess() - Method in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
UpdateAfterInsert - org.eclipse.persistence.mappings.OneToOneMapping.ShallowMode
 
updateAll() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Issue update SQL statement
updateAll() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Update the rows on the database.
UpdateAll - Static variable in class org.eclipse.persistence.config.QueryType
 
updateAllFields - Variable in class org.eclipse.persistence.descriptors.CMPPolicy
 
updateAllFieldsNotSet(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
UpdateAllQuery - Class in org.eclipse.persistence.queries
PUBLIC: A Query Class used to perform a bulk update using TopLink's expression framework.
UpdateAllQuery() - Constructor for class org.eclipse.persistence.queries.UpdateAllQuery
PUBLIC: Constructs a default update all query.
UpdateAllQuery(Class<?>) - Constructor for class org.eclipse.persistence.queries.UpdateAllQuery
PUBLIC: Constructs an update all query for the Class type specified.
UpdateAllQuery(Class<?>, Expression) - Constructor for class org.eclipse.persistence.queries.UpdateAllQuery
PUBLIC: Constructs an update all query for the specified Class type and selection criteria.
UpdateAllQuery(Class<?>, ExpressionBuilder) - Constructor for class org.eclipse.persistence.queries.UpdateAllQuery
PUBLIC: Constructs an update all query for the Class type specified and the given ExpressionBuilder.
updateAllQueryAddUpdateDefinesWrongField(ClassDescriptor, DatabaseQuery, String, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
updateAllQueryAddUpdateDoesNotDefineField(ClassDescriptor, DatabaseQuery, String) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
updateAllQueryAddUpdateFieldIsNull(DatabaseQuery) - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
updateAllUsingTempTables() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Execute updateAll using temp tables
updateAndSelectSequence(Accessor, AbstractSession, String, int) - Method in class org.eclipse.persistence.sequencing.QuerySequence
INTERNAL:
updateAndSelectSequence(Accessor, AbstractSession, String, int) - Method in class org.eclipse.persistence.sequencing.StandardSequence
 
UpdateAtIndex - Static variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
updateAtIndexQuery - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
Used (only in case listOrderField != null) to update orderFieldValue of object with particular orderFieldValue
updateAttributeAddObjectToCollection(String, Object, Object) - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
ADVANCED: Use this method when updating object attribute values, with unmapped objects Integer, String or others.
updateAttributeRemoveObjectFromCollection(String, Object, Object) - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
ADVANCED: Use this method when updating object attribute values, with unmapped objects Integer, String or others.
updateAttributeWithObject(String, Object) - Method in class org.eclipse.persistence.descriptors.DescriptorEvent
ADVANCED: Use this method when updating object attribute values, with unmapped objects Integer, String or others.
UpdateBeforeDelete - org.eclipse.persistence.mappings.OneToOneMapping.ShallowMode
 
updateCachedAttributes(PersistenceEntity, CacheKey, Object) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
INTERNAL: Used to updated any attributes that may be cached on a woven entity
updateCacheKeyProperties(UnitOfWorkImpl, CacheKey, Object, Object, ObjectChangeSet, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.MergeManager
INTERNAL: Update CacheKey properties with new information.
updateCacheSize(String, int) - Method in class org.eclipse.persistence.services.DevelopmentServices
This method is used to update the cache size of a particular Identity Map
updateCacheSize(String, int) - Method in interface org.eclipse.persistence.services.mbean.MBeanDevelopmentServicesMBean
This method is used to update the cache size of a particular Identity Map If ClassNotFoundException is thrown then the IdenityMap for that class name could not be found
updateChangeRecord(Object, Object, Object, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Either create a new change record or update the change record with the new value.
updateChangeRecord(Object, Object, Object, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Either create a new change record or update with the new value.
updateChangeRecord(Object, Object, Object, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Either create a new change record or update the change record with the new value.
updateChangeRecord(Object, Object, Object, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Either create a new change record or update with the new value.
updateChangeRecord(Object, Object, Object, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Either create a new change record or update the change record with the new value.
updateChangeRecord(Object, Object, Object, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Either create a new change record or update with the new value.
updateChangeRecord(Object, Object, Object, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Either create a new change record or update the change record with the new value.
updateChangeRecord(Object, Object, Object, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Either create a new change record or update the change record with the new value.
updateChangeRecordForAttribute(String, Object) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Used to update a changeRecord that is stored in the CHangeSet with a new value.
updateChangeRecordForAttribute(DatabaseMapping, Object, AbstractSession, Object) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Used to update a changeRecord that is stored in the CHangeSet with a new value.
updateChangeRecordForAttributeWithMappedObject(String, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
ADVANCED: Used to update a changeRecord that is stored in the CHangeSet with a new value.
updateChangeRecordForSelfMerge(ChangeRecord, Object, Object, UnitOfWorkChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Update a ChangeRecord to replace the ChangeSet for the old entity with the changeSet for the new Entity.
updateChangeRecordForSelfMerge(ChangeRecord, Object, Object, UnitOfWorkChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Update a ChangeRecord to replace the ChangeSet for the old entity with the changeSet for the new Entity.
updateChangeRecordForSelfMerge(ChangeRecord, Object, Object, UnitOfWorkChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Update a ChangeRecord to replace the ChangeSet for the old entity with the changeSet for the new Entity.
updateChangeRecordForSelfMerge(ChangeRecord, Object, Object, ForeignReferenceMapping, UnitOfWorkChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Update a ChangeRecord to replace the ChangeSet for the old entity with the changeSet for the new Entity.
updateChangeRecordForSelfMerge(ChangeRecord, Object, Object, ForeignReferenceMapping, UnitOfWorkChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.queries.ListContainerPolicy
INTERNAL: Update a ChangeRecord to replace the ChangeSet for the old entity with the changeSet for the new Entity.
updateChangeRecordForSelfMerge(ChangeRecord, Object, Object, ForeignReferenceMapping, UnitOfWorkChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Update a ChangeRecord to replace the ChangeSet for the old entity with the changeSet for the new Entity.
updateChangeRecordWithNewValue(Object) - Method in class org.eclipse.persistence.internal.sessions.ChangeRecord
INTERNAL: used by the record to update the new value ignores the value in the default implementation
updateChangeRecordWithNewValue(Object) - Method in class org.eclipse.persistence.internal.sessions.DirectToFieldChangeRecord
INTERNAL: used by the record to update the new value ignores the value in the default implementation
updateChangeTrackersIfRequired(Object, ObjectChangeSet, UnitOfWorkImpl, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: This method is used internally to update the tracked objects if required
updateChangeTrackersIfRequired(Object, ObjectChangeSet, UnitOfWorkImpl, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This method is used internally to update the tracked objects if required
updateClassTypes(Map<String, Class<?>>) - Method in interface org.eclipse.persistence.internal.databaseaccess.DatabaseJsonPlatform
Update the mapping of class types to database types for the schema framework.
updateCollectionChangeRecord(CollectionChangeEvent, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Add or removes a new value and its change set to the collection change record based on the event passed in.
updateCollectionChangeRecord(CollectionChangeEvent, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Add or removes a new value and its change set to the collection change record based on the event passed in.
updateCollectionChangeRecord(CollectionChangeEvent, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Add or removes a new value and its change set to the collection change record based on the event passed in.
updateCollectionChangeRecord(CollectionChangeEvent, ObjectChangeSet, UnitOfWorkImpl) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Add or removes a new value and its change set to the collection change record based on the event passed in.
updateDeploymentTimeData() - Method in class org.eclipse.persistence.services.RuntimeServices
INTERNAL: Define the deployment time data associated with logging and profiling
updateDerivedIds(Object, ClassDescriptor) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: On persist and flush operations we must update any derived id fields.
updateFieldTypes(Hashtable<Class<?>, FieldTypeDefinition>) - Method in interface org.eclipse.persistence.internal.databaseaccess.DatabaseJsonPlatform
Update the mapping of database types to class types for the schema framework.
updateForeignKeyFieldAfterInsert() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Update the foreign key fields when resolving a bi-directonal reference in a UOW.
updateForeignKeyFieldAfterInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Update the foreign key fields when resolving a bi-directional reference in a UOW.
updateForeignKeyFieldAfterInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Update the foreign key fields when resolving a bi-directonal reference in a UOW.
updateForeignKeyFieldAfterInsert(WriteObjectQuery) - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Update the foreign key fields when resolving a bi-directional reference in a UOW.
updateForeignKeyFieldBeforeDelete() - Method in class org.eclipse.persistence.internal.queries.CallQueryMechanism
Update the foreign key fields to null when resolving a deletion cycle.
updateForeignKeyFieldBeforeDelete() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Update the foreign key fields to null when resolving a deletion cycle.
updateForeignReferenceRemove(Object) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkQueryValueHolder
INTERNAL: Here we now must check for bi-directional relationship.
updateForeignReferenceSet(Object, Object) - Method in class org.eclipse.persistence.internal.indirection.UnitOfWorkQueryValueHolder
INTERNAL: Here we now must check for bi-directional relationship.
updateInsertableAndUpdatableFields(DatabaseField) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Add the field to the updatable and/or insertable list.
updateJoinedMappingIndexesForMapKey(Map<DatabaseMapping, Object>, int) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Update the joined mapping indices This method is a no-op, but will be overridden by subclasses
updateJoinedMappingIndexesForMapKey(Map<DatabaseMapping, Object>, int) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: Update the joined mapping indices Adds the key mapping and it's index to the list of joined mappings.
updateJoinedMappingIndexesForMapKey(Map<DatabaseMapping, Object>, int) - Method in class org.eclipse.persistence.internal.queries.OrderedListContainerPolicy
INTERNAL: Add the index field count.
updateListenerForSelfMerge(ObjectChangeListener, ForeignReferenceMapping, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.descriptors.changetracking.AttributeChangeTrackingPolicy
INTERNAL: In cases where a relationship with detached or new entities is merged into itself previous changes may have been recorded for the detached/new entity that need to be updated.
updateListenerForSelfMerge(ObjectChangeListener, ForeignReferenceMapping, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: In cases where a relationship with detached or new entities is merged into itself previous changes may have been recorded for the detached/new entity that need to be updated.
updateListenerForSelfMerge(ObjectChangeListener, ForeignReferenceMapping, Object, Object, UnitOfWorkImpl) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: In cases where a relationship with detached or new entities is merged into itself previous changes may have been recorded for the detached/new entity that need to be updated.
updateListOrderFieldQuery - Variable in class org.eclipse.persistence.mappings.AggregateCollectionMapping
These queries used to update listOrderField
updateMaxSize(int) - Method in class org.eclipse.persistence.internal.identitymaps.AbstractIdentityMap
This method will be used to update the max cache size, any objects exceeding the max cache size will be remove from the cache.
updateMaxSize(int) - Method in class org.eclipse.persistence.internal.identitymaps.CacheIdentityMap
INTERNAL: This method will be used to update the max cache size, any objects exceeding the max cache size will be remove from the cache.
updateMaxSize(int) - Method in class org.eclipse.persistence.internal.identitymaps.HardCacheWeakIdentityMap
This method will be used to update the max cache size.
updateMaxSize(int) - Method in interface org.eclipse.persistence.internal.identitymaps.IdentityMap
This method will be used to update the max cache size, any objects exceeding the max cache size will be remove from the cache.
updateMaxSize(int) - Method in class org.eclipse.persistence.sessions.interceptors.CacheInterceptor
This method will be used to update the max cache size, any objects exceeding the max cache size will be remove from the cache.
updateNamespaces(QName, MarshalRecord, Field) - Method in class org.eclipse.persistence.internal.oxm.MappingNodeValue
 
updateNestedAggregateMappings(ClassDescriptor, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Called in case nestedAggregateToSourceFieldNames != null Updates AggregateObjectMappings and AggregateCollectionMappings of the reference descriptor.
updateObject() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Update an object.
updateObject() - Method in class org.eclipse.persistence.internal.queries.DatasourceCallQueryMechanism
Update the object.
updateObject() - Method in class org.eclipse.persistence.internal.queries.StatementQueryMechanism
Update the object
updateObject(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Update the object and all of its privately owned parts in the database.
updateObject(Object) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Update the object and all of its privately owned parts in the database.
updateObject(Node) - Method in class org.eclipse.persistence.oxm.XMLBinder
Updates the object associated with the provided node to reflect any changed made to that node.
updateObjectAndRowWithReturnRow(Collection, boolean) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
 
updateObjectAndRowWithSequenceNumber() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Update the object's primary key by fetching a new sequence number from the accessor.
updateObjectAndRowWithSequenceNumber(DatabaseCall) - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Update the object's primary key by getting the generated keys from the call If there are no generated keys or the value is NULL, then default back to the DatabaseQueryMechanism.updateObjectAndRowWithSequenceNumber()
updateObjectForWrite() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Update the object.
updateObjectForWriteWithChangeSet() - Method in class org.eclipse.persistence.internal.queries.DatabaseQueryMechanism
Update the object.
UpdateObjectQuery - Class in org.eclipse.persistence.queries
Purpose: Used for updating existing objects into the database.
UpdateObjectQuery() - Constructor for class org.eclipse.persistence.queries.UpdateObjectQuery
PUBLIC: Default constructor.
UpdateObjectQuery(Object) - Constructor for class org.eclipse.persistence.queries.UpdateObjectQuery
PUBLIC: Create an update query with the object being updated.
UpdateObjectQuery(Call) - Constructor for class org.eclipse.persistence.queries.UpdateObjectQuery
PUBLIC: Create an update query with the custom call.
updateObjectWithWriteValue(ObjectLevelModifyQuery, Object) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
 
updatePoolSize(String, int, int) - Method in interface org.eclipse.persistence.services.mbean.MBeanRuntimeServicesMBean
This method allows the client to set the pool size for a particular pool, based on the pool name
updatePoolSize(String, int, int) - Method in class org.eclipse.persistence.services.RuntimeServices
This method allows the client to set the pool size for a particular pool, based on the pool name
updateProfile(String, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Updates the value of SessionProfiler state
updateProfile(String, Object) - Method in interface org.eclipse.persistence.sessions.coordination.CommandProcessor
Log the profile event.
updatePropertyParameterExpression(Expression) - Method in class org.eclipse.persistence.descriptors.DescriptorQueryManager
INTERNAL: This method will walk the given expression and mark any parameter expressions as property expressions.
updateQuery - Variable in class org.eclipse.persistence.descriptors.DescriptorQueryManager
 
updateQuery - Variable in class org.eclipse.persistence.sequencing.QuerySequence
 
updateReferences(UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.AggregateChangeRecord
INTERNAL: This method will be used to update the objectsChangeSets references If this is an aggregate change set then there is no need to update the reference as the ChangeSet has no identity outside of this record Check to see if it exists here already to prevent us from creating a little extra garbage.
updateReferences(UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.AggregateCollectionChangeRecord
INTERNAL: This method will be used to update the objectsChangeSets references If this is an aggregate change set then there is no need to update the reference as the ChangeSet has no identity outside of this record Check to see if it exists here already to prevent us from creating a little extra garbage.
updateReferences(UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.ChangeRecord
INTERNAL: This method will be used to update the objectsChangeSets references
updateReferences(UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.CollectionChangeRecord
This method will be used to update the objectsChangeSets references.
updateReferences(UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.DirectCollectionChangeRecord
This method will be used to update the objectsChangeSets references
updateReferences(UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.DirectMapChangeRecord
This method will be used to update the objectsChangeSets references.
updateReferences(UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.DirectToFieldChangeRecord
INTERNAL: This method will be used to update the objectsChangeSets references
updateReferences(UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: This method will be used when merging changesets into other changesets.
updateReferences(UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.ObjectReferenceChangeRecord
INTERNAL: This method will be used to update the objectsChangeSets references
updateReferences(UnitOfWorkChangeSet, UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.TransformationMappingChangeRecord
INTERNAL: This method will be used to update the objectsChangeSets references There is nothing to do for this mapping type as there are no object references
updateRowAndObjectForUpdate(ObjectLevelModifyQuery, Object) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Nothing to do because all updates are handled by the application
updateRowAndObjectForUpdate(ObjectLevelModifyQuery, Object) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: This method updates the modify row, and the domain object with the new lock value.
updateRowAndObjectForUpdate(ObjectLevelModifyQuery, Object) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
INTERNAL: This method should update the translation row, the modify row and the domain object with th lock value.
updateStandardConnectionPools() - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: Updates standard connection pools.
updateStatementsNotSpecified() - Static method in exception org.eclipse.persistence.exceptions.QueryException
 
updateString1 - Variable in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
updateString2 - Variable in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
updateStringBufferSize - Variable in class org.eclipse.persistence.sequencing.UnaryTableSequence
 
updateTable(DatabaseTable) - Method in class org.eclipse.persistence.descriptors.SchemaPerMultitenantPolicy
 
updateTable(DatabaseTable) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL: This method will update the table by cloning it and setting a new name on it.
updateTablePerTenantDescriptors(String, Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Set the table per tenant.
updateTables() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
INTERNAL: set the tables on the child descriptor overridden in org.eclipse.persistence.internal.oxm.QNameInheritancePolicy
updateTables() - Method in class org.eclipse.persistence.internal.oxm.QNameInheritancePolicy
Override to control order of uniqueTables, child tablenames should be first since getDefaultRootElement on an XMLDescriptor will return the first table.
updateTargetForeignKeyPostUpdateSource_ObjectAdded(ObjectLevelModifyQuery, Object, Map) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Update target foreign key after a target object was added to the source.
updateTargetForeignKeyPostUpdateSource_ObjectRemoved(ObjectLevelModifyQuery, Object) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Update target foreign key after a target object was removed from the source.
updateTargetRowPostInsertSource(WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Update target foreign keys after a new source was inserted.
updateTargetRowPreDeleteSource(ObjectLevelModifyQuery) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Update target foreign key after a target object was removed from the source.
updateUOWChangeSet() - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
updateValueInObject(Object, Object, Object) - Method in class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
Coordinate the valueholder for this mapping with the underlying property by calling the initial setter method.
updateWithChanges(Object, ObjectChangeSet, UnitOfWorkImpl, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.changetracking.AttributeChangeTrackingPolicy
INTERNAL: Clear the change set in the change event listener.
updateWithChanges(Object, ObjectChangeSet, UnitOfWorkImpl, ClassDescriptor) - Method in class org.eclipse.persistence.descriptors.changetracking.DeferredChangeDetectionPolicy
INTERNAL: Clear changes in the ChangeListener of the clone
updateWithChanges(Object, ObjectChangeSet, UnitOfWorkImpl, ClassDescriptor) - Method in interface org.eclipse.persistence.descriptors.changetracking.ObjectChangePolicy
INTERNAL: This method is used internally to rest the policies back to original state This is used when the clones are to be reused.
updateWriteLockValue(Object, Class<?>, Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Update the write lock value in the cache.
updateWriteLockValue(Object, Class<?>, Object) - Method in class org.eclipse.persistence.internal.sessions.IsolatedClientSessionIdentityMapAccessor
ADVANCED: Update the write lock value in the identity map.
updateWriteLockValue(Object, Class<?>, Object) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Updates the write lock value in the cache for the Object with same primary key as the given Object.
updateWriteLockValue(Object, Object) - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
ADVANCED: Update the write lock value in the cache.
updateWriteLockValue(Object, Object) - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: Updates the write lock value in the identity map for cache key of the primary key the given Object.
updateWriteLockValueForWrite(ObjectLevelModifyQuery, Object) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Update the row, object and change set with the version value.
updateXML(Object) - Method in class org.eclipse.persistence.oxm.XMLBinder
This method will update the cached XML node for the provided object.
updateXML(Object, Node) - Method in class org.eclipse.persistence.oxm.XMLBinder
 
UPPERCASE_COLUMN_NAMES - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.jpa.uppercase-column-names" property configures JPA processing to uppercase all column name definitions.
URI - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
URL_Class - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
usage() - Static method in class org.eclipse.persistence.tools.PackageRenamer
 
USE_DISTINCT - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
USE_LOCAL_TIMESTAMP - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.locking.timestamp.local" property defines if locking policies should default to local time(true) or server time(false).
USE_SESSION_CACHE_AFTER_TRANSACTION - Static variable in class org.eclipse.persistence.descriptors.CachePolicy
 
USE_SESSION_CACHE_AFTER_TRANSACTION - Static variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
USE_SINGLE_THREADED_NOTIFICATION_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
useAccess() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the database platform to be Access.
useAllFieldsLocking() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the locking policy an all fields locking policy.
useBasicIndirection() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Indirection means that a ValueHolder will be put in-between the attribute and the real object.
useBasicIndirection() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Indirection means that a ValueHolder will be put in-between the attribute and the real object.
useBatchReading() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Indicates whether the referenced object should always be batch read on read all queries.
useBatchWriting() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use batch writing.
useByteArrayBinding() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use parameter binding for large binary data.
useCacheIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the cache identity map.
useCacheIdentityMap() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Switch all descriptors to use the cache identity map.
useCacheIdentityMap(int) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Switch all descriptors to use the cache identity map the size.
useChangedFieldsLocking() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the locking policy a changed fields locking policy.
useClassNameAsIndicator() - Method in class org.eclipse.persistence.descriptors.InheritancePolicy
PUBLIC: Set the descriptor to use the classes full name as the indicator.
useCloneCopyPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Specifies that the creation of clones within a unit of work is done by sending the #clone() method to the original object.
useCloneCopyPolicy(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Specifies that the creation of clones within a unit of work is done by sending the cloneMethodName method to the original object.
useCloudscape() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the database platform to be Cloudscape.
useCloudscapeDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the Cloudscape JDBC driver.
useCollectionClass(Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyCollectionMapping
Configure the mapping to use an instance of the specified container class to hold the target objects.
useCollectionClass(Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeCollectionMapping
Configure the mapping to use an instance of the specified container class to hold the target objects.
useCollectionClass(Class<?>) - Method in interface org.eclipse.persistence.internal.oxm.mappings.InverseReferenceMapping
 
useCollectionClass(Class<?>) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useCollectionClass(Class<?>) - Method in interface org.eclipse.persistence.mappings.ContainerMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useCollectionClass(Class<?>) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useCollectionClass(Class<?>) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the nested objects.
useCollectionClass(Class<?>) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useCollectionClass(Class<?>) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
useCollectionClass(Class<?>) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useCollectionClass(Class<?>) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
useCollectionClass(Class<?>) - Method in class org.eclipse.persistence.queries.DataReadQuery
PUBLIC: Configure the query to use an instance of the specified container class to hold the target objects.
useCollectionClass(Class<?>) - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useCollectionClassName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.BinaryDataCollectionMapping
 
useCollectionClassName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.ChoiceCollectionMapping
 
useCollectionClassName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.CollectionReferenceMapping
 
useCollectionClassName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.CompositeCollectionMapping
 
useCollectionClassName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
 
useCollectionClassName(String) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Used to set the collection class by name.
useCollectionClassName(String) - Method in interface org.eclipse.persistence.mappings.ContainerMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useCollectionClassName(String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
 
useCollectionClassName(String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Used to set the collection class by name.
useCollectionClassName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
useCollectionClassName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
useCollectionClassName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
 
useCollectionClassName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
useCollectionClassName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
useContainerIndirection(Class<?>) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Indirection means that a IndirectContainer (wrapping a ValueHolder) will be put in-between the attribute and the real object.
useContainerIndirection(Class<?>) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Indirection means that a IndirectContainer (wrapping a ValueHolder) will be put in-between the attribute and the real object.
useCursoredStream() - Method in class org.eclipse.persistence.queries.DataReadQuery
PUBLIC: Use a CursoredStream as the result collection.
useCursoredStream() - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Use a CursoredStream as the result collection.
useCursoredStream(int, int) - Method in class org.eclipse.persistence.queries.DataReadQuery
PUBLIC: Use a CursoredStream as the result collection.
useCursoredStream(int, int) - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Use a CursoredStream as the result collection.
useCursoredStream(int, int, ValueReadQuery) - Method in class org.eclipse.persistence.queries.DataReadQuery
PUBLIC: Use a CursoredStream as the result collection.
useCursoredStream(int, int, ValueReadQuery) - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Use a CursoredStream as the result collection.
useCursorOutputResultSet(String, String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
INTERNAL: Add the unnamed output cursor to return the result.
useCustomSQLCursorOutputAsResultSet(String) - Method in class org.eclipse.persistence.queries.SQLCall
PUBLIC: This method should only be used with custom SQL: Used for Oracle result sets through procedures.
useDatabaseTime() - Method in class org.eclipse.persistence.history.HistoryPolicy
Answers if the Timestamp used in maintaining history should be the current time according to the database.
useDataSource(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Specify the J2EE DataSource name to connect to.
useDB2() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the database platform to be DB2.
useDB2JDBCDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the IBM DB2 native client interface.
useDB2NetJDBCDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the IBM DB2 thin JDBC driver.
useDBase() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the database platform to be DBase.
useDefaultConstructorInstantiationPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Use the default constructor to create new instances of objects built from the database.
useDefaultConstructorInstantiationPolicy() - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
useDefaultDriverConnect() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Connect to the JDBC driver via DriverManager.
useDefaultDriverConnect(String, String, String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Connect to the JDBC driver via DriverManager.
useDelimiters - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
 
useDelimiters - Variable in class org.eclipse.persistence.internal.helper.DatabaseTable
 
useDerby() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
 
UseDescriptorSetting - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
useDescriptorsToValidateInheritedObjects - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
useDirectDriverConnect() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Some JDBC drivers don't support connecting correctly (via DriverManager), but do support connecting incorrectly (e.g.
useDirectDriverConnect(String, String, String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Some JDBC drivers don't support connecting correctly (via DriverManager), but do support connecting incorrectly (e.g.
useDistinct() - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
ADVANCED: If a distinct has been set the DISTINCT clause will be printed.
useDistinct() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
ADVANCED: If a distinct has been set the DISTINCT clause will be printed.
UseEntityDefault - Static variable in class org.eclipse.persistence.config.CacheUsage
By default the descriptor default is used, which is to not check the cache first.
useExclusiveReadConnectionPool(int, int) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Sets the read connection pool to be a separate exclusive ConnectionPool with the minimum and maximum number of connections.
useExclusiveReadConnectionPool(int, int) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Configure the read connection pool.
useExclusiveReadConnectionPool(int, int, int) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Sets the read connection pool to be a separate exclusive ConnectionPool with the initial, minimum and maximum number of connections.
useExclusiveReadConnectionPool(int, int, int) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Configure the read connection pool.
useExternalConnectionPooling() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use external connection pooling, such as WebLogic's JTS driver.
useExternalConnectionPooling() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Use external connection pooling.
useExternalReadConnectionPool() - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Sets the read connection pool to be an ExternalConnectionPool.
useExternalReadConnectionPool() - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Configure the read connection pool.
useExternalTransactionController() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use an external transaction controller such as a JTS service
useExternalTransactionController() - Method in class org.eclipse.persistence.sessions.DatasourceLogin
PUBLIC: Use an external transaction controller such as a JTS service
useFactoryInstantiationPolicy(Class<?>, String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Use an object factory to create new instances of objects built from the database.
useFactoryInstantiationPolicy(Class<?>, String) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
useFactoryInstantiationPolicy(Class<?>, String, String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Use an object factory to create new instances of objects built from the database.
useFactoryInstantiationPolicy(Class<?>, String, String) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
useFactoryInstantiationPolicy(Object, String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Use an object factory to create new instances of objects built from the database.
useFactoryInstantiationPolicy(Object, String) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
useFactoryInstantiationPolicy(String, String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the factory class name, used by the MW.
useFactoryInstantiationPolicy(String, String) - Method in class org.eclipse.persistence.internal.core.descriptors.CoreInstantiationPolicy
 
useFactoryInstantiationPolicy(String, String) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
useFactoryInstantiationPolicy(String, String, String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Set the factory class name, used by the MW.
useFactoryInstantiationPolicy(String, String, String) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
useFullCache() - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Set the type of the cache used for the query results to a FullIdentityMap.
useFullIdentityMap() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Set the class of identity map to be the full identity map.
useFullIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the full identity map.
useFullIdentityMap() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Switch all descriptors to use the full identity map.
useFullIdentityMap(int) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Switch all descriptors to use the full identity map with initial cache size.
useHardCacheWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Set the class of identity map to be the hard cache weak identity map.
useHardCacheWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the hard cache weak identity map.
useHSQL() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the HSQL JDBC driver.
useHSQLDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the HSQL JDBC driver.
useIndexedRecordFormat() - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Configure the data format to use indexed records.
useIndirection() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Indirection means that a ValueHolder will be put in-between the attribute and the real object.
useINetSQLServerDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the i-net SQL Server JDBC driver.
useInformix() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the database platform to be Informix.
useInnerJoinFetch() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Specify this relationship to always be join fetched using an INNER join.
useInstantiationCopyPolicy() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Specifies that the creation of clones within a unit of work is done by building a new instance using the technique indicated by the descriptor's instantiation policy (which by default is to use the the default constructor).
useIntersolvSequeLinkDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the Intersolv/Merant SequeLink JDBC driver.
useJConnect50Driver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the Sybase JConnect JDBC driver.
useJConnectDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the Sybase JConnect JDBC driver.
useJDBC() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the database platform to be JDBC.
useJDBCBatchWriting() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink support batch writing in both JDK 1.1 abd JDK 1.2.
useJDBCConnectDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the Borland JDBCConnect JDBC driver.
useJDBCConnectRemoteDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the Borland JDBCConnect JDBC driver.
useJDBCODBCBridge() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: User the Sun/Merant JDBC-ODBC bridge driver.
useJDBCStoredProcedureSyntax - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
useJDBCStoredProcedureSyntax() - Method in class org.eclipse.persistence.platform.database.OraclePlatform
Return true if JDBC syntax should be used for stored procedure calls.
useJDBCStoredProcedureSyntax() - Method in class org.eclipse.persistence.platform.database.SybasePlatform
Return true if this platform is to use the JDBC supported syntax for executing stored procedures.
useJsonTypeAttributeName() - Method in class org.eclipse.persistence.internal.oxm.JsonTypeConfiguration
Override default type property name for JSON as MOXy type discriminator.
useJsonTypeCompatibility() - Method in class org.eclipse.persistence.internal.oxm.JsonTypeConfiguration
If we should treat unqualified type property in JSON as MOXy type discriminator.
useJTADataSource(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Specify the J2EE JTA enabled DataSource name to connect to.
useLazyConnection() - Method in class org.eclipse.persistence.sessions.server.ConnectionPolicy
PUBLIC: A lazy connection only acquires a physical connection when a transaction is started and releases the connection when the transaction completes.
useLazyInstantiation - Variable in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
IndirectList and IndirectSet can be configured not to instantiate the list from the database when you add and remove from them.
useListClassName(String) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Used to set the collection class by name.
useListClassName(String) - Method in interface org.eclipse.persistence.mappings.ContainerMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useListClassName(String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
 
useListClassName(String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Used to set the collection class by name.
useListClassName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
useListClassName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
 
useListClassName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
useLocalTime() - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
PUBLIC: set this policy to get the time from the local machine.
useLocalTime() - Method in class org.eclipse.persistence.history.HistoryPolicy
Answers if the Timestamp used in maintaining history should be System.currentTimeMillis();
useLRUCache() - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Set the type of the cache used for the query results to a CacheIdentityMap.
useMapClass(Class<?>) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useMapClass(Class<?>) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useMapClass(Class<?>) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
useMapClass(Class<?>, String) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useMapClass(Class<?>, String) - Method in interface org.eclipse.persistence.mappings.ContainerMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useMapClass(Class<?>, String) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
PUBLIC: It is illegal to use a Map as the container of a DirectCollectionMapping.
useMapClass(Class<?>, String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useMapClass(Class<?>, String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
PUBLIC: Mapping does not support Map containers.
useMapClass(Class<?>, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
useMapClass(Class<?>, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useMapClass(Class<?>, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
useMapClass(Class<?>, String) - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Configure the query to use an instance of the specified container class to hold the result objects.
useMapClass(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
useMapClassName(String) - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyAttributeMapping
INTERNAL: Indicates the name of the Map class to be used.
useMapClassName(String) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
INTERNAL: Indicates the name of the Map class to be used.
useMapClassName(String, String) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Not sure were this is used, MW?
useMapClassName(String, String) - Method in interface org.eclipse.persistence.mappings.ContainerMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useMapClassName(String, String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
 
useMapClassName(String, String) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
 
useMapClassName(String, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
useMapClassName(String, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useMapClassName(String, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
useMapClassName(String, String) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
useMappedRecordFormat() - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Configure the data format to use mapped records.
useMethodInstantiationPolicy(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Use the specified static method to create new instances of objects built from the database.
useMethodInstantiationPolicy(String) - Method in class org.eclipse.persistence.internal.descriptors.InstantiationPolicy
 
useMySQL() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the database platform to be MySQL.
useNamedCursorOutputAsResultSet() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLargument
 
useNamedCursorOutputAsResultSet(String) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
useNamedCursorOutputAsResultSet(String) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Used for Oracle result sets through procedures.
useNamedCursorOutputAsResultSet(String, DatabaseType) - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
PUBLIC: Add a named OUT cursor argument to the stored procedure.
useNationalCharacterVarying - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
If true, the platform should map String columns to a type that supports national characters.
useNativeSequencing() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use a sequence table or native sequencing to generate unique object IDs.
useNativeSQL() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use database-specific SQL grammar, as opposed to the JDBC standard grammar.
useNoIdentityMap() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Set the class of identity map to be the no identity map.
useNoIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the no identity map.
useNoIdentityMap() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Switch all descriptors to use no identity map.
useOracle() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the database platform to be Oracle.
useOracle7JDBCDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the Oracle 7.x native OCI JDBC driver.
useOracleJDBCDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the Oracle 8.x native OCI JDBC driver.
useOracleServerJDBCDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the Oracle server JDBC driver.
useOracleThinJDBCDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the Oracle thin JDBC driver.
useOuterJoinFetch() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Specify this relationship to always be join fetched using an OUTER join.
usePlatform(Platform) - Method in class org.eclipse.persistence.sessions.DatasourceLogin
ADVANCED: Set the database platform to be custom platform.
usePlatform(DatabasePlatform) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
ADVANCED: Set the database platform to be custom platform.
usePointBase() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the database platform to be PointBase.
usePointBaseDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the PointBase JDBC driver.
usePropertyAccessForWeaving() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Record that this descriptor uses property access.
useProxyIndirection() - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
PUBLIC: Set this mapping to use Proxy Indirection.
useProxyIndirection(Class<?>) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
PUBLIC: Set this mapping to use Proxy Indirection.
useProxyIndirection(Class<?>[]) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
PUBLIC: Set this mapping to use Proxy Indirection.
USER - Static variable in class org.eclipse.persistence.eis.EISConnectionSpec
 
UserDefinedTransportManagerConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.transport
INTERNAL:
UserDefinedTransportManagerConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.transport.UserDefinedTransportManagerConfig
 
useReadConnectionPool(int, int) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Sets the read connection pool to be a separate shared ConnectionPool with the minimum and maximum number of connections.
useReadConnectionPool(int, int) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Configure the read connection pool.
useReadConnectionPool(int, int, int) - Method in interface org.eclipse.persistence.sessions.server.Server
PUBLIC: Sets the read connection pool to be a separate shared ConnectionPool with the minimum and maximum number of connections.
useReadConnectionPool(int, int, int) - Method in class org.eclipse.persistence.sessions.server.ServerSession
PUBLIC: Configure the read connection pool.
useRemoteCacheIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the cache identity map.
useRemoteFullIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the full identity map.
useRemoteHardCacheWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the hard cache weak identity map.
useRemoteNoIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the no identity map.
useRemoteSoftCacheWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the soft cache weak identity map.
useRemoteSoftIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the soft identity map.
useRemoteWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the weak identity map.
userJavaTypes - Variable in class org.eclipse.persistence.oxm.XMLField
 
USERNAME_DEFAULT - Static variable in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
useRownumFiltering - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Some platforms allow a query's maxRows and FirstResult settings to be specified in SQL.
userXMLTypes - Variable in class org.eclipse.persistence.oxm.XMLField
 
usesBatchWriting - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Batch all write statements
usesBatchWriting() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
usesBinding - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
 
usesBinding - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
The call may specify that all of its parameters should/shouldn't be bound.
usesBinding() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL Indicates whether usesBinding has been set.
usesBinding(DatabasePlatform) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Determines if this call should bind all parameters.
usesBinding(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
Convenience method
usesByteArrayBinding - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Indicates that binding will be used for BLOB data.
usesByteArrayBinding() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
usesContextProperty(String) - Method in class org.eclipse.persistence.descriptors.TablePerMultitenantPolicy
INTERNAL: Return true if this policy accepts the given property.
useScrollableCursor() - Method in class org.eclipse.persistence.queries.DataReadQuery
PUBLIC: Use a ScrollableCursor as the result collection.
useScrollableCursor() - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Use a ScrollableCursor as the result collection.
useScrollableCursor(int) - Method in class org.eclipse.persistence.queries.DataReadQuery
PUBLIC: Use a ScrollableCursor as the result collection.
useScrollableCursor(int) - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Use a ScrollableCursor as the result collection.
useScrollableCursor(ScrollableCursorPolicy) - Method in class org.eclipse.persistence.queries.DataReadQuery
PUBLIC: Use a ScrollableCursor as the result collection.
useScrollableCursor(ScrollableCursorPolicy) - Method in class org.eclipse.persistence.queries.ReadAllQuery
PUBLIC: Use a ScrollableCursor as the result collection.
useSelectedFieldsLocking(Vector) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the locking policy a selected fields locking policy.
useServerTime() - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
PUBLIC: set this policy to get the time from the server.
usesExternalConnectionPooling - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
PERF: Cache connection pooling flag.
usesExternalConnectionPooling - Variable in class org.eclipse.persistence.sessions.DatasourceLogin
True if we use an external connection pool such as WebLogic's JTS driver
usesExternalConnectionPooling() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return whether the accessor uses external connection pooling.
usesExternalConnectionPooling() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return true if some external connection pool is in use.
usesExternalTransactionController - Variable in class org.eclipse.persistence.sessions.DatasourceLogin
True if we should use some external transaction service such as JTS.
usesExternalTransactionController() - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
Return whether the accessor uses an external transaction controller (e.g.
usesExternalTransactionController() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Return true if some external transaction service is controlling transactions.
usesFieldLocking() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return true if the receiver uses either all or changed fields for optimistic locking.
usesGroup - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
usesGroup() - Method in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
usesImplementorDescriptor() - Method in class org.eclipse.persistence.descriptors.InterfacePolicy
INTERNAL: Returns true if this descriptor should be ignored and the implementing descriptor should be used instead.
usesIndirection() - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return whether the indirection policy actually uses indirection.
usesIndirection() - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return whether the indirection policy actually uses indirection.
usesIndirection() - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
PUBLIC: Indirection means that some sort of indirection object will be put in-between the attribute and the real object.
usesIndirection() - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
PUBLIC: Indirection means that a ValueHolder will be put in-between the attribute and the real object.
usesJDBCBatchWriting - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Allow for our batch writing support to be used in JDK 1.2.
usesJDBCBatchWriting() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Some JDBC 2 drivers to not support batching, so this lets are own batching be used.
usesListOrderField() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Returns whether the mapping has listOrderField.
usesLocalTime - Variable in class org.eclipse.persistence.history.HistoryPolicy
 
usesLocalTime() - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
PUBLIC: Return true if policy uses local time.
usesLocatorForLOBWrite - Variable in class org.eclipse.persistence.platform.database.Oracle8Platform
Locator is required for Oracle thin driver to write LOB value exceeds the limits
usesNativeBatchWriting - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
bug 4241441: Allow custom batch writing to enable batching with optimistic locking.
usesNativeBatchWriting() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
usesNativeSQL - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Indicates that native SQL should be used for literal values instead of ODBC escape format Only used with Oracle, Sybase & DB2
usesNativeSQL() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
useSoftCache() - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Set the type of the cache used for the query results to a SoftIdentityMap.
useSoftCacheWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the soft cache weak identity map.
useSoftCacheWeakIdentityMap() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Switch all descriptors to use the soft cache weak identity map.
useSoftCacheWeakIdentityMap(int) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Switch all descriptors to use the soft cache weak identity map with soft cache size.
useSoftIdentityMap() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Set the class of identity map to be the soft identity map.
useSoftIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the soft identity map.
useSoftLRUCache() - Method in class org.eclipse.persistence.queries.QueryResultsCachePolicy
PUBLIC: Set the type of the cache used for the query results to a SoftCacheWeakIdentityMap.
usesOptimisticLocking - Variable in class org.eclipse.persistence.internal.databaseaccess.DynamicSQLBatchWritingMechanism
Records if this batch uses optimistic locking.
usesOptimisticLocking - Variable in class org.eclipse.persistence.queries.DeleteObjectQuery
Indicates whether the query should use optimistic locking.
usesOptimisticLocking() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if the receiver uses write (optimistic) locking.
usesOptimisticLocking() - Method in class org.eclipse.persistence.queries.DeleteObjectQuery
INTERNAL: Indicating whether the query should use optimistic locking.
usesOptimisticLocking() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Asks each descriptor if is uses optimistic locking.
useSortedSetClass(Class<?>, Comparator) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useSortedSetClassName(String) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Configure the mapping to use an instance of the specified container class name to hold the target objects.
useSortedSetClassName(String, String) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Configure the mapping to use an instance of the specified container class name to hold the target objects.
usesPartitions() - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: Some servers may support partitioning
usesPartitions() - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
 
usesPartitions() - Method in class org.eclipse.persistence.platform.server.wls.WebLogic_12_Platform
 
usesPlatformDefaultSequence() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
INTERNAL: Indicates whether defaultSequence is the same as platform default sequence.
usesPlatformDefaultSequence() - Method in interface org.eclipse.persistence.internal.databaseaccess.Platform
INTERNAL: Indicates whether defaultSequence is the same as platform default sequence.
usesPropertyAccessForWeaving() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Return whether this descriptor uses property access.
useSQLServer() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the database platform to be SQL Server.
usesResultSetAccessOptimization - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
PERF: Indicates whether the query is actually using ResultSet optimization.
usesResultSetAccessOptimization() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Return if the query uses ResultSet optimization.
usesResultSetAccessOptimization() - Method in class org.eclipse.persistence.queries.ObjectLevelReadQuery
INTERNAL: Return if the query uses ResultSet optimization.
usesSequenceNumbers() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if the receiver uses sequence numbers.
usesSequenceTable() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
usesSequencing() - Method in class org.eclipse.persistence.sessions.Project
INTERNAL: Asks each descriptor if is uses sequencing.
usesServerTime() - Method in class org.eclipse.persistence.descriptors.TimestampLockingPolicy
PUBLIC: Return true if policy uses server time.
usesSingleNode() - Method in interface org.eclipse.persistence.internal.oxm.mappings.CollectionReferenceMapping
For the purpose of XMLCollectionReferenceMappings, 'usesSingleNode' refers to the fact that the source key xpath fields should all be written as space-separated lists.
usesSingleNode() - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectCollectionMapping
Checks whether the mapping uses a single node.
usesSingleNode() - Method in interface org.eclipse.persistence.internal.oxm.mappings.Field
Checks whether the mapping uses a single node.
usesSingleNode() - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
PUBLIC: Checks whether the mapping uses a single node.
usesSingleNode() - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
INTERNAL: For the purpose of XMLCollectionReferenceMappings, 'usesSingleNode' refers to the fact that the source key xpath fields should all be written as space-separated lists.
usesSingleNode() - Method in class org.eclipse.persistence.oxm.XMLField
PUBLIC: Checks whether the mapping uses a single node.
usesStreamsForBinding - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Indicates that streams will be used to store BLOB data.
usesStreamsForBinding() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
usesStringBinding - Variable in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
Indicates that strings will above the stringBindingSize will be bound NOTE: does not work with ODBC
usesStringBinding() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
usesStringBinding() - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
usesTransparentIndirection() - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return whether the indirection policy uses transparent indirection.
usesTransparentIndirection() - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return whether the indirection policy uses transparent indirection.
useStreamsForBinding() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: EclipseLink can be configured to use streams to store large binary data.
useStringBinding() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Bind strings larger than 255 characters.
useStringBinding(int) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Bind strings that are larger than the specified size.
usesVersionLocking() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Return true if the receiver uses version optimistic locking.
usesXMLRoot() - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyCollectionMapping
 
usesXMLRoot() - Method in interface org.eclipse.persistence.internal.oxm.mappings.AnyObjectMapping
 
usesXMLRoot() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
usesXMLRoot() - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
useSybase() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the database platform to be Sybase.
useSymfoware() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the database platform to be Symfoware.
useTimestampLocking(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Use the Timestamps locking policy and storing the value in the cache key #see useVersionLocking(String)
useTimestampLocking(String, boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the locking policy to use timestamp version locking.
useTransparentCollection() - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: If transparent indirection is used, a special collection will be placed in the source object's attribute.
useTransparentList() - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: If transparent indirection is used, a special collection will be placed in the source object's attribute.
useTransparentMap() - Method in class org.eclipse.persistence.mappings.DirectMapMapping
PUBLIC: Configure the mapping to use an instance of the specified container class to hold the target objects.
useTransparentMap(String) - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: If transparent indirection is used, a special map will be placed in the source object's attribute.
useTransparentSet() - Method in class org.eclipse.persistence.mappings.CollectionMapping
PUBLIC: If transparent indirection is used, a special collection will be placed in the source object's attribute.
useUnicode - Variable in class org.eclipse.persistence.internal.codegen.CodeGenerator
 
useUniqueFieldAliases - Variable in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
Flag used to indicate field names should use unique aliases
useUnnamedCursorOutputAsResultSet() - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseCall
PUBLIC: Used for Oracle result sets through procedures.
useUnnamedCursorOutputAsResultSet() - Method in class org.eclipse.persistence.platform.database.oracle.plsql.PLSQLStoredProcedureCall
 
useUnnamedCursorOutputAsResultSet() - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Used for Oracle result sets through procedures.
useUnnamedCursorOutputAsResultSet(int) - Method in class org.eclipse.persistence.queries.StoredProcedureCall
PUBLIC: Used for Oracle result sets through procedures.
useUpperCaseForComparisons - Variable in class org.eclipse.persistence.internal.helper.DatabaseField
setting to true will cause getNameForComparisons to lazy initialize nameForComparisons using the value from getName().toUpperCase().
useUpperCaseForComparisons(boolean) - Method in class org.eclipse.persistence.internal.helper.DatabaseField
INTERNAL: Sets the useUpperCaseForComparisons flag which is used to force using the uppercase version of the field's name to determine field equality and its hashcode, but will still use the original name when writing/printing operations.
useVersionLocking(String) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Default to use the version locking policy and storing the value in the cache key #see useVersionLocking(String)
useVersionLocking(String, boolean) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the locking policy to use numeric version locking.
useWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.CachePolicy
PUBLIC: Set the class of identity map to be the weak identity map.
useWeakIdentityMap() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
PUBLIC: Set the class of identity map to be the weak identity map.
useWeakIdentityMap() - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Switch all descriptors to use the weak identity map.
useWeakIdentityMap(int) - Method in class org.eclipse.persistence.sessions.Project
PUBLIC: Switch all descriptors to use the weak identity map.
useWeavedIndirection(String, String, boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Configures the mapping to used weaved indirection.
useWebLogicDriverCursoredOutputCode() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set the prepare cursor code to what the WebLogic Oracle OCI JDBC driver expects.
useWebLogicJDBCConnectionPool(String) - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Set a WebLogic JDBC connection pool (a pool must be defined for the entity beans that are to be deployed)
useWebLogicOracleOCIDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the WebLogic Oracle OCI JDBC driver.
useWebLogicSQLServerDBLibDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the WebLogic SQL Server dblib JDBC driver.
useWebLogicSQLServerDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the WebLogic SQL Server JDBC driver.
useWebLogicSybaseDBLibDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the WebLogic Sybase dblib JDBC driver.
useWebLogicThinClientDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the WebLogic thin client JDBC driver.
useWebLogicThinDriver() - Method in class org.eclipse.persistence.sessions.DatabaseLogin
PUBLIC: Use the WebLogic thin JDBC driver.
useXMLRecordFormat() - Method in class org.eclipse.persistence.eis.EISDescriptor
PUBLIC: Configure the data format to use xml records.
useXsdTypesWithPrefix() - Method in class org.eclipse.persistence.internal.oxm.JsonTypeConfiguration
If there should be xsd prefix when using simple types, e.g.
UTILDATE - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
utilDateFromLong(Long) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a Date from a long This implementation is based on the java.sql.Date class, not java.util.Date.
utilDateFromSQLDate(Date) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a java.util.Date from a sql.date
utilDateFromTime(Time) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a java.util.Date from a sql.Time
utilDateFromTimestamp(Timestamp) - Static method in class org.eclipse.persistence.internal.helper.Helper
Answer a java.util.Date from a timestamp
UUID - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
UUID - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
UUIDConverter - Class in org.eclipse.persistence.mappings.converters
Default UUID field value to JDBC data type converter.
UUIDConverter() - Constructor for class org.eclipse.persistence.mappings.converters.UUIDConverter
Creates an instance of default UUID field value to JDBC data type converter.
UuidGenerator - Annotation Type in org.eclipse.persistence.annotations
Defines a primary key generator that may be referenced by name when a generator element is specified for the GeneratedValue annotation.
UuidGenerators - Annotation Type in org.eclipse.persistence.annotations
A UuidGenerators annotation allows the definition of multiple UuidGenerator.
uuidQuery - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourcePlatform
Store the query use to query the current server UUID.
UUIDSequence - Class in org.eclipse.persistence.sequencing
 
UUIDSequence() - Constructor for class org.eclipse.persistence.sequencing.UUIDSequence
 
UUIDSequence(String) - Constructor for class org.eclipse.persistence.sequencing.UUIDSequence
 

V

v1_1 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 1.1.
v1_2 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 1.2.
v1_3 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 1.3.
v1_4 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 1.4.
v1_5 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 1.5.
v1_6 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 1.6.
v1_7 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 1.7.
v1_8 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 1.8.
v10_0 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 10.
v11_0 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 11.
v12_0 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 12.
v13_0 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 13.
v14_0 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 14.
v9_0 - org.eclipse.persistence.internal.helper.JavaSEPlatform
Java SE 9.
val - Variable in enum org.eclipse.persistence.internal.databaseaccess.DatasourceCall.ParameterType
 
validate(Object) - Method in class org.eclipse.persistence.oxm.XMLValidator
Validate the given object.
validate(AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Validates the object builder.
validate(Element, XMLDescriptor, ErrorHandler) - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
Validates a document fragment against a complex type or element in the XML schema
VALIDATE_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
VALIDATE_EXISTENCE - Static variable in class org.eclipse.persistence.config.EntityManagerProperties
Configures if the existence of an object should be verified on persist(), otherwise it will assume to be new if not in the persistence context.
VALIDATE_EXISTENCE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.validate-existence" property configures if the existence of an object should be verified on persist(), otherwise it will assume to be new if not in the persistence context.
validateAfterInitialization(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Validate the entire post-initialization descriptor.
validateAfterInitialization(AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Allow for subclasses to perform validation.
validateAttributeOfInstantiatedObject(Object) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Verify that the value of the attribute within an instantiated object is of the appropriate type for the indirection policy.
validateAttributeOfInstantiatedObject(Object) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Verify that the value of the attribute within an instantiated object is of the appropriate type for the indirection policy.
validateAttributeOfInstantiatedObject(Object) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Verify that the value of the attribute within an instantiated object is of the appropriate type for the indirection policy.
validateAttributeOfInstantiatedObject(Object) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Verify that the value of the attribute within an instantiated object is of the appropriate type for the indirection policy.
validateAttributeOfInstantiatedObject(Object) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Verify that the value of the attribute within an instantiated object is of the appropriate type for the indirection policy.
validateBeforeInitialization(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Validate the entire pre-initialization descriptor.
validateBeforeInitialization(AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: To validate mappings declaration
validateBeforeInitialization(AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Allow for subclasses to perform validation.
validateBeforeInitialization(AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: To validate mappings declaration
validateBeforeInitialization(AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Allow for subclasses to perform validation.
validateBeforeInitialization(AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Validate mapping declaration
validateCache() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
ADVANCED: This can be used to help debugging an object identity problem.
validateCache() - Method in class org.eclipse.persistence.internal.sessions.IdentityMapAccessor
INTERNAL: This can be used to help debugging an object identity problem.
validateCache() - Method in interface org.eclipse.persistence.sessions.IdentityMapAccessor
ADVANCED: This can be used to help debugging an Object identity problem.
validateCache() - Method in interface org.eclipse.persistence.sessions.Session
ADVANCED: This can be used to help debugging an object identity problem.
validateContainerPolicy(IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Verify that the container policy is compatible with the indirection policy.
validateContainerPolicy(IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Verify that the container policy is compatible with the indirection policy.
validateDeclaredAttributeType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Verify that attributeType is correct for the indirection policy.
validateDeclaredAttributeType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Verify that attributeType is correct for the indirection policy.
validateDeclaredAttributeType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Verify that attributeType is correct for the indirection policy.
validateDeclaredAttributeType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Verify that attribute type is correct for the indirection policy.
validateDeclaredAttributeType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Verify that attributeType is correct for the indirection policy.
validateDeclaredAttributeTypeForCollection(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Verify that attributeType is an appropriate collection type for the indirection policy.
validateDeclaredAttributeTypeForCollection(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Verify that attributeType is an appropriate collection type for the indirection policy.
validateDelete(int, Object, DeleteObjectQuery) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Check the row count for lock failure.
validateDelete(int, Object, DeleteObjectQuery) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Check the row count for lock failure.
validateDelete(int, Object, DeleteObjectQuery) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
 
validateDocument(Document, URL, ErrorHandler) - Method in interface org.eclipse.persistence.platform.xml.XMLPlatform
Validate the document against the XML Schema
validateExample - Variable in class org.eclipse.persistence.queries.QueryByExamplePolicy
 
validateException(Exception) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
validateGetMethodReturnType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Verify that getter returnType is correct for the indirection policy.
validateGetMethodReturnType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Verify that getter returnType is correct for the indirection policy.
validateGetMethodReturnType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Verify that getter returnType is correct for the indirection policy.
validateGetMethodReturnType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Verify that the return type of the attribute's get method is correct for the indirection policy.
validateGetMethodReturnType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Verify that getter returnType is correct for the indirection policy.
validateGetMethodReturnTypeForCollection(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Verify that getter returnType is an appropriate collection type for the indirection policy.
validateGetMethodReturnTypeForCollection(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Verify that getter returnType is an appropriate collection type for the indirection policy.
validateMappingType(DatabaseMapping) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
 
validateMappingType(DatabaseMapping) - Method in class org.eclipse.persistence.eis.EISDescriptor
 
validateMappingType(DatabaseMapping) - Method in class org.eclipse.persistence.mappings.structures.ObjectRelationalDataTypeDescriptor
 
validateMappingType(DatabaseMapping) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
 
validateNode() - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Do any required validation for this node.
validateNode() - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
 
validateNode() - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
Do any required validation for this node.
validateNode() - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
Do any required validation for this node.
validateNode() - Method in class org.eclipse.persistence.internal.expressions.ManualQueryKeyExpression
Do any required validation for this node.
validateNode() - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
Do any required validation for this node.
validateNode() - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
Do any required validation for this node.
validateNode() - Method in class org.eclipse.persistence.internal.expressions.RelationExpression
Do any required validation for this node.
validateNode() - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
validateObjectSpace() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: This can be used to help debugging an object-space corruption.
validateObjectSpace() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: This can be used to help debugging an object-space corruption.
validateParameterValueAgainstMapping(Object, boolean) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL Validate the passed parameter against the local base mapping.
validateQuery(DatabaseQuery) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: This method will be used to update the query with any settings required For this session.
validateQuery(DatabaseQuery) - Method in class org.eclipse.persistence.sessions.server.ServerSession
INTERNAL: This method will be used to update the query with any settings required For this session.
validateRoot(Object) - Method in class org.eclipse.persistence.oxm.XMLValidator
Validate the given root object.
validateSetMethodParameterType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Verify that setter parameterType is correct for the indirection policy.
validateSetMethodParameterType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Verify that setter parameterType is correct for the indirection policy.
validateSetMethodParameterType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Verify that setter parameterType is correct for the indirection policy.
validateSetMethodParameterType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Verify that the parameter type of the attribute's set method is correct for the indirection policy.
validateSetMethodParameterType(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Verify that setter parameterType is correct for the indirection policy.
validateSetMethodParameterTypeForCollection(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Verify that setter parameterType is an appropriate collection type for the indirection policy.
validateSetMethodParameterTypeForCollection(Class<?>, IntegrityChecker) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Verify that setter parameterType is an appropriate collection type for the indirection policy.
validateUpdate(int, Object, WriteObjectQuery) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: Check the row count for lock failure.
validateUpdate(int, Object, WriteObjectQuery) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: Check the row count for lock failure.
validateUpdate(int, Object, WriteObjectQuery) - Method in interface org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy
 
validatingContentHandler - Variable in class org.eclipse.persistence.internal.oxm.record.XMLReader
 
ValidatingContentHandler(ValidatorHandler) - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLReader.ValidatingContentHandler
 
ValidatingMarshalRecord - Class in org.eclipse.persistence.oxm.record
 
ValidatingMarshalRecord(MarshalRecord, XMLMarshaller) - Constructor for class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
ValidatingMarshalRecord.MarshalSAXParseException - Exception in org.eclipse.persistence.oxm.record
 
validation() - Method in annotation type org.eclipse.persistence.annotations.PrimaryKey
(Optional) Configures what id validation is done.
VALIDATION_GROUP_PRE_PERSIST - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.validation.group.pre-persist" property specifies the name of the validator groups to execute for preUpdate event.
VALIDATION_GROUP_PRE_REMOVE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.validation.group.pre-remove" property specifies the name of the validator groups to execute for preRemove event.
VALIDATION_GROUP_PRE_UPDATE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.validation.group.pre-update" property specifies the name of the validator groups to execute for preUpdate event.
VALIDATION_MODE - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.validation.mode" property specifies whether the automatic lifecycle event validation is in effect.
VALIDATION_ONLY_PROPERTY - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.validation-only" property validates deployment which includes initializing descriptors but does not connect (no login to the database).
validationAfterDescriptorInitialization(AbstractSession) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
INTERNAL:
ValidationException - Exception in org.eclipse.persistence.exceptions
Purpose: This exception is used if incorrect state or method arguments are detected in a general TopLink object.
ValidationException() - Constructor for exception org.eclipse.persistence.exceptions.ValidationException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
ValidationException(String) - Constructor for exception org.eclipse.persistence.exceptions.ValidationException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
ValidationException(String, Throwable) - Constructor for exception org.eclipse.persistence.exceptions.ValidationException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
ValidationExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for ValidationException messages.
ValidationExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.ValidationExceptionResource
Default constructor.
validationLevel - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
The amount of validation can be configured.
VALIDATOR_FACTORY - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "jakarta.persistence.validation.factory" property specifies an instance of jakarta.validation.ValidatorFactory used by EclipseLink to perform Automatic Validation upon Lifecycle Events.
validTypeName() - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the type that is appropriate for the indirection policy.
value - Variable in class org.eclipse.persistence.indirection.ValueHolder
Stores the wrapped object.
value - Variable in class org.eclipse.persistence.internal.expressions.ConstantExpression
 
value - Variable in class org.eclipse.persistence.internal.expressions.LiteralExpression
 
value - Variable in class org.eclipse.persistence.internal.indirection.DatabaseValueHolder
Stores the object after it is read from the database.
value - Variable in class org.eclipse.persistence.mappings.Association
 
value - Variable in class org.eclipse.persistence.mappings.transformers.ConstantTransformer
 
value() - Method in annotation type org.eclipse.persistence.annotations.AdditionalCriteria
(Required) The JPQL fragment to use as the additional criteria.
value() - Method in annotation type org.eclipse.persistence.annotations.BatchFetch
(Optional) The type of batch-fetch to use.
value() - Method in annotation type org.eclipse.persistence.annotations.CacheIndexes
 
value() - Method in annotation type org.eclipse.persistence.annotations.CacheInterceptor
The Class that will be used to intercept EclipseLink's cache access.
value() - Method in annotation type org.eclipse.persistence.annotations.ChangeTracking
(Optional) The type of change tracking to use.
value() - Method in annotation type org.eclipse.persistence.annotations.ClassExtractor
(Required) Defines the name of the class extractor that should be applied to this entity's descriptor.
value() - Method in annotation type org.eclipse.persistence.annotations.CompositeMember
The name of a target composite member persistence unit to which element table belongs (if differs from source composite member persistence unit)
value() - Method in annotation type org.eclipse.persistence.annotations.Convert
(Optional) The name of the converter to be used.
value() - Method in annotation type org.eclipse.persistence.annotations.Converters
(Required) An array of converter.
value() - Method in annotation type org.eclipse.persistence.annotations.CopyPolicy
(Required) This defines the class of the copy policy.
value() - Method in annotation type org.eclipse.persistence.annotations.Customizer
(Required) Defines the name of the descriptor customizer that should be applied to this entity's descriptor.
value() - Method in annotation type org.eclipse.persistence.annotations.DiscriminatorClass
(Required) The class to the instantiated with the given discriminator.
value() - Method in annotation type org.eclipse.persistence.annotations.ExistenceChecking
(Optional) Set the existence check for determining if an insert or update should occur for an object.
value() - Method in annotation type org.eclipse.persistence.annotations.FetchGroups
(Required) An array of fetch group.
value() - Method in annotation type org.eclipse.persistence.annotations.Indexes
 
value() - Method in annotation type org.eclipse.persistence.annotations.JoinFetch
(Optional) The type of join-fetch to use.
value() - Method in annotation type org.eclipse.persistence.annotations.MapKeyConvert
(Optional) The name of the converter to be used.
value() - Method in annotation type org.eclipse.persistence.annotations.Multitenant
(Optional) Specify the multi-tenant strategy to use.
value() - Method in annotation type org.eclipse.persistence.annotations.Mutable
(Optional) Set the mapping to be mutable, or not mutable.
value() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredFunctionQueries
(Required) An array of named stored procedure query.
value() - Method in annotation type org.eclipse.persistence.annotations.NamedStoredProcedureQueries
(Required) An array of named stored procedure query.
value() - Method in annotation type org.eclipse.persistence.annotations.ObjectTypeConverters
(Required) An array of object type converter.
value() - Method in annotation type org.eclipse.persistence.annotations.OrderCorrection
 
value() - Method in annotation type org.eclipse.persistence.annotations.Partitioned
(Required) name of partitioning policy to use.
value() - Method in annotation type org.eclipse.persistence.annotations.Properties
 
value() - Method in annotation type org.eclipse.persistence.annotations.Property
String representation of Property value, converted to an instance of valueType.
value() - Method in annotation type org.eclipse.persistence.annotations.SerializedConverters
(Required) An array of type converter.
value() - Method in annotation type org.eclipse.persistence.annotations.SerializedObject
The Class that implements org.eclipse.persistence.descriptors.SerializedObjectPolicy interface.
value() - Method in annotation type org.eclipse.persistence.annotations.StructConverters
(Required) An array of struct converter.
value() - Method in annotation type org.eclipse.persistence.annotations.TenantDiscriminatorColumns
(Required) One or more TenantDiscriminatorColumn annotations.
value() - Method in annotation type org.eclipse.persistence.annotations.TypeConverters
(Required) An array of type converter.
value() - Method in annotation type org.eclipse.persistence.annotations.UuidGenerators
(Required) An array of UuidGenerator.
value() - Method in annotation type org.eclipse.persistence.annotations.ValuePartition
The String representation of the value.
value() - Method in annotation type org.eclipse.persistence.annotations.WriteTransformers
 
value() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, this represents the value function, used in nestedtable
value() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlClassExtractor
(Required) Defines the name of the class extractor that should be applied to this entity's descriptor.
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlCustomizer
(Required) Defines the name of the descriptor customizer that should be applied to this classes descriptor.
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlDiscriminatorNode
(Required) Indicates the the class indicator field name.
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlDiscriminatorValue
(Required) Indicates the class indicator for a given Type.
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlElementsJoinNodes
 
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlJoinNodes
 
value() - Method in enum org.eclipse.persistence.oxm.annotations.XmlMarshalNullRepresentation
 
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNamedAttributeNode
required: the name of the property
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNamedObjectGraphs
 
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNameTransformer
(Required) Defines the name of the XML name transformer that should be applied to names.
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlParameter
 
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlPath
The XPath for this property.
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlPaths
 
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlProperties
 
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlProperty
String representation of Property value, converted to an instance of valueType.
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlVariableNode
The name of the attribute on the referenced type to be used as the tag name
value() - Method in enum org.eclipse.persistence.oxm.annotations.XmlVirtualAccessMethodsSchema
 
value() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlWriteTransformers
 
value() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredFunctionQueries
(Required) An array of named PLSQL stored procedure query.
value() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.NamedPLSQLStoredProcedureQueries
(Required) An array of named PLSQL stored procedure query.
value() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.OracleArrays
(Required) An array of Oracle VARRAY types.
value() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.OracleObjects
(Required) An array of Oracle OBJECT types.
value() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLRecords
(Required) An array of named PLSQL records.
value() - Method in annotation type org.eclipse.persistence.platform.database.oracle.annotations.PLSQLTables
(Required) An array of named PLSQL tables.
value(boolean) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression on the constant.
value(byte) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression on the constant.
value(char) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression on the constant.
value(double) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression on the constant.
value(float) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression on the constant.
value(int) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression on the constant.
value(long) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression on the constant.
value(short) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression on the constant.
value(Object) - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Return an expression on the constant.
Value - Static variable in class org.eclipse.persistence.config.ResultType
The first value of the first rows is returned.
Value - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
VALUE - org.eclipse.persistence.internal.mappings.converters.AttributeNamePrefix
INTERNAL: Attribute name prefix is "value".
VALUE - Static variable in class org.eclipse.persistence.queries.DataReadQuery
A single value is returned.
VALUE_HOLDER_INSTANTIATION_MISMATCH - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
VALUE_NOT_FOUND_IN_CLASS_INDICATOR_MAPPING - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
VALUE_PARAMETER_TYPE_INCORRECT - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
VALUE_PARAMETER_TYPE_INCORRECT_FOR_OXM_XML - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
VALUE_WRAPPER - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
valueColumn() - Method in annotation type org.eclipse.persistence.annotations.BasicCollection
Deprecated.
(Optional) The name of the value column that holds the direct collection data.
valueColumn() - Method in annotation type org.eclipse.persistence.annotations.BasicMap
Deprecated.
(Optional) The name of the data column that holds the direct collection data.
valueConverter - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
Allows user defined conversion between the object value and the database value.
valueConverter - Variable in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
Allows user defined conversion between the object value and the database value.
valueConverter - Variable in class org.eclipse.persistence.queries.DirectReadQuery
Allows user defined conversion between the result value and the database value.
valueConverter() - Method in annotation type org.eclipse.persistence.annotations.BasicMap
Deprecated.
(Optional) Specify the value converter.
valueConverterClassName - Variable in class org.eclipse.persistence.mappings.DirectCollectionMapping
 
valueFromBatchQuery(ReadQuery, AbstractRecord, ObjectLevelReadQuery, CacheKey) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromBatchQuery(ReadQuery, AbstractRecord, ObjectLevelReadQuery, CacheKey) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromBatchQuery(ReadQuery, AbstractRecord, ObjectLevelReadQuery, CacheKey) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromBatchQuery(ReadQuery, AbstractRecord, ObjectLevelReadQuery, CacheKey) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromBatchQuery(ReadQuery, AbstractRecord, ObjectLevelReadQuery, CacheKey) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromBatchQuery(ReadQuery, AbstractRecord, ObjectLevelReadQuery, CacheKey) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromMethod(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromMethod(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromMethod(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromMethod(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromMethod(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromMethod(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromObject(Object, FIELD, ABSTRACT_SESSION) - Method in class org.eclipse.persistence.core.mappings.CoreMapping
INTERNAL: A subclass should extract the value from the object for the field, if it does not map the field then it should return null.
valueFromObject(Object, FIELD, ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.oxm.mappings.DirectMapping
 
valueFromObject(Object, DatabaseField, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Extract value of the field from the object
valueFromObject(Object, DatabaseField, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass should extract the value from the object for the field, if it does not map the field then it should return null.
valueFromObject(Object, DatabaseField, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: Extract and return value of the field from the object
valueFromObject(Object, DatabaseField, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Get the value from the object for this mapping.
valueFromObject(Object, DatabaseField, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
valueFromObject(Object, DatabaseField, AbstractSession) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL: Return the Value from the object.
valueFromObject(Object, DatabaseField, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
valueFromObject(Object, DatabaseField, AbstractSession) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
valueFromObject(Object, AbstractSession, AbstractRecord, int) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Return the value for in memory comparison.
valueFromObject(Object, AbstractSession, AbstractRecord, int) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
valueFromObject(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Return the value for in memory comparison.
valueFromObject(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: The expression builder represent the entire object, just return it.
valueFromObject(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
INTERNAL: Return the value for in memory comparison.
valueFromObject(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.internal.expressions.CollectionExpression
INTERNAL: Return the value for in memory comparison.
valueFromObject(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: Return the value for in memory comparison.
valueFromObject(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: Return the value for in memory comparison.
valueFromObject(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Return the value for in memory comparison.
valueFromObject(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
INTERNAL: Return the value for in memory comparison.
valueFromObject(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Return the value for in memory comparison.
valueFromObject(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Return the value for in memory comparison.
valueFromObject(Object, AbstractSession, AbstractRecord, int, boolean) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
valueFromPKList(Object[], AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: This method is used to load a relationship from a list of PKs.
valueFromPKList(Object[], AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
This method is used to load a relationship from a list of PKs.
valueFromPKList(Object[], AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: This method is used to load a relationship from a list of PKs.
valueFromPKList(Object[], AbstractRecord, ForeignReferenceMapping, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: This method is used to load a relationship from a list of PKs.
valueFromPKList(Object[], AbstractRecord, ForeignReferenceMapping, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ListContainerPolicy
INTERNAL: This method is used to load a relationship from a list of PKs.
valueFromPKList(Object[], AbstractRecord, ForeignReferenceMapping, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MapContainerPolicy
INTERNAL: This method is used to load a relationship from a list of PKs.
valueFromPKList(Object[], AbstractRecord, ForeignReferenceMapping, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
INTERNAL: This method is used to load a relationship from a list of PKs.
valueFromQuery(ReadQuery, AbstractRecord, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromQuery(ReadQuery, AbstractRecord, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromQuery(ReadQuery, AbstractRecord, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromQuery(ReadQuery, AbstractRecord, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: A combination of valueFromQuery and valueFromRow(object).
valueFromQuery(ReadQuery, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromQuery(ReadQuery, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromQuery(ReadQuery, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromQuery(ReadQuery, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromQuery(ReadQuery, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromQuery(ReadQuery, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromResultSet(ResultSet, ObjectBuildingQuery, AbstractSession, DatabaseAccessor, ResultSetMetaData, int, DatabasePlatform) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Returns the value for the mapping directly from the result-set.
valueFromResultSet(ResultSet, ObjectBuildingQuery, AbstractSession, DatabaseAccessor, ResultSetMetaData, int, DatabasePlatform) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Returns the value for the mapping directly from the result-set.
valueFromRow(Object) - Method in class org.eclipse.persistence.internal.indirection.BasicIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromRow(Object) - Method in class org.eclipse.persistence.internal.indirection.ContainerIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromRow(Object) - Method in class org.eclipse.persistence.internal.indirection.IndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromRow(Object) - Method in class org.eclipse.persistence.internal.indirection.NoIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromRow(Object) - Method in class org.eclipse.persistence.internal.indirection.ProxyIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromRow(Object) - Method in class org.eclipse.persistence.internal.indirection.TransparentIndirectionPolicy
INTERNAL: Return the value to be stored in the object's attribute.
valueFromRow(Object, XMLRecord, JoinedAttributeManager, ObjectBuildingQuery, AbstractSession, boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, boolean) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Return the value of the reference attribute or a value holder.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: Return the value of the field from the row or a value holder on the query to obtain the object.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return the value of the reference attribute or a value holder.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return the value of the reference attribute or a value holder.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Build and return an aggregate collection from the specified row.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Build the nested collection from the database row.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: Extract and return the aggregate object from the specified row.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Return the mapping's attribute value from the row.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Return the value of the field from the row or a value holder on the query to obtain the object.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Return the value of the field from the row or a value holder on the query to obtain the object.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
 
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
INTERNAL: Build the nested collection from the database row.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
INTERNAL: Return the mapping's attribute value from the row.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
INTERNAL: Build the nested collection from the database row.
valueFromRow(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean, Boolean[]) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentMapping
 
valueFromRowInternal(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, AbstractSession) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return the value of the reference attribute or a value holder.
valueFromRowInternal(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: Return the value of the reference attribute or a value holder.
valueFromRowInternal(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return the value of the field from the row or a value holder on the query to obtain the object.
valueFromRowInternalWithJoin(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Return the value of the field from the row or a value holder on the query to obtain the object.
valueFromRowInternalWithJoin(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Return the value of the field from the row or a value holder on the query to obtain the object.
valueFromRowInternalWithJoin(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.DirectMapMapping
INTERNAL: Return the value of the field from the row or a value holder on the query to obtain the object.
valueFromRowInternalWithJoin(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.ForeignReferenceMapping
INTERNAL: If the query used joining or partial attributes, build the target object directly.
valueFromRowInternalWithJoin(AbstractRecord, JoinedAttributeManager, ObjectBuildingQuery, CacheKey, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Return the value of the field from the row or a value holder on the query to obtain the object.
valueHolder - Variable in class org.eclipse.persistence.indirection.IndirectList
Delegate indirection behavior to a value holder.
valueHolder - Variable in class org.eclipse.persistence.indirection.IndirectMap
Delegate indirection behavior to a value holder
ValueHolder<T> - Class in org.eclipse.persistence.indirection
Purpose: Act as a place holder for a variable that required a value holder interface.
ValueHolder() - Constructor for class org.eclipse.persistence.indirection.ValueHolder
PUBLIC: Initialize the holder.
ValueHolder(T) - Constructor for class org.eclipse.persistence.indirection.ValueHolder
PUBLIC: Initialize the holder with an object.
valueHolderInstantiationMismatch(Object, DatabaseMapping) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
ValueHolderInterface<T> - Interface in org.eclipse.persistence.indirection
Purpose: Interface to allow lazy loading of an object's relationships from the database.
ValueHolderInterface_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
valueIsNull(Element) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
INTERNAL: When using the DOM Platform during unmarshal operations.
valueIsNull(Attributes) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
INTERNAL: When using the SAX or DOM Platform during unmarshal operations.
valueMapping - Variable in class org.eclipse.persistence.internal.queries.MappedKeyMapContainerPolicy
 
valueNotFoundInClassIndicatorMapping(ClassDescriptor, ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
valueOf(int) - Static method in enum org.eclipse.persistence.internal.databaseaccess.DatasourceCall.ParameterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.BatchFetchType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.CacheCoordinationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.CacheKeyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.CacheType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.ChangeTrackingType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.DatabaseChangeNotificationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.Direction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.ExistenceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.IdValidation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.JoinFetchType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.MultitenantType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.OptimisticLockingType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.OrderCorrectionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.annotations.TenantTableDiscriminatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.config.CacheIsolationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.config.ReferenceMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.internal.databaseaccess.DatasourceCall.ParameterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy.LockOnChange
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.internal.helper.DatabaseType.DatabaseTypeHelper
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.internal.mappings.converters.AttributeNamePrefix
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.logging.LogCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.logging.LogLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.mappings.DatabaseMapping.WriteType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.mappings.OneToOneMapping.ShallowMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.oxm.annotations.XmlMarshalNullRepresentation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.oxm.annotations.XmlVirtualAccessMethodsSchema
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.oxm.mappings.nullpolicy.XMLNullRepresentationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.oxm.mappings.UnmarshalKeepAsElementPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.oxm.MediaType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.queries.DatabaseQuery.ParameterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.queries.ReadAllQuery.Direction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.sessions.server.ConnectionPolicy.ExclusiveMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.persistence.sessions.UnitOfWork.CommitOrderType
Returns the enum constant of this type with the specified name.
ValuePartition - Annotation Type in org.eclipse.persistence.annotations
Represent a specific value partition.
ValuePartitioning - Annotation Type in org.eclipse.persistence.annotations
ValuePartitioning partitions access to a database cluster by a field value from the object, such as the object's location, or tenant.
ValuePartitioningPolicy - Class in org.eclipse.persistence.descriptors.partitioning
PUBLIC: ValuePartitioningPolicy partitions access to a database cluster by a field value from the object, such as the object's location, or tenant.
ValuePartitioningPolicy() - Constructor for class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
 
ValuePartitioningPolicy(String) - Constructor for class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
 
ValuePartitioningPolicy(String, boolean) - Constructor for class org.eclipse.persistence.descriptors.partitioning.ValuePartitioningPolicy
 
ValueRead - Static variable in class org.eclipse.persistence.config.QueryType
 
ValueReadQuery - Class in org.eclipse.persistence.queries
Purpose: Concrete class to perform a read of a single data value.
ValueReadQuery() - Constructor for class org.eclipse.persistence.queries.ValueReadQuery
PUBLIC: Initialize the state of the query.
ValueReadQuery(String) - Constructor for class org.eclipse.persistence.queries.ValueReadQuery
PUBLIC: Initialize the query to use the specified SQL string.
ValueReadQuery(Call) - Constructor for class org.eclipse.persistence.queries.ValueReadQuery
PUBLIC: Initialize the query to use the specified call.
values - Variable in class org.eclipse.persistence.internal.expressions.TableAliasLookup
 
values - Variable in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
values - Variable in class org.eclipse.persistence.internal.sessions.AbstractRecord
Use vector to store the fields/values for optimal performance.
values() - Static method in enum org.eclipse.persistence.annotations.BatchFetchType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.annotations.CacheCoordinationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.annotations.CacheKeyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.annotations.CacheType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.annotations.ChangeTrackingType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.annotations.DatabaseChangeNotificationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.annotations.Direction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.annotations.ExistenceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.annotations.IdValidation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.annotations.JoinFetchType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.annotations.MultitenantType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.annotations.OptimisticLockingType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.annotations.OrderCorrectionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.annotations.TenantTableDiscriminatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.config.CacheIsolationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.config.ReferenceMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.eclipse.persistence.eis.EISMappedRecord
Forward the request to the record.
values() - Method in class org.eclipse.persistence.indirection.IndirectMap
 
values() - Static method in enum org.eclipse.persistence.internal.databaseaccess.DatasourceCall.ParameterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.internal.descriptors.OptimisticLockingPolicy.LockOnChange
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.eclipse.persistence.internal.expressions.TableAliasLookup
 
values() - Static method in enum org.eclipse.persistence.internal.helper.DatabaseType.DatabaseTypeHelper
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.eclipse.persistence.internal.helper.IdentityWeakHashMap
Returns a collection view of the values contained in this IdentityWeakHashMap.
values() - Static method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.eclipse.persistence.internal.helper.NonSynchronizedProperties
 
values() - Static method in enum org.eclipse.persistence.internal.mappings.converters.AttributeNamePrefix
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.eclipse.persistence.internal.oxm.NamespaceResolverStorage
Unmodifiable collection of values
values() - Method in class org.eclipse.persistence.internal.sessions.AbstractRecord
PUBLIC: Returns an collection of the values.
values() - Static method in enum org.eclipse.persistence.logging.LogCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.logging.LogLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.mappings.DatabaseMapping.WriteType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.mappings.OneToOneMapping.ShallowMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.oxm.annotations.XmlMarshalNullRepresentation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.oxm.annotations.XmlVirtualAccessMethodsSchema
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.oxm.mappings.nullpolicy.XMLNullRepresentationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.oxm.mappings.UnmarshalKeepAsElementPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.oxm.MediaType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.eclipse.persistence.oxm.record.DOMRecord
PUBLIC: Return the collection of element values from the DOM.
values() - Static method in enum org.eclipse.persistence.platform.database.jdbc.JDBCTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.queries.DatabaseQuery.ParameterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.queries.ReadAllQuery.Direction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.eclipse.persistence.queries.ReportQueryResult
PUBLIC: Returns an collection of the values.
values() - Static method in enum org.eclipse.persistence.sessions.server.ConnectionPolicy.ExclusiveMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.persistence.sessions.UnitOfWork.CommitOrderType
Returns an array containing the constants of this enum type, in the order they are declared.
ValuesAccessor - Class in org.eclipse.persistence.internal.dynamic
ValueAccessor is a specialized AttributeAccessor enabling access to property values
ValuesAccessor(DatabaseMapping) - Constructor for class org.eclipse.persistence.internal.dynamic.ValuesAccessor
 
valuesArray - Variable in class org.eclipse.persistence.internal.sessions.ArrayRecord
 
valuesFromCollection(Object, AbstractSession, int, boolean) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL This method iterates through a collection and gets the values from the objects to conform in an in-memory query.
ValuesSet() - Constructor for class org.eclipse.persistence.internal.sessions.AbstractRecord.ValuesSet
Default constructor.
valuesToExclude - Variable in class org.eclipse.persistence.queries.QueryByExamplePolicy
 
valueType - Variable in class org.eclipse.persistence.mappings.TypedAssociation
 
valueType() - Method in annotation type org.eclipse.persistence.annotations.Property
Property value type.
valueType() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlProperty
Property value type.
VARBINARY_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
VARCHAR_TYPE - org.eclipse.persistence.platform.database.jdbc.JDBCTypes
 
VARIABLE_ONE_TO_ONE_MAPPING_IS_NOT_DEFINED - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
variableAttributeName - Variable in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
variableAttributeName - Variable in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
variableCannotHaveMapKey - Static variable in exception org.eclipse.persistence.exceptions.JPQLException
 
variableCannotHaveMapKey(String, int, int, String) - Static method in exception org.eclipse.persistence.exceptions.JPQLException
 
variableGetMethodName - Variable in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
variableGetMethodName - Variable in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
VariableOneToOne - Annotation Type in org.eclipse.persistence.annotations
Variable one to one mappings are used to represent a pointer references between a java object and an implementer of an interface.
VariableOneToOneMapping - Class in org.eclipse.persistence.mappings
Purpose: Variable one to one mappings are used to represent a pointer references between a java object and an implementer of an interface.
VariableOneToOneMapping() - Constructor for class org.eclipse.persistence.mappings.VariableOneToOneMapping
PUBLIC: Default constructor.
variableOneToOneMappingIsNotDefinedProperly(DatabaseMapping, ClassDescriptor, String) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
variables - Variable in class org.eclipse.persistence.tools.schemaframework.StoredProcedureDefinition
 
variableSetMethodName - Variable in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
variableSetMethodName - Variable in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
VariableXPathCollectionMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​CONVERTER extends CoreConverter,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​SESSION extends CoreSession,​UNMARSHALLER extends Unmarshaller,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
VariableXPathObjectMapping<ABSTRACT_SESSION extends CoreAbstractSession,​ATTRIBUTE_ACCESSOR extends CoreAttributeAccessor,​CONTAINER_POLICY extends CoreContainerPolicy,​CONVERTER extends CoreConverter,​DESCRIPTOR extends CoreDescriptor,​FIELD extends CoreField,​MARSHALLER extends Marshaller,​SESSION extends CoreSession,​UNMARSHALLER extends Unmarshaller,​XML_RECORD extends XMLRecord> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
variance() - Method in class org.eclipse.persistence.expressions.Expression
PUBLIC: Function, this represents the aggregate function Variance.
variance() - Static method in class org.eclipse.persistence.expressions.ExpressionOperator
INTERNAL: Build operator.
Variance - Static variable in class org.eclipse.persistence.expressions.ExpressionOperator
 
VarrayDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Allow for creation of varray type.
VarrayDefinition() - Constructor for class org.eclipse.persistence.tools.schemaframework.VarrayDefinition
 
varSuffix - Static variable in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
Vector_class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
VectorContainerPolicy - Class in org.eclipse.persistence.internal.queries
PERF: Avoids reflection usage for Vectors.
VectorContainerPolicy() - Constructor for class org.eclipse.persistence.internal.queries.VectorContainerPolicy
INTERNAL: Construct a new policy.
VectorContainerPolicy(Class<?>) - Constructor for class org.eclipse.persistence.internal.queries.VectorContainerPolicy
INTERNAL: Construct a new policy for the specified class.
VectorContainerPolicy(String) - Constructor for class org.eclipse.persistence.internal.queries.VectorContainerPolicy
INTERNAL: Construct a new policy for the specified class name.
vectorFor(Object, ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.core.queries.CoreContainerPolicy
INTERNAL: Return a Vector populated with the contents of container.
vectorFor(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.queries.ContainerPolicy
INTERNAL: Return a Vector populated with the contents of container.
vectorFromArray(T[]) - Static method in class org.eclipse.persistence.internal.helper.Helper
Convert the specified array into a vector.
VectorUtils - Class in org.eclipse.persistence.internal.oxm
This class provides "empty" and "unmodifiable" wrappers for the Vector class.
vendorConnectionMethod - Variable in class org.eclipse.persistence.platform.server.was.WebSpherePlatform
Cached WAS util method used for unwrapping connections.
vendorConnectionMethod - Variable in class org.eclipse.persistence.platform.server.wls.WebLogicPlatform
Cached WLConnection.getVendorConnection() Method used for unwrapping connections.
verify() - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
INTERNAL: Verify that this project and descriptors do not have optimistic locking.
verify(Class<?>, ClassLoader) - Method in class org.eclipse.persistence.dynamic.DynamicClassWriter
Verify that the provided class meets the requirements of the writer.
verifyDelete(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
TESTING: This is used by testing code to ensure that a deletion was successful.
verifyDelete(Object) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
TESTING: This is used by testing code to ensure that a deletion was successful.
verifyDelete(Object, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Used to verify whether the specified object is deleted or not.
verifyDelete(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Verify that an object has been deleted from the database.
verifyDelete(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
INTERNAL: Checks if object is deleted from the database or not.
verifyDelete(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Return whether the specified object and all its components have been deleted.
verifyDelete(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Checks if object is deleted from the database or not.
verifyDelete(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: To verify if the specified object has been deleted or not.
verifyDelete(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.DirectCollectionMapping
INTERNAL: Checks if object is deleted from the database or not.
verifyDelete(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: To verify if the specified object is deleted or not.
verifyDelete(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToManyMapping
INTERNAL: Used to verify whether the specified object is deleted or not.
verifyDeleteForUpdate(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.AggregateCollectionMapping
Verifying deletes make sure that all the records privately owned by this mapping are actually removed.
verifyDeleteForUpdate(DeleteObjectQuery) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: Verifying deletes make sure that all the records privately owned by this mapping are actually removed.
verifyDeleteOfAttributeValue(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateMapping
INTERNAL: Return whether the specified object and all its components have been deleted.
verifyDeleteOfAttributeValue(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
Return whether the specified object and all its components have been deleted.
verifyField(AbstractSession, DatabaseField, ClassDescriptor) - Static method in class org.eclipse.persistence.descriptors.ReturningPolicy
 
verifyFieldAndMapping(AbstractSession, DatabaseField) - Method in class org.eclipse.persistence.descriptors.ReturningPolicy
 
verifyFieldAndMapping(AbstractSession, DatabaseField, ClassDescriptor, DatabaseMapping) - Static method in class org.eclipse.persistence.descriptors.ReturningPolicy
 
verifyMultipleTableInsertOrder() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Verify multiple table insert order provided by the user.
verifyMultipleTablesForeignKeysTables() - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Verify that the tables specified in multipleTablesForeignKeysTables are valid.
verifyMutexThreadIntegrityBeforeRelease() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: 272022: Avoid releasing locks on the wrong server thread.
verifyPlatform(Platform) - Method in class org.eclipse.persistence.sequencing.Sequence
INTERNAL: Make sure that the sequence is not used by more than one platform.
verifyTableQualifiers(DatasourcePlatform) - Method in class org.eclipse.persistence.history.HistoryPolicy
INTERNAL: Check that the qualifiers on the historical tables are properly set.
verifyTableQualifiers(Platform) - Method in class org.eclipse.persistence.descriptors.ClassDescriptor
INTERNAL: Check that the qualifier on the table names are properly set.
verifyUsage(AbstractSession) - Method in class org.eclipse.persistence.descriptors.FieldsLockingPolicy
INTERNAL: throw an exception if not inside a unit of work at this point
version(String) - Static method in class org.eclipse.persistence.internal.helper.Helper
INTERNAL: Expects version in ***num.num.num.num.num*** format, converts it to a List of Integers.
Version - Class in org.eclipse.persistence
This class stores variables for the version and build numbers that are used in printouts and exceptions.
VERSION_COLUMN - org.eclipse.persistence.annotations.OptimisticLockingType
Using this type of locking policy compares a single version number in the where clause when doing an update.
VersionLockingPolicy - Class in org.eclipse.persistence.descriptors
Purpose: Used to allow a single version number to be used for optimistic locking.
VersionLockingPolicy() - Constructor for class org.eclipse.persistence.descriptors.VersionLockingPolicy
PUBLIC: Create a new VersionLockingPolicy.
VersionLockingPolicy(String) - Constructor for class org.eclipse.persistence.descriptors.VersionLockingPolicy
PUBLIC: Create a new VersionLockingPolicy.
VersionLockingPolicy(DatabaseField) - Constructor for class org.eclipse.persistence.descriptors.VersionLockingPolicy
PUBLIC: Create a new VersionLockingPolicy.
versionString - Static variable in class org.eclipse.persistence.sessions.DatasourceLogin
 
versionString() - Method in class org.eclipse.persistence.internal.helper.JavaSEPlatform.Version
Return computer readable String containing version numbers in <major> '.' <minor> format.
versionString() - Method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Return computer readable String containing version numbers in <major> '.' <minor> format.
versionString(int, int) - Static method in enum org.eclipse.persistence.internal.helper.JavaSEPlatform
Generate String containing minor and major version numbers in <major> '.' <minor> format.
VERTICAL_BAR - Static variable in class org.eclipse.persistence.internal.helper.StringHelper
Vertical bar.
ViewDefinition - Class in org.eclipse.persistence.tools.schemaframework
Purpose: Allow for creation of views.
ViewDefinition() - Constructor for class org.eclipse.persistence.tools.schemaframework.ViewDefinition
 
viewTable - Variable in class org.eclipse.persistence.expressions.ExpressionBuilder
 
VirtualAccessMethods - Annotation Type in org.eclipse.persistence.annotations
Specifies that this class contains virtual attributes.
VirtualAttributeAccessor - Class in org.eclipse.persistence.internal.descriptors
 
VirtualAttributeAccessor() - Constructor for class org.eclipse.persistence.internal.descriptors.VirtualAttributeAccessor
 
VirtualAttributeMethodInfo - Class in org.eclipse.persistence.internal.descriptors
Data-holding object that holds information about object used by mappings with a VIRTUAL access type.
VirtualAttributeMethodInfo(String, String) - Constructor for class org.eclipse.persistence.internal.descriptors.VirtualAttributeMethodInfo
 
virtualAttributeMethods - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
A list of methods that are used by virtual mappings.
visit() - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
Visited - Static variable in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
visitedObjects - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
visitedStack - Variable in class org.eclipse.persistence.internal.descriptors.DescriptorIterator
 
VM_VERSION_PROPERTY - Static variable in class org.eclipse.persistence.internal.helper.JavaVersion
Java VM version system property name.
vmVersion() - Static method in class org.eclipse.persistence.internal.helper.JavaVersion
Java specification version detector.
vmVersionString() - Static method in class org.eclipse.persistence.internal.helper.JavaVersion
Retrieves Java specification version String from JDK system property.
Void_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
VPD - org.eclipse.persistence.annotations.MultitenantType
Specifies that the DB will handle the tenant filtering on all SELECT, UPDATE and DELETE queries.
VPD_MULTIPLE_IDENTIFIERS_SPECIFIED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
VPD_NOT_SUPPORTED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
vpdClearIdentifierQuery - Static variable in class org.eclipse.persistence.platform.database.OraclePlatform
 
vpdIdentifier - Variable in class org.eclipse.persistence.descriptors.VPDMultitenantPolicy
 
vpdIdentifier - Variable in class org.eclipse.persistence.sessions.Project
VPD connection settings
vpdIdentifierFieldName - Variable in class org.eclipse.persistence.descriptors.VPDMultitenantPolicy
 
vpdLastIdentifierClassName - Variable in class org.eclipse.persistence.sessions.Project
 
VPDMultitenantPolicy - Class in org.eclipse.persistence.descriptors
A vpd multitenant policy.
VPDMultitenantPolicy(ClassDescriptor) - Constructor for class org.eclipse.persistence.descriptors.VPDMultitenantPolicy
 
vpdNotSupported(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
vpdSetIdentifierQuery - Static variable in class org.eclipse.persistence.platform.database.OraclePlatform
 

W

WAIT_FAILURE_CLIENT - Static variable in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
WAIT_FAILURE_SEQ_DATABASE_SESSION - Static variable in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
WAIT_FAILURE_SERVER - Static variable in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
WAIT_ON_ERROR_RECEIVING_JMS_MESSAGE - Static variable in class org.eclipse.persistence.internal.sessions.coordination.jms.JMSTopicRemoteConnection
 
WAIT_TIMEOUT - Static variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
WAIT_WAS_INTERRUPTED - Static variable in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
waitFailureOnClientSession(InterruptedException) - Static method in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
waitFailureOnSequencingForDatabaseSession(InterruptedException) - Static method in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
waitFailureOnServerSession(InterruptedException) - Static method in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
waitForObject() - Method in class org.eclipse.persistence.internal.identitymaps.CacheKey
 
waitOnObjectLock(ClassDescriptor, Object, AbstractSession, int) - Method in class org.eclipse.persistence.internal.helper.WriteLockManager
INTERNAL: This method performs the operations of finding the cacheKey and locking it if possible.
waitTimeout - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
waitTimeout has three possible setting: null, 0 and 1..N null: use the session.getPessimisticLockTimeoutDefault() if available.
waitTimeout - Variable in class org.eclipse.persistence.sessions.server.ConnectionPool
 
waitTimeoutUnit - Variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
waitUntilAdd() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Wait until a new element has been added.
waitUntilComplete() - Method in class org.eclipse.persistence.internal.helper.ThreadCursoredList
Wait until the list has been fully populated.
waitWasInterrupted(String) - Static method in exception org.eclipse.persistence.exceptions.ConcurrencyException
 
warning(String) - Method in class org.eclipse.persistence.logging.AbstractSessionLog
PUBLIC:
warning(String) - Method in interface org.eclipse.persistence.logging.SessionLog
PUBLIC: This method is called when a warning level message needs to be logged.
warning(String, String) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC:
warning(SAXParseException) - Method in class org.eclipse.persistence.platform.xml.DefaultErrorHandler
 
warning(SAXParseException) - Method in class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader.XMLSessionConfigLoaderErrorHandler
 
WARNING - org.eclipse.persistence.logging.LogLevel
Exceptions that are not fatal.
WARNING - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
WARNING_LABEL - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
WARNING_PREFIX - Static variable in class org.eclipse.persistence.logging.AbstractSessionLog
Represents prefix to logged warning
wasAdditionJoinCriteriaUsed - Variable in class org.eclipse.persistence.expressions.ExpressionBuilder
 
wasAdditionJoinCriteriaUsed() - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: If the additional Join Criteria for the class this builder represents has been added to the statement this method will return true;
wasDefaultLockMode - Variable in class org.eclipse.persistence.queries.ObjectBuildingQuery
PERF: Store if the query originally used the default lock mode.
wasDefaultLockMode() - Method in class org.eclipse.persistence.queries.ObjectBuildingQuery
INTERNAL: Return if this query originally used the default lock mode.
wasDefaultUnitOfWorkCacheIsolationLevel - Variable in class org.eclipse.persistence.descriptors.CachePolicy
 
wasDeleted(Object) - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: Return if the object was deleted previously (in a flush).
wasDeleted(Object) - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Return if the object was deleted previously (in a flush).
wasFailureCommunicationBased(SQLException, Connection, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
wasFailureCommunicationBased(SQLException, Connection, AbstractSession) - Method in class org.eclipse.persistence.platform.database.OraclePlatform
INTERNAL: A call to this method will perform a platform based check on the connection and exception error code to determine if the connection is still valid or if a communication error has occurred.
wasFailureCommunicationBased(SQLException, Connection, AbstractSession) - Method in class org.eclipse.persistence.platform.database.SymfowarePlatform
Fail-over is not implemented on platform.
wasFailureCommunicationBased(SQLException, Accessor, AbstractSession) - Method in interface org.eclipse.persistence.platform.server.ServerPlatform
INTERNAL: A call to this method will perform a platform based check on the connection and exception error code to determine if the connection is still valid or if a communication error has occurred.
wasFailureCommunicationBased(SQLException, Accessor, AbstractSession) - Method in class org.eclipse.persistence.platform.server.ServerPlatformBase
INTERNAL: A call to this method will perform a platform based check on the connection and exception error code to determine if the connection is still valid or if a communication error has occurred.
wasJTSTransactionInternallyStarted - Variable in class org.eclipse.persistence.internal.sessions.AbstractSession
If Transactions were externally started
wasJTSTransactionInternallyStarted() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Return if a JTS transaction was started by the session.
wasNonObjectLevelModifyQueryExecuted - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
True if either DataModifyQuery or ModifyAllQuery was executed.
wasNonObjectLevelModifyQueryExecuted() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: True if either DataModifyQuery or ModifyAllQuery was executed.
wasOperationSuccessful - Variable in class org.eclipse.persistence.internal.sessions.remote.Transporter
 
wasOperationSuccessful() - Method in class org.eclipse.persistence.internal.sessions.remote.Transporter
Return whether the operation which caused this transporter to be returned was successful.
wasQueryClassSetInternally - Variable in class org.eclipse.persistence.expressions.ExpressionBuilder
 
wasQueryClassSetInternally() - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: Returns true if TopLink set the query class as opposed to the customer.
wasSelectQueryCreated - Variable in class org.eclipse.persistence.sequencing.QuerySequence
 
wasTransactionBegunPrematurely - Variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
Flag indicating that the transaction for this UOW was already begun.
wasTransactionBegunPrematurely() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: Indicates if a transaction was begun by a pessimistic locking or non-selecting query.
wasUpdateQueryCreated - Variable in class org.eclipse.persistence.sequencing.QuerySequence
 
Weak - Static variable in class org.eclipse.persistence.config.CacheType
A Weak cache holds all objects in use by the application, but allows any un-referenced objects to be free to garbage collection.
WEAK - org.eclipse.persistence.annotations.CacheType
Similar to the FULL identity map except that the map holds the objects using weak references.
WEAK - org.eclipse.persistence.config.ReferenceMode
References to Objects that support active attribute change tracking (enabled through weaving or by the developer)will be held by weak references.
WeakCacheKey - Class in org.eclipse.persistence.internal.identitymaps
Purpose: Container class for storing objects in an IdentityMap.
WeakCacheKey(Object, Object, Object, long, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.WeakCacheKey
Initialize the newly allocated instance of this class.
WeakIdentityMap - Class in org.eclipse.persistence.internal.identitymaps
Purpose: A WeakIdentityMap holds all objects referenced by the application only.
WeakIdentityMap(int, ClassDescriptor, AbstractSession, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.WeakIdentityMap
 
WeakIdentityMap_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
WeakObjectWrapper - Class in org.eclipse.persistence.internal.oxm
INTENRAL:
WeakObjectWrapper(Object) - Constructor for class org.eclipse.persistence.internal.oxm.WeakObjectWrapper
 
WeakUnitOfWorkIdentityMap - Class in org.eclipse.persistence.internal.identitymaps
 
WeakUnitOfWorkIdentityMap(int, ClassDescriptor, AbstractSession, boolean) - Constructor for class org.eclipse.persistence.internal.identitymaps.WeakUnitOfWorkIdentityMap
 
WeavedAttributeValueHolderInterface<T> - Interface in org.eclipse.persistence.indirection
INTERNAL: This interface defines functionality required by ValueHolders for OneToOneMappings that have LAZY access weaved into them and use Property (method) based access The weaving feature adds a paralell valueholder to the class it weaves and uses that valueholder to control the lazy loading.
WeavedAttributeValueHolderInterface_Class - Static variable in class org.eclipse.persistence.internal.helper.ClassConstants
 
WeavedObjectBasicIndirectionPolicy - Class in org.eclipse.persistence.internal.indirection
A WeavedObjectBasicIndirectionPolicy is used by OneToOne mappings that are LAZY through weaving and which use Property(method) access.
WeavedObjectBasicIndirectionPolicy(String, String, String, boolean) - Constructor for class org.eclipse.persistence.internal.indirection.WeavedObjectBasicIndirectionPolicy
 
weaveInplaceForJar(String) - Static method in exception org.eclipse.persistence.exceptions.StaticWeaveException
INTERNAL: EclipseLink exceptions should only be thrown by EclipseLink.
WEAVER - org.eclipse.persistence.logging.LogCategory
 
WEAVER - Static variable in interface org.eclipse.persistence.logging.SessionLog
 
WEAVING - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.weaving" property configures whether weaving should be performed.
WEAVING_CHANGE_TRACKING - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.weaving.changetracking" property configures whether AttributeLevelChangeTracking should be enabled through weaving.
WEAVING_EAGER - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.weaving.eager" property configures whether EAGER mapping's attributes should be woven to use indirection.
WEAVING_FETCHGROUPS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.weaving.fetchgroups" property configures whether FetchGroup support should be enabled through weaving.
WEAVING_INTERNAL - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.weaving.internal" property indicates whether internal optimizations should be enabled through weaving.
WEAVING_LAZY - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.weaving.lazy" property configures whether LAZY OneToOne and ManyToOne mappings should be enabled through weaving.
WEAVING_MAPPEDSUPERCLASS - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.weaving.mappedsuperclass" property configures whether MappedSuperclasses with no direct sub-classes will be woven.
WEAVING_OUTPUT_PATH - Static variable in class org.eclipse.persistence.config.SystemProperties
This property is used to debug weaving issues.
WEAVING_REFLECTIVE_INTROSPECTION - Static variable in class org.eclipse.persistence.config.SystemProperties
This property can be used to tell EclipseLink to process classes in the ASM Default manner.
WEAVING_REST - Static variable in class org.eclipse.persistence.config.PersistenceUnitProperties
The "eclipselink.weaving.rest" property configures whether classes will be woven to support EclipseLink JPA_RS functionality
WEAVING_SHOULD_OVERWRITE - Static variable in class org.eclipse.persistence.config.SystemProperties
This property is used in conjunction with WEAVING_OUTPUT_PATH.
weavingUsesPropertyAccess - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
This flag stores whether this descriptor is using Property access based on JPA semantics.
WebLogic - Static variable in class org.eclipse.persistence.config.TargetServer
 
WebLogic_10 - Static variable in class org.eclipse.persistence.config.TargetServer
 
WebLogic_10_Platform - Class in org.eclipse.persistence.platform.server.wls
PUBLIC: This is the concrete subclass responsible for representing WebLogic 10 specific behavior.
WebLogic_10_Platform(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.wls.WebLogic_10_Platform
INTERNAL: Default Constructor: All behavior for the default constructor is inherited
WebLogic_10_PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
WebLogic_10_PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.WebLogic_10_PlatformConfig
 
WebLogic_12 - Static variable in class org.eclipse.persistence.config.TargetServer
 
WebLogic_12_Platform - Class in org.eclipse.persistence.platform.server.wls
 
WebLogic_12_Platform(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.wls.WebLogic_12_Platform
 
WebLogic_6_1_PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
WebLogic_6_1_PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.WebLogic_6_1_PlatformConfig
 
WebLogic_7_0_PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
WebLogic_7_0_PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.WebLogic_7_0_PlatformConfig
 
WebLogic_8_1_PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
WebLogic_8_1_PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.WebLogic_8_1_PlatformConfig
 
WebLogic_9 - Static variable in class org.eclipse.persistence.config.TargetServer
 
WebLogic_9_Platform - Class in org.eclipse.persistence.platform.server.wls
PUBLIC: This is the concrete subclass responsible for representing WebLogic9 specific behavior.
WebLogic_9_Platform(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.wls.WebLogic_9_Platform
INTERNAL: Default Constructor: All behavior for the default constructor is inherited
WebLogic_9_PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
WebLogic_9_PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.WebLogic_9_PlatformConfig
 
weblogicConnectionClass - Variable in class org.eclipse.persistence.platform.server.wls.WebLogicPlatform
Cached WLS connection class used to reflectively check connections and unwrap them.
WebLogicPlatform - Class in org.eclipse.persistence.platform.server.wls
PUBLIC: This is the concrete subclass responsible for representing WebLogic-specific server behavior.
WebLogicPlatform(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.wls.WebLogicPlatform
INTERNAL: Default Constructor: All behavior for the default constructor is inherited.
WebLogicPlatformDetector - Class in org.eclipse.persistence.platform.server.wls
 
WebLogicPlatformDetector() - Constructor for class org.eclipse.persistence.platform.server.wls.WebLogicPlatformDetector
Default constructor.
WebLogicRuntimeServices - Class in org.eclipse.persistence.services.weblogic
Purpose: Provide a dynamic interface into the EclipseLink Session.
WebLogicRuntimeServices() - Constructor for class org.eclipse.persistence.services.weblogic.WebLogicRuntimeServices
PUBLIC: Default Constructor
WebLogicRuntimeServices(Locale) - Constructor for class org.eclipse.persistence.services.weblogic.WebLogicRuntimeServices
Create an instance of WebLogicRuntimeServices to be associated with the provided locale The user must call setSession(Session) afterwards to define the session.
WebLogicRuntimeServices(AbstractSession) - Constructor for class org.eclipse.persistence.services.weblogic.WebLogicRuntimeServices
PUBLIC: Create an instance of WebLogicRuntimeServices to be associated with the provided session
WebLogicTransactionController - Class in org.eclipse.persistence.transaction.wls
Purpose: TransactionController implementation for WLS JTA
WebLogicTransactionController() - Constructor for class org.eclipse.persistence.transaction.wls.WebLogicTransactionController
Default constructor
WebLogicTransactionController11 - Class in org.eclipse.persistence.transaction.wls
Purpose: TransactionController implementation for WLS JTA
WebLogicTransactionController11() - Constructor for class org.eclipse.persistence.transaction.wls.WebLogicTransactionController11
Default constructor.
WebSphere - Static variable in class org.eclipse.persistence.config.TargetServer
 
WebSphere_4_0_PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
WebSphere_4_0_PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.WebSphere_4_0_PlatformConfig
 
WebSphere_5_0_PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
WebSphere_5_0_PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.WebSphere_5_0_PlatformConfig
 
WebSphere_5_1_PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
WebSphere_5_1_PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.WebSphere_5_1_PlatformConfig
 
WebSphere_6_0_PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
WebSphere_6_0_PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.WebSphere_6_0_PlatformConfig
 
WebSphere_6_1 - Static variable in class org.eclipse.persistence.config.TargetServer
 
WebSphere_6_1_Platform - Class in org.eclipse.persistence.platform.server.was
PUBLIC: This is the concrete subclass responsible for representing WebSphere 6.1-specific server behavior.
WebSphere_6_1_Platform(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.was.WebSphere_6_1_Platform
INTERNAL: Default Constructor: All behavior for the default constructor is inherited
WebSphere_6_1_PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
WebSphere_6_1_PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.WebSphere_6_1_PlatformConfig
 
WebSphere_7 - Static variable in class org.eclipse.persistence.config.TargetServer
 
WebSphere_7_0_PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
INTERNAL:
WebSphere_7_0_PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.WebSphere_7_0_PlatformConfig
 
WebSphere_7_Platform - Class in org.eclipse.persistence.platform.server.was
PUBLIC: This is the concrete subclass responsible for representing WebSphere 7 -specific server behavior.
WebSphere_7_Platform(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.was.WebSphere_7_Platform
INTERNAL: Default Constructor: All behavior for the default constructor is inherited
WebSphere_EJBEmbeddable - Static variable in class org.eclipse.persistence.config.TargetServer
 
WebSphere_EJBEmbeddable_Platform - Class in org.eclipse.persistence.platform.server.was
 
WebSphere_EJBEmbeddable_Platform(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.was.WebSphere_EJBEmbeddable_Platform
INTERNAL: Default Constructor: All behavior for the default constructor is inherited
WebSphere_EJBEmbeddable_PlatformConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
 
WebSphere_EJBEmbeddable_PlatformConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.WebSphere_EJBEmbeddable_PlatformConfig
 
WebSphere_Liberty - Static variable in class org.eclipse.persistence.config.TargetServer
 
WebSphere_Liberty_Platform - Class in org.eclipse.persistence.platform.server.was
PUBLIC: This is the concrete subclass responsible for representing WebSphere-specific server behavior.
WebSphere_Liberty_Platform(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.was.WebSphere_Liberty_Platform
INTERNAL: Default Constructor: All behavior for the default constructor is inherited
WebSphere_Liberty_Platform_Config - Class in org.eclipse.persistence.internal.sessions.factories.model.platform
 
WebSphere_Liberty_Platform_Config() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.platform.WebSphere_Liberty_Platform_Config
 
websphereConnectionClass - Variable in class org.eclipse.persistence.platform.server.was.WebSpherePlatform
Cached WAS connection class used to reflectively check connections and unwrap them.
WebSphereEJBEmbeddableTransactionController - Class in org.eclipse.persistence.transaction.was
 
WebSphereEJBEmbeddableTransactionController() - Constructor for class org.eclipse.persistence.transaction.was.WebSphereEJBEmbeddableTransactionController
Default constructor
WebSphereLibertyTransactionController - Class in org.eclipse.persistence.transaction.was
 
WebSphereLibertyTransactionController() - Constructor for class org.eclipse.persistence.transaction.was.WebSphereLibertyTransactionController
Default constructor
WebSpherePlatform - Class in org.eclipse.persistence.platform.server.was
PUBLIC: This is the concrete subclass responsible for representing WebSphere-specific server behavior.
WebSpherePlatform(DatabaseSession) - Constructor for class org.eclipse.persistence.platform.server.was.WebSpherePlatform
INTERNAL: Default Constructor: All behavior for the default constructor is inherited
WebSpherePlatformDetector - Class in org.eclipse.persistence.platform.server.was
 
WebSpherePlatformDetector() - Constructor for class org.eclipse.persistence.platform.server.was.WebSpherePlatformDetector
Default constructor.
WebSphereRuntimeServices - Class in org.eclipse.persistence.services.websphere
Purpose: Provide a dynamic interface into the EclipseLink Session.
WebSphereRuntimeServices() - Constructor for class org.eclipse.persistence.services.websphere.WebSphereRuntimeServices
PUBLIC: Default Constructor
WebSphereRuntimeServices(Locale) - Constructor for class org.eclipse.persistence.services.websphere.WebSphereRuntimeServices
Create an instance of WebSphereRuntimeServices to be associated with the provided locale The user must call setSession(Session) afterwards to define the session.
WebSphereRuntimeServices(AbstractSession) - Constructor for class org.eclipse.persistence.services.websphere.WebSphereRuntimeServices
PUBLIC: Create an instance of WebSphereRuntimeServices to be associated with the provided session
WebSphereTransactionController - Class in org.eclipse.persistence.transaction.was
Purpose: TransactionController implementation for WebSphere
WebSphereTransactionController() - Constructor for class org.eclipse.persistence.transaction.was.WebSphereTransactionController
 
websphereUtilClass - Variable in class org.eclipse.persistence.platform.server.was.WebSpherePlatform
Cached WAS util class used to reflectively check connections and unwrap them.
weight - Variable in class org.eclipse.persistence.mappings.DatabaseMapping
This is a TopLink defined attribute that allows us to sort the mappings
WEIGHT_AGGREGATE - Static variable in class org.eclipse.persistence.mappings.DatabaseMapping
 
WEIGHT_DIRECT - Static variable in class org.eclipse.persistence.mappings.DatabaseMapping
 
WEIGHT_TO_ONE - Static variable in class org.eclipse.persistence.mappings.DatabaseMapping
 
WEIGHT_TRANSFORM - Static variable in class org.eclipse.persistence.mappings.DatabaseMapping
 
whenShouldAcquireValueForAll() - Method in interface org.eclipse.persistence.internal.sequencing.Sequencing
INTERNAL: Indicates when sequencing value should be acquired for all classes.
WhenShouldAcquireValueForAll() - Constructor for class org.eclipse.persistence.internal.sessions.remote.SequencingFunctionCall.WhenShouldAcquireValueForAll
 
whereClause - Variable in class org.eclipse.persistence.internal.expressions.SQLStatement
 
whitespace() - Method in class org.eclipse.persistence.eis.interactions.XQueryInteraction
INTERNAL: Return the characters that represent non-arguments names.
whitespace() - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceCall
INTERNAL: Return the characters that represent non-arguments names.
withAllSubclasses(CommitOrderDependencyNode) - Method in class org.eclipse.persistence.internal.sessions.CommitOrderDependencyNode
 
withAllSubclassesExpression - Variable in class org.eclipse.persistence.descriptors.InheritancePolicy
 
withinDistance() - Static method in class org.eclipse.persistence.internal.expressions.SpatialExpressionOperators
ExpressionOperator for the MDSYS.SDO_WITHIN_DISTANCE Spatial Operator on the Oracle Database Use of this operator requires the Java spatial classes
WORKING_COPY_INTO_ORIGINAL - Static variable in class org.eclipse.persistence.internal.sessions.MergeManager
 
WORKING_COPY_INTO_REMOTE - Static variable in class org.eclipse.persistence.internal.sessions.MergeManager
 
workingCopyMethod - Variable in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
 
workingCopyMethod() - Method in annotation type org.eclipse.persistence.annotations.CloneCopyPolicy
(Optional) Either method or workingCopyMethod must be specified this defines a method that will be used to create a clone that will be used to create the object returned when registering an Object in an EclipseLink UnitOfWork
workingCopyMethodName - Variable in class org.eclipse.persistence.descriptors.copying.CloneCopyPolicy
 
wrapKey(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Allow the key mapping to wrap the object.
wrapKey(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Allow the key mapping to wrap the object.
wrapKey(Object, AbstractSession) - Method in interface org.eclipse.persistence.mappings.foundation.MapKeyMapping
INTERNAL: Allow the key mapping to wrap the object
wrapKey(Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Allow the key mapping to wrap the object.
wrapObject(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Wrap the object if required.
wrapObject(Object, AbstractSession) - Method in interface org.eclipse.persistence.descriptors.WrapperPolicy
PUBLIC: Required: Wrap the object to return the implementation that the application requires.
wrapObject(Object, AbstractSession) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Wrap the object if required.
wrapObjectInXMLRoot(Object, String, String, String, boolean, boolean, XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Determines the appropriate object to return from the unmarshal call.
wrapObjectInXMLRoot(Object, String, String, String, boolean, boolean, UNMARSHALLER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: Determines the appropriate object to return from the unmarshal call.
wrapObjectInXMLRoot(Object, String, String, String, String, String, boolean, boolean, XMLUnmarshaller) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL:
wrapObjectInXMLRoot(Object, String, String, String, String, String, boolean, boolean, UNMARSHALLER) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL:
wrapObjectInXMLRoot(UnmarshalRecord, boolean) - Method in class org.eclipse.persistence.oxm.XMLDescriptor
INTERNAL: Determines the appropriate object to return from the unmarshal call.
wrapObjectInXMLRoot(UNMARSHAL_RECORD, boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Descriptor
INTERNAL: Determines the appropriate object to return from the unmarshal call.
WRAPPED_ID_RESOLVER_WITH_MULTI_ID - Static variable in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
wrappedDatabaseType - Variable in class org.eclipse.persistence.internal.sessions.factories.DatabaseTypeWrapper
 
wrappedIDResolverWithMultiID(String, Object) - Static method in exception org.eclipse.persistence.exceptions.XMLMarshalException
 
wrappedKey - Variable in class org.eclipse.persistence.sessions.interceptors.CacheKeyInterceptor
 
wrappedServerValueHolder - Variable in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
 
wrappedValueHolder - Variable in class org.eclipse.persistence.internal.indirection.ProtectedValueHolder
 
wrappedValueHolder - Variable in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
The value holder in the original object.
wrappedValueHolderRemoteID - Variable in class org.eclipse.persistence.internal.indirection.UnitOfWorkValueHolder
 
wrapper - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
The cached wrapper for the object, used in EJB.
wrapperPolicy - Variable in class org.eclipse.persistence.descriptors.ClassDescriptor
 
WrapperPolicy - Interface in org.eclipse.persistence.descriptors
Purpose: The wrapper policy can be used to wrap all objects read from the database in another object.
WrappingValueHolder<T> - Interface in org.eclipse.persistence.internal.indirection
WrappingValueHolder is an interface type that implementors use when they will be wrapping another ValueHolder that has the original value.
wrapType(DatabaseType) - Static method in class org.eclipse.persistence.internal.sessions.factories.ObjectPersistenceRuntimeXMLProject_11_1_1
Wrap the type in a type wrapper to handle XML conversion.
write(char) - Method in interface org.eclipse.persistence.oxm.record.JSONWriterRecord.Output
 
write(char) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.OutputStreamOutput
 
write(Writer, PerformanceProfiler) - Method in class org.eclipse.persistence.tools.profiler.Profile
 
write(Object) - Method in class org.eclipse.persistence.internal.codegen.CodeGenerator
 
write(String) - Method in interface org.eclipse.persistence.oxm.record.JSONWriterRecord.Output
 
write(String) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.OutputStreamOutput
 
write(String, Project) - Static method in class org.eclipse.persistence.sessions.factories.XMLProjectWriter
INTERNAL: This should not be used.
write(String, Project, Writer) - Static method in class org.eclipse.persistence.sessions.factories.XMLProjectWriter
INTERNAL: This should not be used.
write(CodeGenerator) - Method in class org.eclipse.persistence.internal.codegen.AccessLevel
 
write(CodeGenerator) - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
Write the code out to the generator's stream.
write(CodeGenerator) - Method in class org.eclipse.persistence.internal.codegen.CodeDefinition
Write the code out to the generator's stream.
write(SessionConfigs, Writer) - Static method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigWriter
Given the writer, and a SessionConfigs, this writes out the session XML file.
write(SessionConfigs, String) - Static method in class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigWriter
Given the file name (including path), and a SessionConfigs, this writes out the session XML file.
write(Project, Writer) - Static method in class org.eclipse.persistence.sessions.factories.XMLProjectWriter
PUBLIC: Given the writer, and a project, this writes out the deployment XML file storing the project's descriptor and mapping information.
write(Project, String) - Static method in class org.eclipse.persistence.sessions.factories.XMLProjectWriter
PUBLIC: Given the file name (including path), and a project, this writes out the deployment XML file storing the project's descriptor and mapping information.
write(Project, String, Writer) - Static method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Generate the source code to a project class to the project's descriptor into the writer.
write(Project, String, String) - Static method in class org.eclipse.persistence.sessions.factories.ProjectClassGenerator
PUBLIC: Generate the source code to a project class to the project's descriptor into the file.
write(TableCreator, String, Writer) - Static method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Generate the source code to a table creator class to the table creator's tables into the writer.
write(TableCreator, String, String) - Static method in class org.eclipse.persistence.sessions.factories.TableCreatorClassGenerator
PUBLIC: Generate the source code to a table creator class to the table creator's tables into the file.
WRITE - Static variable in class org.eclipse.persistence.queries.ObjectLevelReadQuery
 
WRITE_LOCK_FIELD_IN_CHILD_DESCRIPTOR - Static variable in exception org.eclipse.persistence.exceptions.DescriptorException
 
WRITE_OBJECT_NOT_ALLOWED_IN_UNIT_OF_WORK - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
WRITE_RETURN - Static variable in class org.eclipse.persistence.descriptors.ReturningPolicy
 
WRITE_STATEMENTS_COUNT_PROPERTY - Static variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
 
WRITE_TRANSFORMER_CLASS_DOESNT_IMPLEMENT_FIELD_TRANSFORMER - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
WRITE_TRANSFORMER_HAS_BOTH_CLASS_AND_METHOD - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
WRITE_TRANSFORMER_HAS_BOTH_CLASS_AND_METHOD - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
WRITE_TRANSFORMER_HAS_NEITHER_CLASS_NOR_METHOD - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
WRITE_TRANSFORMER_HAS_NEITHER_CLASS_NOR_METHOD - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
WRITE_TRANSFORMER_HAS_NO_COLUMN_NAME - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
WRITE_TRANSFORMER_HAS_NO_XMLPATH - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
writeAddColumnClause(Writer, AbstractSession, TableDefinition, FieldDefinition) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: May need to override this method if the platform supports ALTER TABLE ADD <column> and the generated sql doesn't work.
writeAddColumnClause(Writer, AbstractSession, TableDefinition, FieldDefinition) - Method in class org.eclipse.persistence.platform.database.HANAPlatform
 
writeAlias(ExpressionSQLPrinter, DatabaseField, SQLSelectStatement) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Append the field's alias to the writer.
writeAllObjects(Collection) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Write all of the objects and all of their privately owned parts in the database.
writeAllObjects(Collection) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Write all of the objects and all of their privately owned parts in the database.
writeAllObjects(Vector) - Method in class org.eclipse.persistence.internal.sessions.DatabaseSessionImpl
PUBLIC: Write all of the objects and all of their privately owned parts in the database.
writeAllObjectsWithChangeSet(UnitOfWorkChangeSet) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: Write all of the objects and all of their privately owned parts in the database.
writeArguments(CodeGenerator) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
writeArguments(CodeGenerator) - Method in class org.eclipse.persistence.internal.codegen.NonreflectiveMethodDefinition
 
writeArguments(CodeGenerator) - Method in class org.eclipse.persistence.internal.codegen.ReflectiveMethodDefinition
 
writeAttributePrefix() - Method in interface org.eclipse.persistence.oxm.record.JSONWriterRecord.Output
 
writeAttributePrefix() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.OutputStreamOutput
 
writeAutoAssignmentSetClause(Writer, String, String, Collection<DatabaseField>, DatasourcePlatform) - Static method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: helper method, don't override.
writeAutoJoinWhereClause(Writer, String, String, Collection<DatabaseField>, DatasourcePlatform) - Static method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: helper method, don't override.
writeBody(CodeGenerator) - Method in class org.eclipse.persistence.internal.codegen.AttributeDefinition
 
writeBody(CodeGenerator) - Method in class org.eclipse.persistence.internal.codegen.ClassDefinition
Write the code out to the generator's stream.
writeBody(CodeGenerator) - Method in class org.eclipse.persistence.internal.codegen.CodeDefinition
Write the code out to the generator's stream.
writeBody(CodeGenerator) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
Write the code out to the generator's stream.
writeChanges() - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteUnitOfWork
Simulate a flush, current just begins a transaction and commits.
writeChanges() - Method in class org.eclipse.persistence.internal.sessions.RepeatableWriteUnitOfWork
INTERNAL: This will flush all changes to the database, and create or merge into the cumulativeUOWChangeSet.
writeChanges() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
ADVANCED: Writes all changes now before commit().
writeChanges() - Method in interface org.eclipse.persistence.sessions.UnitOfWork
ADVANCED: Writes all changes now before commit().
writeChanges(ObjectChangeSet, WriteObjectQuery) - Method in class org.eclipse.persistence.mappings.CollectionMapping
INTERNAL: Write the changes defined in the change set for the mapping.
WriteChangesFailed - Static variable in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
 
writeChangesOnNestedUnitOfWork() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
writeCharacters(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
writeCharacters(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
writeCharacters(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
writeCharacters(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
writeClass(DynamicClassLoader, String) - Method in class org.eclipse.persistence.dynamic.DynamicClassWriter
 
writeClass(DynamicClassLoader, String) - Method in interface org.eclipse.persistence.dynamic.EclipseLinkClassWriter
 
writeCleanUpTempTableSql(Writer, DatabaseTable) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Don't override this method.
writeComment(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.JsonRecord.JsonRecordContentHandler
 
writeComment(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.JSONWriterRecordContentHandler
 
writeComment(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
writeComment(char[], int, int) - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
writeCompleteChangeSet(ObjectOutputStream) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Helper method to readObject.
WriteConnectionPoolConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.pool
INTERNAL:
WriteConnectionPoolConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.pool.WriteConnectionPoolConfig
 
writeConnections - Variable in class org.eclipse.persistence.sessions.server.ClientSession
 
writeCR() - Method in interface org.eclipse.persistence.oxm.record.JSONWriterRecord.Output
 
writeCR() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.OutputStreamOutput
 
writeCreateTempTableSql(Writer, DatabaseTable, AbstractSession, Collection<DatabaseField>, Collection<DatabaseField>, Collection<DatabaseField>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Don't override this method.
writeDeclareTypeAndVar(Writer, DatabaseField, DatasourcePlatform) - Static method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
writeDefinition(StoredProcedureDefinition) - Method in class org.eclipse.persistence.tools.schemaframework.StoredProcedureGenerator
 
writeDeleteFromTargetTableUsingTempTableSql(Writer, DatabaseTable, DatabaseTable, Collection<DatabaseField>, Collection<DatabaseField>, DatasourcePlatform) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Write an sql string for deletion from target table using temporary table.
writeDeleteFromTargetTableUsingTempTableSql(Writer, DatabaseTable, DatabaseTable, Collection<DatabaseField>, Collection<DatabaseField>, DatasourcePlatform) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Writes MySQL specific SQL for accessing temp tables for delete-all queries.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Used to print a debug form of the expression tree.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.expressions.ExpressionBuilder
INTERNAL: For debug printing purposes.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.internal.expressions.ClassTypeExpression
INTERNAL: Used to print a debug form of the expression tree.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: Used to print a debug form of the expression tree.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: Used to print a debug form of the expression tree.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: Used to print a debug form of the expression tree.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.internal.expressions.FromSubSelectExpression
INTERNAL: Used to print a debug form of the expression tree.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Used to print a debug form of the expression tree.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
INTERNAL: Used to print a debug form of the expression tree.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.internal.expressions.MapEntryExpression
INTERNAL: Used to print a debug form of the expression tree.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Used to print a debug form of the expression tree.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.internal.expressions.QueryKeyExpression
INTERNAL: Used to print a debug form of the expression tree.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
INTERNAL: Used to print a debug form of the expression tree.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.internal.expressions.TableExpression
INTERNAL: Used to print a debug form of the expression tree.
writeDescriptionOn(BufferedWriter) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
writeEmptyCollection(JsonBuilderRecord.Level, String) - Method in class org.eclipse.persistence.oxm.record.JsonBuilderRecord
 
writeEmptyCollection(JsonRecord.Level, String) - Method in class org.eclipse.persistence.oxm.record.JsonGeneratorRecord
 
writeEmptyCollection(T, String) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
writeExternal(ObjectOutput) - Method in class org.eclipse.persistence.internal.sessions.remote.RemoteValueHolder
Override the default serialization for a remote valueholder so as not to serialize the value Note: Changed for bug 3145211.
writeExtraNamespaces(List, XMLRecord, CoreAbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLRelationshipMappingNodeValue
 
writeExtraNamespaces(List, XMLRecord) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
writeField(ExpressionSQLPrinter, DatabaseField) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL:
writeField(ExpressionSQLPrinter, DatabaseField, SQLSelectStatement) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Append the field name to the writer.
writeField(ExpressionSQLPrinter, DatabaseField, SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
 
writeFields(Writer, String, String, Collection<DatabaseField>, Collection<DatabaseField>, String, DatasourcePlatform) - Static method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: helper method, don't override.
writeFields(ExpressionSQLPrinter, List<DatabaseField>, SQLSelectStatement) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: called from SQLSelectStatement.writeFieldsFromExpression(...)
writeFields(ExpressionSQLPrinter, List<DatabaseField>, SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.ConstantExpression
INTERNAL: Append the constant value into the printer
writeFields(ExpressionSQLPrinter, List<DatabaseField>, SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: called from SQLSelectStatement.writeFieldsFromExpression(...)
writeFields(ExpressionSQLPrinter, List<DatabaseField>, SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: called from SQLSelectStatement.writeFieldsFromExpression(...)
writeFields(ExpressionSQLPrinter, List<DatabaseField>, SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.LiteralExpression
INTERNAL: Append the literal value into the printer, accounting for the first element
writeFields(ExpressionSQLPrinter, List<DatabaseField>, SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
INTERNAL: Append the parameter into the printer.
writeFields(ExpressionSQLPrinter, List<DatabaseField>, SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
INTERNAL: called from SQLSelectStatement.writeFieldsFromExpression(...) This allows a sub query in the select clause.
writeFields(ExpressionSQLPrinter, List<DatabaseField>, SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
writeFieldsAutoClause(Writer, String, String, Collection<DatabaseField>, String, DatasourcePlatform) - Static method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: helper method, don't override.
writeFieldsFromExpression(ExpressionSQLPrinter, Expression, Vector<DatabaseField>) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL:
writeFieldsIn(ExpressionSQLPrinter) - Method in class org.eclipse.persistence.internal.expressions.SQLSelectStatement
INTERNAL:
writeFieldsList(Writer, Collection<DatabaseField>, DatasourcePlatform) - Static method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: helper method, don't override.
writeForAll(Writer, DatabaseField, DatasourcePlatform) - Static method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
writeForUpdateOf(ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.FieldExpression
INTERNAL: writes the field for fine-grained pessimistic locking.
writeForUpdateOfFields(ExpressionSQLPrinter, SQLSelectStatement) - Method in class org.eclipse.persistence.internal.expressions.ObjectExpression
INTERNAL: writes the first field from each of the owned tables, used for fine-grained pessimistic locking.
writeFromAttributeIntoRow(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
writeFromAttributeIntoRow(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
writeFromAttributeIntoRow(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
writeFromAttributeIntoRow(UnmarshalRecord, Field, Object, boolean) - Method in interface org.eclipse.persistence.internal.oxm.mappings.TransformationMapping
INTERNAL: Put value into a record keyed on field.
writeFromAttributeIntoRow(UnmarshalRecord, Field, Object, boolean) - Method in class org.eclipse.persistence.oxm.mappings.XMLTransformationMapping
INTERNAL: Put value into a record keyed on field.
writeFromNullObjectIntoRow(AbstractRecord) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.eis.mappings.EISCompositeObjectMapping
INTERNAL: Build the value for the database field and put it in the specified database row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.eis.mappings.EISDirectMapping
INTERNAL: We override this method in order to set the session on the record if the data format is XML.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Get the appropriate attribute value from the object and put it in the appropriate field of the database row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.eis.mappings.EISOneToOneMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Get the attribute value from the object and add the appropriate values to the specified database row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Get the attribute value from the object and add the appropriate values to the specified database row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Get the attribute value from the object and store it in the appropriate field of the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: Build the value for the database field and put it in the specified database row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
 
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
INTERNAL: Write the attribute value from the object to the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
INTERNAL:
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
INTERNAL:
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
INTERNAL:
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
INTERNAL:
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
INTERNAL: Write the attribute value from the object to the row.
writeFromObjectIntoRow(Object, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
 
writeFromObjectIntoRowForShallowInsert(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: This row is built for shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForShallowInsert(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: This row is built for shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForShallowInsert(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: This row is built for shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForShallowInsert(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: This row is built for shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForShallowInsert(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: This row is built for shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForShallowInsert(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: This row is built for shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForShallowInsert(Object, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: This row is built for shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForShallowInsertWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: This row is built for shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForShallowInsertWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: This row is built for shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForShallowInsertWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: This row is built for shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForShallowInsertWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: This row is built for shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForShallowInsertWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: This row is built for shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForShallowInsertWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: This row is built for shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForUpdate(WriteObjectQuery, AbstractRecord) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: If any of the references objects has changed, write out all the keys.
writeFromObjectIntoRowForUpdate(WriteObjectQuery, AbstractRecord) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Get the attribute value from the object and add the changed values to the specified database row.
writeFromObjectIntoRowForUpdate(WriteObjectQuery, AbstractRecord) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL:
writeFromObjectIntoRowForUpdate(WriteObjectQuery, AbstractRecord) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Get the attribute value from the object and add the changed values to the specified database row.
writeFromObjectIntoRowForUpdate(WriteObjectQuery, AbstractRecord) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: If any part of the nested collection has changed, the whole thing is written.
writeFromObjectIntoRowForUpdate(WriteObjectQuery, AbstractRecord) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: If it has changed, build the value for the database field and put it in the specified database row.
writeFromObjectIntoRowForUpdate(WriteObjectQuery, AbstractRecord) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Write the attribute value from the object to the row for update.
writeFromObjectIntoRowForUpdate(WriteObjectQuery, AbstractRecord) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRowForUpdate(WriteObjectQuery, AbstractRecord) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRowForUpdate(WriteObjectQuery, AbstractRecord) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: Write the entire structure into the row as a special type that prints as the constructor.
writeFromObjectIntoRowForUpdateAfterShallowInsert(Object, AbstractRecord, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: This row is built for update after shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForUpdateAfterShallowInsert(Object, AbstractRecord, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: This row is built for update after shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForUpdateAfterShallowInsert(Object, AbstractRecord, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: This row is built for update after shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForUpdateAfterShallowInsert(Object, AbstractRecord, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: This row is built for update after shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForUpdateAfterShallowInsert(Object, AbstractRecord, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: This row is built for update after shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForUpdateAfterShallowInsert(Object, AbstractRecord, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: This row is built for update after shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForUpdateAfterShallowInsert(Object, AbstractRecord, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: This row is built for update after shallow insert which happens in case of bidirectional inserts.
writeFromObjectIntoRowForUpdateBeforeShallowDelete(Object, AbstractRecord, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: This row is built for update before shallow delete which happens in case of bidirectional inserts.
writeFromObjectIntoRowForUpdateBeforeShallowDelete(Object, AbstractRecord, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: This row is built for update before shallow delete which happens in case of bidirectional inserts.
writeFromObjectIntoRowForUpdateBeforeShallowDelete(Object, AbstractRecord, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: This row is built for update before shallow delete which happens in case of bidirectional inserts.
writeFromObjectIntoRowForWhereClause(ObjectLevelModifyQuery, AbstractRecord) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
writeFromObjectIntoRowForWhereClause(ObjectLevelModifyQuery, AbstractRecord) - Method in class org.eclipse.persistence.mappings.ObjectReferenceMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRowForWhereClause(ObjectLevelModifyQuery, AbstractRecord) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRowInternal(Object, AbstractRecord, AbstractSession, boolean) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRowInternal(Object, AbstractRecord, AbstractSession, OneToOneMapping.ShallowMode, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRowWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Get the appropriate attribute value from the object and put it in the appropriate field of the database row.
writeFromObjectIntoRowWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Get the attribute value from the object and add the appropriate values to the specified database row.
writeFromObjectIntoRowWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: A subclass should implement this method if it wants different behavior.
writeFromObjectIntoRowWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Get the attribute value from the object and add the appropriate values to the specified database row.
writeFromObjectIntoRowWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Get the appropriate attribute value from the object and put it in the appropriate field of the database row.
writeFromObjectIntoRowWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: Get the attribute value from the object and add the appropriate values to the specified database row.
writeFromObjectIntoRowWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRowWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRowWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRowWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRowWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeFromObjectIntoRowWithChangeRecord(ChangeRecord, AbstractRecord, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Get a value from the object and set that in the respective field of the row.
writeHeader() - Method in class org.eclipse.persistence.oxm.record.FormattedOutputStreamRecord
INTERNAL
writeHeader() - Method in class org.eclipse.persistence.oxm.record.FormattedWriterRecord
INTERNAL
writeHeader() - Method in class org.eclipse.persistence.oxm.record.MarshalRecord
INTERNAL Writes the header, if appropriate.
writeHeader() - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL
writeHeader() - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
writeHeader() - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL
writeHexString(byte[], Writer) - Static method in class org.eclipse.persistence.internal.helper.Helper
Convert the byte array to a HEX string.
writeIdentityInformation(ObjectOutputStream) - Method in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
INTERNAL: Helper method to writeObject.
writeInsertFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.eis.mappings.EISOneToManyMapping
INTERNAL: Write fields needed for insert into the template for with null values.
writeInsertFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Write fields needed for insert into the template for with null values.
writeInsertFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Write fields needed for insert into the template for with null values.
writeInsertFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeCollectionMapping
INTERNAL: Write fields needed for insert into the template with null values.
writeInsertFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeDirectCollectionMapping
INTERNAL: Write the fields needed for insert into the template with null values.
writeInsertFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractCompositeObjectMapping
INTERNAL: Write fields needed for insert into the template for with null values.
writeInsertFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Write fields needed for insert into the template for with null values.
writeInsertFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractTransformationMapping
INTERNAL: Write fields needed for insert into the template for with null values.
writeInsertFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL: Write fields needed for insert into the template for with null values.
writeInsertFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.OneToOneMapping
INTERNAL: Write fields needed for insert into the template for with null values.
writeInsertFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.NestedTableMapping
INTERNAL: Write fields needed for insert into the template for with null values.
writeInsertFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.structures.ReferenceMapping
INTERNAL: Write fields needed for insert into the template for with null values.
writeInsertFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.VariableOneToOneMapping
INTERNAL: Write fields needed for insert into the template for with null values.
writeInsertIntoTableSql(Writer, DatabaseTable, Collection<DatabaseField>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: May need to override this method if the platform supports temporary tables and the generated sql doesn't work.
writeIntoRowFromPrimaryKeyValues(AbstractRecord, Object, AbstractSession, boolean) - Method in class org.eclipse.persistence.internal.descriptors.ObjectBuilder
Build the row from the primary key values.
writeJoinWhereClause(Writer, String, String, Collection<DatabaseField>, Collection<DatabaseField>, DatasourcePlatform) - Static method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: helper method, don't override.
writeKey(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
 
writeKey(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
writeLineSeperator(AbstractSession, Writer) - Method in class org.eclipse.persistence.tools.schemaframework.TableDefinition
 
writeListSeparator() - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
 
writeListSeparator() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
writeln(Object) - Method in class org.eclipse.persistence.internal.codegen.CodeGenerator
 
writeLOB(DatabaseField, Object, ResultSet, AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Write LOB value - only on Oracle8 and up
writeLOB(DatabaseField, Object, ResultSet, AbstractSession) - Method in class org.eclipse.persistence.platform.database.Oracle8Platform
INTERNAL: Write LOB value - only on Oracle8 and up
writeLocalName(XPathFragment) - Method in interface org.eclipse.persistence.oxm.record.JSONWriterRecord.Output
 
writeLocalName(XPathFragment) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.OutputStreamOutput
 
writeLockField - Variable in class org.eclipse.persistence.descriptors.VersionLockingPolicy
 
writeLockFieldInChildDescriptor(ClassDescriptor) - Static method in exception org.eclipse.persistence.exceptions.DescriptorException
 
writeLockManager - Variable in class org.eclipse.persistence.internal.identitymaps.IdentityMapManager
Used to store the write lock manager used for merging.
WriteLockManager - Class in org.eclipse.persistence.internal.helper
INTERNAL:
WriteLockManager() - Constructor for class org.eclipse.persistence.internal.helper.WriteLockManager
 
writeLockQueued - Variable in class org.eclipse.persistence.internal.sessions.MergeManager
If this variable is not null then the mergemanager is waiting on a particular primary key
writeLockValue - Variable in class org.eclipse.persistence.internal.identitymaps.CacheKey
The writeLock value is being held as an object so that it might contain a number or timestamp.
writeLockValue - Variable in class org.eclipse.persistence.internal.sessions.ObjectChangeSet
 
writeLockValue - Variable in class org.eclipse.persistence.internal.sessions.remote.ObjectDescriptor
A write lock value
writeLockValueIntoRow(ObjectLevelModifyQuery, Object) - Method in class org.eclipse.persistence.descriptors.VersionLockingPolicy
INTERNAL: This method updates the modify row with the old lock value.
writeMessage(String) - Method in class org.eclipse.persistence.logging.DefaultSessionLog
Append the specified message information to the writer.
writeNamespaceSeparator() - Method in interface org.eclipse.persistence.oxm.record.JSONWriterRecord.Output
 
writeNamespaceSeparator() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.OutputStreamOutput
 
writeNestingTabs(Writer) - Method in class org.eclipse.persistence.tools.profiler.PerformanceProfiler
 
writeNullReferenceRow(AbstractRecord) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Write null values for all aggregate fields into the parent row.
writeObject(Object) - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
PUBLIC: Write the object and all of its privately owned parts in the database.
writeObject(Object) - Method in interface org.eclipse.persistence.sessions.DatabaseSession
PUBLIC: Write the object and all of its privately owned parts in the database.
writeObjectNotAllowedInUnitOfWork() - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
WriteObjectQuery - Class in org.eclipse.persistence.queries
Purpose: Used for inserting or updating objects WriteObjectQuery determines whether to perform a insert or an update on the database.
WriteObjectQuery() - Constructor for class org.eclipse.persistence.queries.WriteObjectQuery
 
WriteObjectQuery(Object) - Constructor for class org.eclipse.persistence.queries.WriteObjectQuery
 
WriteObjectQuery(Call) - Constructor for class org.eclipse.persistence.queries.WriteObjectQuery
 
writeOutMappings(XMLRecord, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
 
writeOutMappings(XMLRecord, Object, AbstractSession) - Method in class org.eclipse.persistence.internal.oxm.XMLSequencedObjectBuilder
 
writeParameterMarker(Writer, ParameterExpression, AbstractRecord, DatabaseCall) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
 
writeParameterMarker(Writer, ParameterExpression, AbstractRecord, DatabaseCall) - Method in class org.eclipse.persistence.platform.database.DB2Platform
INTERNAL: DB2 requires casting on certain operations, such as the CONCAT function, and parameterized queries of the form, ":param = :param".
writeParameterMarker(Writer, ParameterExpression, AbstractRecord, DatabaseCall) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
 
writeParameterMarker(Writer, ParameterExpression, AbstractRecord, DatabaseCall) - Method in class org.eclipse.persistence.platform.database.TimesTenPlatform
INTERNAL: TimesTen and requires cast around parameter markers if both operands of certain operators are parameter markers This method generates CAST for parameter markers whose type is correctly identified by the query compiler.
writePartialIntoClones(Object, Object, Object, UnitOfWorkImpl) - Method in class org.eclipse.persistence.descriptors.FetchGroupManager
INTERNAL: Write data of the partially fetched object into the working and backup clones
writePrefixMappings() - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord.OutputStreamRecordContentHandler
 
writePrefixMappings() - Method in class org.eclipse.persistence.oxm.record.WriterRecord.WriterRecordContentHandler
 
writer - Variable in class org.eclipse.persistence.internal.expressions.ExpressionJavaPrinter
 
writer - Variable in class org.eclipse.persistence.internal.expressions.ExpressionSQLPrinter
 
writer - Variable in class org.eclipse.persistence.logging.AbstractSessionLog
Represents the writer that will receive the formatted log entries
writer - Variable in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
writeResultFromCharEscapeHandler(String, boolean) - Method in interface org.eclipse.persistence.oxm.record.JSONWriterRecord.Output
 
writeResultFromCharEscapeHandler(String, boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord.OutputStreamOutput
 
WriterRecord - Class in org.eclipse.persistence.oxm.record
Use this type of MarshalRecord when the marshal target is a Writer and the XML should not be formatted with carriage returns or indenting.
WriterRecord() - Constructor for class org.eclipse.persistence.oxm.record.WriterRecord
 
WriterRecord.WriterRecordContentHandler - Class in org.eclipse.persistence.oxm.record
This class will typically be used in conjunction with an XMLFragmentReader.
writesCompleted() - Method in class org.eclipse.persistence.internal.sessions.AbstractSession
INTERNAL: This method notifies the accessor that a particular sets of writes has completed.
writesCompleted() - Method in class org.eclipse.persistence.internal.sessions.UnitOfWorkImpl
INTERNAL: This method notifies the accessor that a particular sets of writes has completed.
writesCompleted() - Method in class org.eclipse.persistence.sessions.broker.SessionBroker
INTERNAL: This method notifies the accessor that a particular sets of writes has completed.
writesCompleted(AbstractSession) - Method in interface org.eclipse.persistence.internal.databaseaccess.Accessor
This method will be called after a series of writes have been issued to mark where a particular set of writes has completed.
writesCompleted(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabaseAccessor
This method will be called after a series of writes have been issued to mark where a particular set of writes has completed.
writesCompleted(AbstractSession) - Method in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
This method will be called after a series of writes have been issued to mark where a particular set of writes has completed.
writeSelect(Writer, SQLCall, String, SQLCall, DatasourcePlatform) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
writeSelect(Writer, SQLCall, String, SQLCall, DatasourcePlatform) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
writeSeparator() - Method in class org.eclipse.persistence.logging.DefaultSessionLog
Append the separator string to the writer.
writeSeparator() - Method in class org.eclipse.persistence.oxm.record.JSONFormattedWriterRecord
 
writeSeparator() - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
 
writeShouldreadWholeDocument(NonreflectiveMethodDefinition, String, DatabaseMapping) - Method in class org.eclipse.persistence.internal.sessions.factories.DirectToXMLTypeMappingHelper
Write the Project.class code for the XMLType property.
writeShouldreadWholeDocument(NonreflectiveMethodDefinition, String, DatabaseMapping) - Method in class org.eclipse.persistence.sessions.factories.OracleDirectToXMLTypeMappingHelper
Write the Project.class code for the XMLType property.
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLFragmentMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in interface org.eclipse.persistence.oxm.mappings.XMLMapping
INTERNAL: A method that marshals a single value to the provided Record based on this mapping's XPath.
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLTransformationMapping
 
writeSingleValue(Object, Object, XMLRecord, AbstractSession) - Method in class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
writeSingleValue(Object, Object, XML_RECORD, ABSTRACT_SESSION) - Method in interface org.eclipse.persistence.internal.oxm.mappings.Mapping
 
writeStatementsCount - Variable in class org.eclipse.persistence.internal.databaseaccess.DatasourceAccessor
Keep track of the number of the write statement that being executed.
writeSubexpressionsTo(BufferedWriter, int) - Method in class org.eclipse.persistence.expressions.Expression
INTERNAL: Used in SQL printing.
writeSubexpressionsTo(BufferedWriter, int) - Method in class org.eclipse.persistence.internal.expressions.CompoundExpression
INTERNAL: Used for toString for debugging only.
writeSubexpressionsTo(BufferedWriter, int) - Method in class org.eclipse.persistence.internal.expressions.DataExpression
Print the base for debuggin purposes.
writeSubexpressionsTo(BufferedWriter, int) - Method in class org.eclipse.persistence.internal.expressions.FunctionExpression
INTERNAL: Used in SQL printing.
writeSubexpressionsTo(BufferedWriter, int) - Method in class org.eclipse.persistence.internal.expressions.ParameterExpression
Print the base for debuggin purposes.
writeSubexpressionsTo(BufferedWriter, int) - Method in class org.eclipse.persistence.internal.expressions.SubSelectExpression
INTERNAL: Used in SQL printing.
writeSubexpressionsTo(BufferedWriter, int) - Method in class org.eclipse.persistence.internal.expressions.TreatAsExpression
 
writeTableCreationSuffix(Writer, String) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: Write used on all table creation statements generated from the DefaultTableGenerator with a session using this project (DDL generation).
writeThrowsClause(CodeGenerator) - Method in class org.eclipse.persistence.internal.codegen.MethodDefinition
 
writeToEventWriter(Node, String, String, XMLEventWriter) - Method in class org.eclipse.persistence.internal.oxm.record.DomToXMLEventWriter
 
writeToEventWriterMethod - Static variable in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
writeToRowFromAggregate(AbstractRecord, Object, Object, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Write the aggregate values into the parent row.
writeToRowFromAggregateForShallowInsert(AbstractRecord, Object, Object, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Write the aggregate values into the parent row for shallow insert.
writeToRowFromAggregateForUpdate(AbstractRecord, WriteObjectQuery, Object) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Build and return a database row built with the changed values from the specified attribute value.
writeToRowFromAggregateForUpdateAfterShallowInsert(AbstractRecord, Object, Object, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Write the aggregate values into the parent row for update after shallow insert.
writeToRowFromAggregateForUpdateBeforeShallowDelete(AbstractRecord, Object, Object, AbstractSession, DatabaseTable) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Write the aggregate values into the parent row for update before shallow delete.
writeToRowFromAggregateWithChangeRecord(AbstractRecord, ChangeRecord, ObjectChangeSet, AbstractSession, DatabaseMapping.WriteType) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
INTERNAL: Build and return a database row built with the values from the specified attribute value.
writeToStream(Node, String, String, XMLStreamWriter) - Method in class org.eclipse.persistence.internal.oxm.record.DomToXMLStreamWriter
 
writeToStreamMethod - Static variable in class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
WriteTransformer - Annotation Type in org.eclipse.persistence.annotations
Annotation for org.eclipse.persistence.mappings.TransformationMapping.
writeTransformerClassDoesntImplementFieldTransformer(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Cause: WriteTransformer for the specified attribute of the specified class and specified column doesn't implement the required interface FieldTransforer.
writeTransformerHasBothClassAndMethod(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: WriteTransformer for the specified attribute of the specified class and specified xml-path specifies both class and method.
writeTransformerHasBothClassAndMethod(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Cause: WriteTransformer for the specified attribute of the specified class and specified column specifies both class and method.
writeTransformerHasNeitherClassNorMethod(String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: WriteTransformer for the specified attribute of the specified class and specified xml-path specifies neither class nor method.
writeTransformerHasNeitherClassNorMethod(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Cause: WriteTransformer for the specified attribute of the specified class and specified column specifies neither class nor method.
writeTransformerHasNoColumnName(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
PUBLIC: Cause: WriteTransformer for the specified attribute of the specified class has no column specified, of the specified column doesn't have name.
writeTransformerHasNoXmlPath(String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
PUBLIC: Cause: WriteTransformer for the specified attribute of the specified class has no xml-path specified, or the specified xml-path is invalid.
WriteTransformers - Annotation Type in org.eclipse.persistence.annotations
An optional annotation for org.eclipse.persistence.mappings.TransformationMapping.
writeType(Writer, DatabaseField, DatasourcePlatform) - Static method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
writeType(String) - Method in class org.eclipse.persistence.internal.codegen.CodeGenerator
Write the type checking if its package is required.
writeUniqueFieldName(Writer, DatabaseField, DatasourcePlatform) - Static method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
writeUpdateFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.AggregateObjectMapping
 
writeUpdateFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.DatabaseMapping
INTERNAL: Write fields needed for update into the template for with null values.
writeUpdateFieldsIntoRow(AbstractRecord, AbstractSession) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
INTERNAL: Write fields needed for update into the template for with null values.
writeUpdateOriginalFromTempTableSql(Writer, DatabaseTable, Collection<DatabaseField>, Collection<DatabaseField>) - Method in class org.eclipse.persistence.internal.databaseaccess.DatabasePlatform
INTERNAL: May need to override this method if the platform supports temporary tables and the generated sql doesn't work.
writeUpdateOriginalFromTempTableSql(Writer, DatabaseTable, Collection<DatabaseField>, Collection<DatabaseField>) - Method in class org.eclipse.persistence.platform.database.DerbyPlatform
INTERNAL: May need to override this method if the platform supports temporary tables and the generated sql doesn't work.
writeUpdateOriginalFromTempTableSql(Writer, DatabaseTable, Collection<DatabaseField>, Collection<DatabaseField>) - Method in class org.eclipse.persistence.platform.database.H2Platform
H2 does not allow using () in the update if only one field.
writeUpdateOriginalFromTempTableSql(Writer, DatabaseTable, Collection<DatabaseField>, Collection<DatabaseField>) - Method in class org.eclipse.persistence.platform.database.HSQLPlatform
INTERNAL: HSQL does not allow multiple fields to be set as a list, so each field needs to be set one by one.
writeUpdateOriginalFromTempTableSql(Writer, DatabaseTable, Collection<DatabaseField>, Collection<DatabaseField>) - Method in class org.eclipse.persistence.platform.database.Informix11Platform
Overrides DatabasePlatform.writeUpdateOriginalFromTempTableSql(Writer, DatabaseTable, Collection, Collection) to ensure that a SET clause that is supposed to set a value for only one column does not wrap that column name in parentheses.
writeUpdateOriginalFromTempTableSql(Writer, DatabaseTable, Collection<DatabaseField>, Collection<DatabaseField>) - Method in class org.eclipse.persistence.platform.database.MySQLPlatform
INTERNAL: Writes MySQL specific SQL for accessing temp tables for update-all queries.
writeUpdateOriginalFromTempTableSql(Writer, DatabaseTable, Collection<DatabaseField>, Collection<DatabaseField>) - Method in class org.eclipse.persistence.platform.database.PostgreSQLPlatform
INTERNAL: May need to override this method if the platform supports temporary tables and the generated sql doesn't work.
writeUpdateOriginalFromTempTableSql(Writer, DatabaseTable, Collection<DatabaseField>, Collection<DatabaseField>) - Method in class org.eclipse.persistence.platform.database.SQLServerPlatform
INTERNAL:
writeUpdateOriginalFromTempTableSql(Writer, DatabaseTable, Collection<DatabaseField>, Collection<DatabaseField>) - Method in class org.eclipse.persistence.platform.database.SybasePlatform
INTERNAL:
writeUpdateOriginalTable(AbstractSession, Writer) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatementForTempTable
 
writeUpdateOriginalTable(AbstractSession, Writer) - Method in class org.eclipse.persistence.internal.expressions.SQLModifyAllStatementForTempTable
 
writeUpdateOriginalTable(AbstractSession, Writer) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForTempTable
 
writeValue(Object, QName, boolean) - Method in class org.eclipse.persistence.oxm.record.JsonRecord
 
writeValue(String) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL:
writeValue(String, boolean) - Method in class org.eclipse.persistence.oxm.record.JSONWriterRecord
INTERNAL:
writeValue(String, boolean) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL:
writeValue(String, boolean, boolean, OutputStream) - Method in class org.eclipse.persistence.oxm.record.OutputStreamRecord
INTERNAL:
writeValue(String, boolean, StringBuilder) - Method in class org.eclipse.persistence.oxm.record.WriterRecord
INTERNAL:
writeValueIntoRow(AbstractRecord, DatabaseField, Object) - Method in class org.eclipse.persistence.eis.mappings.EISDirectMapping
 
writeValueIntoRow(AbstractRecord, DatabaseField, Object) - Method in class org.eclipse.persistence.mappings.DirectToFieldMapping
 
writeValueIntoRow(AbstractRecord, DatabaseField, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractColumnMapping
INTERNAL:
writeValueIntoRow(AbstractRecord, DatabaseField, Object) - Method in class org.eclipse.persistence.mappings.foundation.AbstractDirectMapping
 
writeValueIntoRow(AbstractRecord, DatabaseField, Object) - Method in class org.eclipse.persistence.mappings.MultitenantPrimaryKeyMapping
INTERNAL:
writeValueIntoRow(AbstractRecord, DatabaseField, Object) - Method in class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
 
writeVar(Writer, DatabaseField, DatasourcePlatform) - Static method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatementForOracleAnonymousBlock
 
writeWhere(Writer, SQLCall, SQLCall) - Method in class org.eclipse.persistence.internal.expressions.SQLDeleteAllStatement
 
writeWhere(Writer, SQLCall, SQLCall) - Method in class org.eclipse.persistence.internal.expressions.SQLUpdateAllStatement
 
writeXsiTypeAttribute(Descriptor, String, String, String, boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
writeXsiTypeAttribute(Descriptor, String, String, String, boolean) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
writeXsiTypeAttribute(Descriptor, String, String, String, boolean) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
writeXsiTypeAttribute(Descriptor, String, String, String, boolean) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL
writeXsiTypeAttribute(Descriptor, XMLSchemaReference, boolean) - Method in interface org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecord
 
writeXsiTypeAttribute(Descriptor, XMLSchemaReference, boolean) - Method in class org.eclipse.persistence.internal.oxm.record.AbstractMarshalRecordImpl
 
writeXsiTypeAttribute(Descriptor, XMLSchemaReference, boolean) - Method in class org.eclipse.persistence.oxm.record.ValidatingMarshalRecord
 
writeXsiTypeAttribute(Descriptor, XMLSchemaReference, boolean) - Method in class org.eclipse.persistence.oxm.record.XMLRecord
INTERNAL
WRONG_CHANGE_EVENT - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
WRONG_COLLECTION_CHANGE_EVENT_TYPE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
WRONG_OBJECT_REGISTERED - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
WRONG_PROPERTY_NAME_IN_CHANGE_EVENT - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
WRONG_PROPERTY_VALUE_TYPE - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
WRONG_SEQUENCE_TYPE - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
WRONG_SESSION_TYPE_EXCEPTION - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
WRONG_USAGE_OF_SET_CUSTOM_SQL_ARGUMENT_TYPE_METOD - Static variable in exception org.eclipse.persistence.exceptions.ValidationException
 
WRONG_VALUE_FOR_PROPERTY - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
WRONG_WEAVING_PROPERTY_VALUE - Static variable in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
wrongChangeEvent(Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
wrongCollectionChangeEventType(int) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
wrongObjectRegistered(Object, Object) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
wrongPropertyNameInChangeEvent(Object, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
wrongPropertyValueType(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
wrongSequenceType(String, String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
wrongSessionTypeException(String, String, Exception) - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 
wrongUsageOfSetCustomArgumentTypeMethod(String) - Static method in exception org.eclipse.persistence.exceptions.ValidationException
 
wrongValueForProperty(String, String, Class<?>) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when trying to set a property to value that is an unsupported conversion
wrongWeavingPropertyValue() - Static method in exception org.eclipse.persistence.exceptions.EntityManagerSetupException
 

X

XDK_PLATFORM_CLASS_NAME - Static variable in class org.eclipse.persistence.platform.xml.XMLPlatformFactory
 
XJB_NOT_SOURCE - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
xjbNotSource() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
XJC_BINDING_ERROR - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
xjcBindingError() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception is thrown if XJC was unable to generate a CodeModel.
XML - Static variable in annotation type org.eclipse.persistence.annotations.Convert
Constant name for the reserved XML converter.
XML - Static variable in class org.eclipse.persistence.eis.EISDescriptor
 
XML_BINARY_COLLECTION_MAPPING_CLASS - Static variable in class org.eclipse.persistence.internal.sessions.factories.MissingDescriptorListener
 
XML_BINARY_MAPPING_CLASS - Static variable in class org.eclipse.persistence.internal.sessions.factories.MissingDescriptorListener
 
XML_CONVERSION_TIME_SUFFIX - Static variable in class org.eclipse.persistence.internal.oxm.OXMSystemProperties
Add suffix/decimal part to time part/seconds in case of conversion from supported date/time formats into String.
XML_GREGORIAN_CALENDAR - Static variable in class org.eclipse.persistence.internal.core.helper.CoreClassConstants
 
XML_INTERACTION_CLASS - Static variable in class org.eclipse.persistence.internal.sessions.factories.MissingDescriptorListener
 
XML_INTERACTION_IS_VALID_ONLY - Static variable in exception org.eclipse.persistence.eis.EISException
 
XML_MIME_URL - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
XML_NAMESPACE_PREFIX - Static variable in class org.eclipse.persistence.oxm.XMLConstants
 
XML_NAMESPACE_SCHEMA_LOCATION - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
XML_NAMESPACE_URL - Static variable in class org.eclipse.persistence.oxm.XMLConstants
 
XML_PLATFORM_CLASS_NOT_FOUND - Static variable in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
XML_PLATFORM_COULD_NOT_CREATE_DOCUMENT - Static variable in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
XML_PLATFORM_COULD_NOT_INSTANTIATE - Static variable in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
XML_PLATFORM_INVALID_TYPE - Static variable in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
XML_PLATFORM_INVALID_XPATH - Static variable in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
XML_PLATFORM_PARSE_EXCEPTION - Static variable in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
XML_PLATFORM_PARSER_ERROR_RESOLVING_XML_SCHEMA - Static variable in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
XML_PLATFORM_PARSER_FILE_NOT_FOUND_EXCEPTION - Static variable in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
XML_PLATFORM_PARSER_SAX_PARSE_EXCEPTION - Static variable in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
XML_PLATFORM_PROPERTY - Static variable in class org.eclipse.persistence.platform.xml.XMLPlatformFactory
 
XML_PLATFORM_TRANSFORM_EXCEPTION - Static variable in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
XML_PLATFORM_VALIDATION_EXCEPTION - Static variable in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
XML_SCHEMA_PARSING_ERROR - Static variable in exception org.eclipse.persistence.exceptions.SessionLoaderException
 
XML_TYPE_CLASS - Static variable in class org.eclipse.persistence.internal.sessions.factories.MissingDescriptorListener
 
XMLAbstractAnyMapping - Class in org.eclipse.persistence.oxm.mappings
Purpose: An abstract superclass for XMLAnyObjectMapping and XMLAnyCollectionMapping.
XMLAbstractAnyMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLAbstractAnyMapping
 
XmlAccessMethods - Annotation Type in org.eclipse.persistence.oxm.annotations
Purpose:This annotation allows the userTo specify accessor methods for a given property.
XMLAccessor - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLAccessor() - Constructor for class org.eclipse.persistence.internal.oxm.XMLAccessor
Default Constructor.
XMLAnyAttributeMapping - Class in org.eclipse.persistence.oxm.mappings
Purpose:The XMLAnyAttributeMapping is used to map to an attribute in an object to any xml attributes contained on a specific element in the XML Document.
XMLAnyAttributeMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLAnyAttributeMapping
 
XMLAnyAttributeMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLAnyAttributeMappingNodeValue(AnyAttributeMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLAnyAttributeMappingNodeValue
 
XMLAnyCollectionMapping - Class in org.eclipse.persistence.oxm.mappings
Any collection XML mappings map an attribute that contains a heterogenous collection of objects to multiple XML elements.
XMLAnyCollectionMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLAnyCollectionMapping
 
XMLAnyCollectionMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLAnyCollectionMappingNodeValue(AnyCollectionMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLAnyCollectionMappingNodeValue
 
XMLANYELEMENT_ALREADY_SET - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
xmlAnyElementAlreadySet(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception should be used when an attempt is made to set an XmlAnyElement property when one has already been set.
XMLAnyObjectMapping - Class in org.eclipse.persistence.oxm.mappings
Any object XML mappings map an attribute that contains a single object to an XML element.
XMLAnyObjectMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLAnyObjectMapping
 
XMLAnyObjectMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLAnyObjectMappingNodeValue(AnyObjectMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLAnyObjectMappingNodeValue
 
XMLAttachmentMarshaller - Interface in org.eclipse.persistence.oxm.attachment
Purpose: Provides an interface through which EclipseLink can allow a user to do special handling for Binary Data.
XMLAttachmentUnmarshaller - Interface in org.eclipse.persistence.oxm.attachment
Purpose: Provides an interface through which EclipseLink can allow a user to do special handling for Binary Data.
XMLBinaryAttachmentHandler - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLBinaryAttachmentHandler(UnmarshalRecord, NodeValue, Mapping, XMLConverterMapping, boolean) - Constructor for class org.eclipse.persistence.internal.oxm.XMLBinaryAttachmentHandler
 
XMLBinaryDataCollectionMapping - Class in org.eclipse.persistence.oxm.mappings
Purpose:Provide a mapping for a collection of binary data values that can be treated as either inline binary values or as an attachment.
XMLBinaryDataCollectionMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLBinaryDataCollectionMapping
 
XMLBinaryDataCollectionMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLBinaryDataCollectionMappingNodeValue(BinaryDataCollectionMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLBinaryDataCollectionMappingNodeValue
 
XMLBinaryDataHelper - Class in org.eclipse.persistence.internal.oxm
 
XMLBinaryDataHelper() - Constructor for class org.eclipse.persistence.internal.oxm.XMLBinaryDataHelper
 
XMLBinaryDataHelper.EncodedData - Class in org.eclipse.persistence.internal.oxm
INTERNAL
XMLBinaryDataMapping - Class in org.eclipse.persistence.oxm.mappings
Purpose:Provide a mapping for binary data that can be treated as either inline or as an attachment.
XMLBinaryDataMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLBinaryDataMapping
 
XMLBinaryDataMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLBinaryDataMappingNodeValue(BinaryDataMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLBinaryDataMappingNodeValue
 
XMLBinder - Class in org.eclipse.persistence.oxm
PUBLIC:
XMLBinder(XMLContext) - Constructor for class org.eclipse.persistence.oxm.XMLBinder
 
XMLBinder(XMLContext, XMLMarshaller, XMLUnmarshaller) - Constructor for class org.eclipse.persistence.oxm.XMLBinder
 
XMLBinderPolicyConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.login
 
XMLBinderPolicyConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.login.XMLBinderPolicyConfig
Default constructor.
XmlCDATA - Annotation Type in org.eclipse.persistence.oxm.annotations
Wrap the value inside a CDATA section.
XMLChoiceCollectionMapping - Class in org.eclipse.persistence.oxm.mappings
PUBLIC:
XMLChoiceCollectionMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLChoiceCollectionMapping
 
XMLChoiceCollectionMappingMarshalNodeValue - Class in org.eclipse.persistence.internal.oxm
 
XMLChoiceCollectionMappingMarshalNodeValue(ChoiceCollectionMapping, Field) - Constructor for class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingMarshalNodeValue
 
XMLChoiceCollectionMappingUnmarshalNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLChoiceCollectionMappingUnmarshalNodeValue(ChoiceCollectionMapping, Field) - Constructor for class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
XMLChoiceCollectionMappingUnmarshalNodeValue(ChoiceCollectionMapping, Field, Mapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLChoiceCollectionMappingUnmarshalNodeValue
 
XMLChoiceFieldToClassAssociation<CONVERTER extends CoreConverter,​XML_FIELD extends Field> - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLChoiceFieldToClassAssociation() - Constructor for class org.eclipse.persistence.internal.oxm.XMLChoiceFieldToClassAssociation
 
XMLChoiceFieldToClassAssociation(XML_FIELD, String) - Constructor for class org.eclipse.persistence.internal.oxm.XMLChoiceFieldToClassAssociation
 
XMLChoiceObjectMapping - Class in org.eclipse.persistence.oxm.mappings
PUBLIC:
XMLChoiceObjectMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLChoiceObjectMapping
 
XMLChoiceObjectMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLChoiceObjectMappingNodeValue(ChoiceObjectMapping, Field) - Constructor for class org.eclipse.persistence.internal.oxm.XMLChoiceObjectMappingNodeValue
 
XmlClassExtractor - Annotation Type in org.eclipse.persistence.oxm.annotations
A ClassExtractor allows for a user defined class indicator in place of using xsi:type.
XMLCollectionReferenceMapping - Class in org.eclipse.persistence.oxm.mappings
TopLink OXM version of a 1-M mapping.
XMLCollectionReferenceMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLCollectionReferenceMapping
PUBLIC: The default constructor initializes the sourceToTargetKeyFieldAssociations and sourceToTargetKeys data structures.
XMLCollectionReferenceMappingMarshalNodeValue - Class in org.eclipse.persistence.internal.oxm
 
XMLCollectionReferenceMappingMarshalNodeValue(CollectionReferenceMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingMarshalNodeValue
 
XMLCollectionReferenceMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLCollectionReferenceMappingNodeValue(CollectionReferenceMapping, Field) - Constructor for class org.eclipse.persistence.internal.oxm.XMLCollectionReferenceMappingNodeValue
This constructor sets the XMLCollectionReferenceMapping and XMLField members to the provided values.
XMLComparer - Class in org.eclipse.persistence.platform.xml
This class is used to compare if two DOM nodes are equal.
XMLComparer() - Constructor for class org.eclipse.persistence.platform.xml.XMLComparer
 
XMLCompositeCollectionMapping - Class in org.eclipse.persistence.oxm.mappings
Composite collection XML mappings map an attribute that contains a homogeneous collection of objects to multiple XML elements.
XMLCompositeCollectionMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLCompositeCollectionMapping
 
XMLCompositeCollectionMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLCompositeCollectionMappingNodeValue(CompositeCollectionMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
XMLCompositeCollectionMappingNodeValue(CompositeCollectionMapping, boolean) - Constructor for class org.eclipse.persistence.internal.oxm.XMLCompositeCollectionMappingNodeValue
 
XMLCompositeDirectCollectionMapping - Class in org.eclipse.persistence.oxm.mappings
Composite direct collection XML mappings map a collection of simple types (String, Number, Date, etc.) to and from a sequence of composite XML nodes.
XMLCompositeDirectCollectionMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLCompositeDirectCollectionMapping
 
XMLCompositeDirectCollectionMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLCompositeDirectCollectionMappingNodeValue(DirectCollectionMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLCompositeDirectCollectionMappingNodeValue
 
XMLCompositeObjectMapping - Class in org.eclipse.persistence.oxm.mappings
Composite object XML mappings represent a relationship between two classes.
XMLCompositeObjectMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLCompositeObjectMapping
 
XMLCompositeObjectMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLCompositeObjectMappingNodeValue(CompositeObjectMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
XMLCompositeObjectMappingNodeValue(CompositeObjectMapping, boolean) - Constructor for class org.eclipse.persistence.internal.oxm.XMLCompositeObjectMappingNodeValue
 
XMLConstants - Class in org.eclipse.persistence.oxm
XMLConstants maintains a list of useful XML constants.
XMLConstants() - Constructor for class org.eclipse.persistence.oxm.XMLConstants
 
XMLContainerMapping - Interface in org.eclipse.persistence.internal.oxm.mappings
This interface represents behaviour that is common to all XML mappings that involve containers: Collection, Map, Arrays, etc.
XMLContext - Class in org.eclipse.persistence.oxm
An XMLContext is created based on EclipseLink sessions or projects and can then used to create instances of XMLMarshaller, XMLUnmarshaller and XMLValidator.
XMLContext(String) - Constructor for class org.eclipse.persistence.oxm.XMLContext
Create a new XMLContext based on the specified session name or list of session names
XMLContext(String, ClassLoader) - Constructor for class org.eclipse.persistence.oxm.XMLContext
Create a new XMLContext based on the specified session name or list of session names
XMLContext(String, ClassLoader, String) - Constructor for class org.eclipse.persistence.oxm.XMLContext
Create a new XMLContext based on passed in session names, classloader and session meta XML.
XMLContext(String, String) - Constructor for class org.eclipse.persistence.oxm.XMLContext
Create a new XMLContext based on passed in session names and session meta XML.
XMLContext(Collection) - Constructor for class org.eclipse.persistence.oxm.XMLContext
 
XMLContext(Collection, ClassLoader) - Constructor for class org.eclipse.persistence.oxm.XMLContext
 
XMLContext(Project) - Constructor for class org.eclipse.persistence.oxm.XMLContext
Create a new XMLContext based on the specified project
XMLContext(Project, ClassLoader) - Constructor for class org.eclipse.persistence.oxm.XMLContext
Create a new XMLContext based on the specified Project and ClassLoader.
XMLContext(Project, ClassLoader, Collection<SessionEventListener>) - Constructor for class org.eclipse.persistence.oxm.XMLContext
Create a new XMLContext based on the specified Project and ClassLoader.
XMLContext(Project, ClassLoader, SessionEventListener) - Constructor for class org.eclipse.persistence.oxm.XMLContext
Create a new XMLContext based on the specified Project and ClassLoader.
XMLConversionException - Exception in org.eclipse.persistence.exceptions
Purpose: XML conversion exceptions are raised for any problem when converting Java types to/from XML.
XMLConversionException(String) - Constructor for exception org.eclipse.persistence.exceptions.XMLConversionException
 
XMLConversionException(String, Exception) - Constructor for exception org.eclipse.persistence.exceptions.XMLConversionException
 
XMLConversionExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL:
XMLConversionExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.XMLConversionExceptionResource
Default constructor.
xmlConversionManager - Variable in class org.eclipse.persistence.eis.EISPlatform
For XML usage, an XMLConversionManager instance is required
XMLConversionManager - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLConversionManager() - Constructor for class org.eclipse.persistence.internal.oxm.XMLConversionManager
 
XMLConversionPair - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLConversionPair() - Constructor for class org.eclipse.persistence.internal.oxm.XMLConversionPair
 
XMLConversionPair(QName, String) - Constructor for class org.eclipse.persistence.internal.oxm.XMLConversionPair
 
xmlConversionTimeSuffix - Static variable in class org.eclipse.persistence.internal.oxm.OXMSystemProperties
 
XMLConverter - Interface in org.eclipse.persistence.oxm.mappings.converters
Purpose: Conversion interface to allow conversion between object and data types.
XMLConverterAdapter - Class in org.eclipse.persistence.oxm.mappings.converters
 
XMLConverterAdapter() - Constructor for class org.eclipse.persistence.oxm.mappings.converters.XMLConverterAdapter
 
XMLConverterMapping<MARSHALLER extends Marshaller,​SESSION extends CoreSession,​UNMARSHALLER extends Unmarshaller> - Interface in org.eclipse.persistence.internal.oxm.mappings
 
XmlCustomizer - Annotation Type in org.eclipse.persistence.oxm.annotations
The XmlCustomizer annotation is used to specify a class that implements the org.eclipse.persistence.config.DescriptorCustomizer interface and is to run against a class descriptor after all metadata processing has been completed.
XMLDescriptor - Class in org.eclipse.persistence.oxm
Use an XML project for nontransactional, nonpersistent (in-memory) conversions between Java objects and XML documents.
XMLDescriptor() - Constructor for class org.eclipse.persistence.oxm.XMLDescriptor
PUBLIC: Return a new XMLDescriptor.
XMLDirectMapping - Class in org.eclipse.persistence.oxm.mappings
XML Direct Mappings map a Java attribute directly to XML attribute or text node.
XMLDirectMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLDirectMapping
 
XMLDirectMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLDirectMappingNodeValue(DirectMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLDirectMappingNodeValue
 
XmlDiscriminatorNode - Annotation Type in org.eclipse.persistence.oxm.annotations
The XmlDiscriminatorNode annotation is used to specify the class indicator field name when using inheritance.
XmlDiscriminatorValue - Annotation Type in org.eclipse.persistence.oxm.annotations
The XmlDiscriminatorValue annotation is used to specify the class indicator for a given type when using inheritance.
XmlElementNillable - Annotation Type in org.eclipse.persistence.oxm.annotations
Purpose: Provide a means of setting nillable on type and package level, which is not possible with standard XmlElement annotation.
XmlElementsJoinNodes - Annotation Type in org.eclipse.persistence.oxm.annotations
XmlElementsJoinNodes is used in conjunction with XmlElements in order to specify the key references for the targets of the XmlElements annotation.
XMLEntry - Class in org.eclipse.persistence.oxm.record
INTERNAL:
XMLEntry() - Constructor for class org.eclipse.persistence.oxm.record.XMLEntry
 
XMLEventReaderInputSource - Class in org.eclipse.persistence.internal.oxm.record
This class is used to expose an XMLEventReader as an InputSource.
XMLEventReaderInputSource(XMLEventReader) - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLEventReaderInputSource
 
XMLEventReaderReader - Class in org.eclipse.persistence.internal.oxm.record
Convert and XMLEventReader into SAX events.
XMLEventReaderReader() - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLEventReaderReader
 
XMLEventReaderReader(Unmarshaller) - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLEventReaderReader
 
XMLEventWriterRecord - Class in org.eclipse.persistence.oxm.record
 
XMLEventWriterRecord(XMLEventWriter) - Constructor for class org.eclipse.persistence.oxm.record.XMLEventWriterRecord
 
xmlField - Variable in class org.eclipse.persistence.internal.oxm.XMLChoiceFieldToClassAssociation
 
XMLField - Class in org.eclipse.persistence.oxm
TopLink XML mappings make use of XMLFields based on XPath statements to find the relevant data in an XML document.
XMLField() - Constructor for class org.eclipse.persistence.oxm.XMLField
Default constructor, create a new XMLField
XMLField(String) - Constructor for class org.eclipse.persistence.oxm.XMLField
Default constructor, create a new XMLField based on the specified xPath
XMLFileSequenceConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.sequencing
INTERNAL:
XMLFileSequenceConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.sequencing.XMLFileSequenceConfig
 
XMLFragmentCollectionMapping - Class in org.eclipse.persistence.oxm.mappings
Purpose: This mapping provides a means to keep a part of the xml tree as a collection of DOM elements.
XMLFragmentCollectionMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLFragmentCollectionMapping
 
XMLFragmentCollectionMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLFragmentCollectionMappingNodeValue(FragmentCollectionMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLFragmentCollectionMappingNodeValue
 
XMLFragmentMapping - Class in org.eclipse.persistence.oxm.mappings
Purpose: This mapping provides a means to keep a part of the xml tree as a DOM element.
XMLFragmentMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLFragmentMapping
 
XMLFragmentMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLFragmentMappingNodeValue(FragmentMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLFragmentMappingNodeValue
 
XMLFragmentReader - Class in org.eclipse.persistence.internal.oxm.record
Internal:
XMLFragmentReader(NamespaceResolver) - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLFragmentReader
 
XMLHelper - Class in org.eclipse.persistence.internal.helper
 
XMLHelper() - Constructor for class org.eclipse.persistence.internal.helper.XMLHelper
 
XmlIDExtension - Annotation Type in org.eclipse.persistence.oxm.annotations
Purpose: Provide a way to allow properties with XmlID annotation have different type than java.lang.String.
XMLInlineBinaryHandler - Class in org.eclipse.persistence.internal.oxm
 
XMLInlineBinaryHandler(UnmarshalRecord, NodeValue, Mapping, XMLConverterMapping, boolean) - Constructor for class org.eclipse.persistence.internal.oxm.XMLInlineBinaryHandler
 
XMLInteraction - Class in org.eclipse.persistence.eis.interactions
Defines the specification for a call to a JCA interaction that uses XML.
XMLInteraction() - Constructor for class org.eclipse.persistence.eis.interactions.XMLInteraction
Default constructor.
xmlInteractionIsValidOnly(String) - Static method in exception org.eclipse.persistence.eis.EISException
 
XmlInverseReference - Annotation Type in org.eclipse.persistence.oxm.annotations
This annotation is used to map a back-pointer during the unmarshal operation.
XMLInverseReferenceMapping - Class in org.eclipse.persistence.oxm.mappings
This mapping is used to map a back-pointer.
XMLInverseReferenceMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLInverseReferenceMapping
 
XmlIsSetNullPolicy - Annotation Type in org.eclipse.persistence.oxm.annotations
Purpose: Provide a means of using annotations to customise the handling of null values and their xml representation.
XmlJoinNode - Annotation Type in org.eclipse.persistence.oxm.annotations
XmlJoinNode is used in conjunction with XmlKey to specify a reference mapping.
XmlJoinNodes - Annotation Type in org.eclipse.persistence.oxm.annotations
XmlJoinNodes is a holder for multiple XmlJoinNode annotations.
XmlKey - Annotation Type in org.eclipse.persistence.oxm.annotations
XmlKey is used to mark a property as a key, to be referenced using a key-based mapping via XmlJoinNode.
XMLListConverter - Class in org.eclipse.persistence.oxm.mappings.converters
Purpose: Provides an implementation of Converter that can be used to convert a collection of Objects into a space separated list of Strings and back.
XMLListConverter() - Constructor for class org.eclipse.persistence.oxm.mappings.converters.XMLListConverter
 
XmlLocation - Annotation Type in org.eclipse.persistence.oxm.annotations
XmlLocation can be used on a property of type Locator, to provide information about the XML location (line and column number, source location) that the owning object was unmarshalled from.
XMLLogFormatter - Class in org.eclipse.persistence.logging
Format a TopLink LogRecord into a standard XML format.
XMLLogFormatter() - Constructor for class org.eclipse.persistence.logging.XMLLogFormatter
Default constructor.
XMLLogin - Class in org.eclipse.persistence.oxm
In OX, the platform determines which parsing method will be used, DOM vs SAX.
XMLLogin() - Constructor for class org.eclipse.persistence.oxm.XMLLogin
Default constructor.
XMLLogin(Platform) - Constructor for class org.eclipse.persistence.oxm.XMLLogin
Constructor, create a new XMLLogin based on the given platform.
XMLLoginConfig - Class in org.eclipse.persistence.internal.sessions.factories.model.login
INTERNAL:
XMLLoginConfig() - Constructor for class org.eclipse.persistence.internal.sessions.factories.model.login.XMLLoginConfig
 
XMLMapping - Interface in org.eclipse.persistence.oxm.mappings
INTERNAL All mappings which can be added to org.eclipse.persistence.oxm.XMLDescriptor must implement this interface.
XMLMARSHAL_EXCEPTION_OCCURRED - Static variable in exception org.eclipse.persistence.exceptions.SDOException
 
XMLMarshalException - Exception in org.eclipse.persistence.exceptions
Purpose: XMLMarshalExceptions are raised when issues are encountered during XMLMarshaller or XMLUnmarshaller operations.
XMLMarshalException(String) - Constructor for exception org.eclipse.persistence.exceptions.XMLMarshalException
 
XMLMarshalException(String, Exception) - Constructor for exception org.eclipse.persistence.exceptions.XMLMarshalException
 
xmlMarshalExceptionOccurred(XMLMarshalException, String, String) - Static method in exception org.eclipse.persistence.exceptions.SDOException
INTERNAL: Exception when an XMLMarshalException happens
XMLMarshalExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL: English ResourceBundle for XMLValidationException.
XMLMarshalExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.XMLMarshalExceptionResource
Default constructor.
XMLMarshaller<ABSTRACT_SESSION extends CoreAbstractSession,​CHARACTER_ESCAPE_HANDLER extends CharacterEscapeHandler,​CONTEXT extends Context<ABSTRACT_SESSION,​DESCRIPTOR,​?,​?,​?,​SESSION,​?>,​DESCRIPTOR extends Descriptor<?,​?,​?,​?,​?,​?,​?,​?,​?,​?>,​MARSHALLER_LISTENER extends Marshaller.Listener,​MEDIA_TYPE extends MediaType,​NAMESPACE_PREFIX_MAPPER extends NamespacePrefixMapper,​OBJECT_BUILDER extends ObjectBuilder<?,​ABSTRACT_SESSION,​?,​XMLMarshaller>,​SESSION extends CoreSession> - Class in org.eclipse.persistence.internal.oxm
 
XMLMarshaller - Class in org.eclipse.persistence.oxm
Class used to marshal object to XML.
XMLMarshaller(CONTEXT) - Constructor for class org.eclipse.persistence.internal.oxm.XMLMarshaller
 
XMLMarshaller(XMLMarshaller) - Constructor for class org.eclipse.persistence.internal.oxm.XMLMarshaller
Copy constructor
XMLMarshaller(XMLContext) - Constructor for class org.eclipse.persistence.oxm.XMLMarshaller
Create a new XMLMarshaller based on the specified session
XMLMarshaller(XMLMarshaller) - Constructor for class org.eclipse.persistence.oxm.XMLMarshaller
Copy constructor
XMLMarshalListener - Interface in org.eclipse.persistence.oxm
An implementation of XMLMarshalListener can be set on an XMLMarshaller to provide additional behaviour during marshal operations.
XmlMarshalNullRepresentation - Enum in org.eclipse.persistence.oxm.annotations
Purpose: This enumeration provides a means of specifying how a null value in a java object should be marshalled to XML.
XmlNamedAttributeNode - Annotation Type in org.eclipse.persistence.oxm.annotations
A XmlNamedAttributeNode is a member element of a XmlNamedObjectGraph.
XmlNamedObjectGraph - Annotation Type in org.eclipse.persistence.oxm.annotations
Purpose: Used to define the boundaries for a marshal or unmarhsal operation.
XmlNamedObjectGraphs - Annotation Type in org.eclipse.persistence.oxm.annotations
Used to group XmlNamedObjectGraph annotations.
XmlNamedSubgraph - Annotation Type in org.eclipse.persistence.oxm.annotations
A XmlNamedSubgraph is a member element of a XmlNamedObjectGraph.
XMLNamespaceResolver - Interface in org.eclipse.persistence.platform.xml
 
XmlNameTransformer - Annotation Type in org.eclipse.persistence.oxm.annotations
An XmlNameTransformer allows for a user defined class to transform names.
XMLNameTransformer - Interface in org.eclipse.persistence.oxm
Interface used when converting from XML to Java names.
XMLNillableMapping - Interface in org.eclipse.persistence.oxm.mappings
INTERNAL All nillable mappings which can be added to org.eclipse.persistence.oxm.XMLDescriptor must implement this interface.
The default policy is AbstractNullPolicy.
XMLNodeList - Class in org.eclipse.persistence.platform.xml
Implementation of the org.w3c.dom.NodeList interface
XMLNodeList() - Constructor for class org.eclipse.persistence.platform.xml.XMLNodeList
 
XMLNodeList(int) - Constructor for class org.eclipse.persistence.platform.xml.XMLNodeList
 
XMLNS - Static variable in class org.eclipse.persistence.oxm.XMLConstants
 
XMLNS_URL - Static variable in class org.eclipse.persistence.oxm.XMLConstants
 
XmlNullPolicy - Annotation Type in org.eclipse.persistence.oxm.annotations
Purpose: Provide a means of using annotations to customise the handling of null values and their xml representation.
XMLNullRepresentationType - Enum in org.eclipse.persistence.oxm.mappings.nullpolicy
Description: An enum that is used within a Node Null Policy to determine what to marshal for a null node.
We define 3 final instances available to the user (XSI_NIL, ABSENT_NODE(default) and EMPTY_NODE.
XMLObjectBuilder - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLObjectBuilder(ClassDescriptor) - Constructor for class org.eclipse.persistence.internal.oxm.XMLObjectBuilder
Create an XML object builder for the descriptor.
XMLObjectReferenceMapping - Class in org.eclipse.persistence.oxm.mappings
TopLink OXM version of a 1-1 mapping.
XMLObjectReferenceMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLObjectReferenceMapping
PUBLIC: The default constructor initializes the sourceToTargetKeyFieldAssociations and sourceToTargetKeys data structures.
XMLObjectReferenceMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLObjectReferenceMappingNodeValue(ObjectReferenceMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLObjectReferenceMappingNodeValue
This constructor sets the XMLObjectReferenceMapping member to the provided value.
XMLObjectReferenceMappingNodeValue(ObjectReferenceMapping, Field) - Constructor for class org.eclipse.persistence.internal.oxm.XMLObjectReferenceMappingNodeValue
This constructor sets the XMLObjectReferenceMapping and XMLField members to the provided values.
XmlParameter - Annotation Type in org.eclipse.persistence.oxm.annotations
Purpose: An annotation representing a parameter to a method.
XMLParseException - Exception in org.eclipse.persistence.exceptions
 
XMLParseException() - Constructor for exception org.eclipse.persistence.exceptions.XMLParseException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
XMLParseException(String) - Constructor for exception org.eclipse.persistence.exceptions.XMLParseException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
XMLParseException(String, Throwable) - Constructor for exception org.eclipse.persistence.exceptions.XMLParseException
INTERNAL: TopLink exceptions should only be thrown by TopLink.
XMLParseExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
 
XMLParseExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.XMLParseExceptionResource
Default constructor.
XMLParser - Interface in org.eclipse.persistence.platform.xml
 
xmlPath() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlJoinNode
 
xmlPath() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlWriteTransformer
Specify here the XPath into which the value should be written.
XmlPath - Annotation Type in org.eclipse.persistence.oxm.annotations
XPath based mapping is what allows an existing object model to be mapped to an existing XML schema.
XmlPaths - Annotation Type in org.eclipse.persistence.oxm.annotations
Purpose: This annotation is used in conjunction with an XmlElements annotation to specify an XmlPath for each of the XmlElement annotations in the XmlElements.
xmlPlatform - Variable in class org.eclipse.persistence.platform.xml.SAXDocumentBuilder
 
XMLPlatform<XML_UNMARSHALLER extends XMLUnmarshaller> - Class in org.eclipse.persistence.oxm.platform
 
XMLPlatform<XML_UNMARSHALLER extends XMLUnmarshaller> - Interface in org.eclipse.persistence.internal.oxm.record
 
XMLPlatform - Interface in org.eclipse.persistence.platform.xml
 
XMLPlatform() - Constructor for class org.eclipse.persistence.oxm.platform.XMLPlatform
 
xmlPlatformClassNotFound(String, Exception) - Static method in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
xmlPlatformCouldNotCreateDocument(Exception) - Static method in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
xmlPlatformCouldNotInstantiate(String, Exception) - Static method in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
xmlPlatformErrorResolvingXMLSchema(URL, Exception) - Static method in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
xmlPlatformErrorResolvingXMLSchemas(Object[], Exception) - Static method in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
XMLPlatformException - Exception in org.eclipse.persistence.platform.xml
 
XMLPlatformException(String) - Constructor for exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
XMLPlatformExceptionResource - Class in org.eclipse.persistence.exceptions.i18n
INTERNAL:
XMLPlatformExceptionResource() - Constructor for class org.eclipse.persistence.exceptions.i18n.XMLPlatformExceptionResource
Default constructor.
XMLPlatformFactory - Class in org.eclipse.persistence.platform.xml
 
xmlPlatformFileNotFoundException(File, IOException) - Static method in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
xmlPlatformInvalidTypeException(int) - Static method in exception org.eclipse.persistence.platform.xml.XMLPlatformException
Handles an invalid type setting in a schema reference.
xmlPlatformInvalidXPath(Exception) - Static method in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
xmlPlatformParseException(Exception) - Static method in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
xmlPlatformSAXParseException(SAXParseException) - Static method in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
xmlPlatformTransformException(Exception) - Static method in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
xmlPlatformValidationException(Exception) - Static method in exception org.eclipse.persistence.platform.xml.XMLPlatformException
 
xmlPlatformValidationException(String) - Static method in exception org.eclipse.persistence.platform.xml.XMLPlatformException
Takes an error messsage string
XMLProjectReader - Class in org.eclipse.persistence.sessions.factories
Purpose: Allow for a EclipseLink Mapping Workbench generated deployment XML project file to be read.
XMLProjectWriter - Class in org.eclipse.persistence.sessions.factories
Purpose: Write the deployment XML (object persistence meta-data) for the TopLink project instance to a file.
XmlProperties - Annotation Type in org.eclipse.persistence.oxm.annotations
Annotation for user defined properties.
XmlProperty - Annotation Type in org.eclipse.persistence.oxm.annotations
Annotation for a user defined property.
xmlReader - Variable in class org.eclipse.persistence.internal.oxm.record.UnmarshalRecordImpl
 
XMLReader - Class in org.eclipse.persistence.internal.oxm.record
INTERNAL:
XMLReader() - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLReader
 
XMLReader(XMLReader) - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLReader
 
XMLReader.ValidatingContentHandler - Class in org.eclipse.persistence.internal.oxm.record
Validate the SAX events reported to the ContentHandler.
XMLReaderAdapter - Class in org.eclipse.persistence.internal.oxm.record
A common super class for all non SAX based XMLReaders.
XMLReaderAdapter() - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
XMLReaderAdapter(Unmarshaller) - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLReaderAdapter
 
XMLReaderAdapter.Attribute - Class in org.eclipse.persistence.internal.oxm.record
 
XMLReaderAdapter.ExtendedContentHandlerAdapter - Class in org.eclipse.persistence.internal.oxm.record
Convert a ContentHandler to an ExtendedContentHandler
XMLReaderAdapter.IndexedAttributeList - Class in org.eclipse.persistence.internal.oxm.record
 
XmlReadOnly - Annotation Type in org.eclipse.persistence.oxm.annotations
Purpose: This annotation indicates that a specific property should be flagged as read-only by EclipseLink.
XmlReadTransformer - Annotation Type in org.eclipse.persistence.oxm.annotations
Purpose: XmlReadTransformer is used to allow the user direct access to the XML in order to populate their object model.
XMLRecord - Class in org.eclipse.persistence.oxm.record
PUBLIC: Provides a Record/Map API on an XML DOM element.
XMLRecord<ABSTRACT_SESSION extends CoreAbstractSession> - Interface in org.eclipse.persistence.internal.oxm.record
 
XMLRecord() - Constructor for class org.eclipse.persistence.oxm.record.XMLRecord
 
XMLRecord.Nil - Class in org.eclipse.persistence.internal.oxm.record
Nil: This is used to indicate that this field represents xsi:nil="true"
XMLRelationshipMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
 
XMLRelationshipMappingNodeValue() - Constructor for class org.eclipse.persistence.internal.oxm.XMLRelationshipMappingNodeValue
 
XMLRoot - Class in org.eclipse.persistence.oxm
XMLRoot is used to hold an Object along with the corresponding QName and some other related information.
XMLRoot() - Constructor for class org.eclipse.persistence.oxm.XMLRoot
Default constructor.
XMLRootConverter - Class in org.eclipse.persistence.oxm.mappings.converters
Purpose: Provides an implementation of XMLConverter to wrap/unwrap objects in an XMLRoot in order to capture element name information.
XMLRootConverter(XMLField) - Constructor for class org.eclipse.persistence.oxm.mappings.converters.XMLRootConverter
 
XMLRootRecord - Class in org.eclipse.persistence.oxm.record
Record for handling simple root elements that have a single text child node, and are being unmarshalled to a primitive wrapper object.
XMLRootRecord(Class<?>, XMLUnmarshaller) - Constructor for class org.eclipse.persistence.oxm.record.XMLRootRecord
Default constructor.
XMLSchemaClassPathReference - Class in org.eclipse.persistence.oxm.schema
A schema reference for accessing an XML Schema from the class path.
XMLSchemaClassPathReference() - Constructor for class org.eclipse.persistence.oxm.schema.XMLSchemaClassPathReference
 
XMLSchemaClassPathReference(String) - Constructor for class org.eclipse.persistence.oxm.schema.XMLSchemaClassPathReference
 
XMLSchemaFileReference - Class in org.eclipse.persistence.oxm.schema
A schema reference for accessing an XML Schema from a file.
XMLSchemaFileReference() - Constructor for class org.eclipse.persistence.oxm.schema.XMLSchemaFileReference
 
XMLSchemaFileReference(File) - Constructor for class org.eclipse.persistence.oxm.schema.XMLSchemaFileReference
 
XMLSchemaFileReference(String) - Constructor for class org.eclipse.persistence.oxm.schema.XMLSchemaFileReference
 
XMLSchemaReference - Class in org.eclipse.persistence.oxm.schema
Provides a way for a descriptor's reference to its schema to be specified.
XMLSchemaReference - Interface in org.eclipse.persistence.platform.xml
A schema reference is used to access a schema in order to validate a document.
XMLSchemaReference() - Constructor for class org.eclipse.persistence.oxm.schema.XMLSchemaReference
The default constructor.
XMLSchemaReference(String) - Constructor for class org.eclipse.persistence.oxm.schema.XMLSchemaReference
This constructor takes a string that references an XMLSchema.
XMLSchemaURLReference - Class in org.eclipse.persistence.oxm.schema
 
XMLSchemaURLReference() - Constructor for class org.eclipse.persistence.oxm.schema.XMLSchemaURLReference
 
XMLSchemaURLReference(String) - Constructor for class org.eclipse.persistence.oxm.schema.XMLSchemaURLReference
 
XMLSchemaURLReference(URL) - Constructor for class org.eclipse.persistence.oxm.schema.XMLSchemaURLReference
 
XMLSequencedDescriptor - Class in org.eclipse.persistence.internal.oxm
Purpose:An extnesion of XMLDescriptor that's used for sequened objects.
XMLSequencedDescriptor() - Constructor for class org.eclipse.persistence.internal.oxm.XMLSequencedDescriptor
 
XMLSequencedObjectBuilder - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLSequencedObjectBuilder(ClassDescriptor) - Constructor for class org.eclipse.persistence.internal.oxm.XMLSequencedObjectBuilder
 
XMLSerializer - Class in org.eclipse.persistence.sessions.serializers
Uses JAXB (MOXy runtime) to convert an object to XML.
XMLSerializer() - Constructor for class org.eclipse.persistence.sessions.serializers.XMLSerializer
 
XMLSerializer(JAXBContext) - Constructor for class org.eclipse.persistence.sessions.serializers.XMLSerializer
 
XMLSerializer(String) - Constructor for class org.eclipse.persistence.sessions.serializers.XMLSerializer
 
XMLSessionConfigLoader - Class in org.eclipse.persistence.sessions.factories
Provide a mechanism for loading Session configuration XML files.
XMLSessionConfigLoader() - Constructor for class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: This constructor is used when the file resource named 'sessions.xml' will be parsed for configuration.
XMLSessionConfigLoader(String) - Constructor for class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader
PUBLIC: This constructor is used when passing in the resource name of the configuration file that should be parsed
XMLSessionConfigLoader.XMLSessionConfigLoaderErrorHandler - Class in org.eclipse.persistence.sessions.factories
INTERNAL:
XMLSessionConfigLoaderErrorHandler() - Constructor for class org.eclipse.persistence.sessions.factories.XMLSessionConfigLoader.XMLSessionConfigLoaderErrorHandler
Default constructor.
XMLSessionConfigProject - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: This class was generated by the TopLink project class generator.
XMLSessionConfigProject() - Constructor for class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject
 
XMLSessionConfigProject_11_1_1 - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: OX mapping project for the 11gR1 sessions XML schema.
XMLSessionConfigProject_11_1_1() - Constructor for class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigProject_11_1_1
 
XMLSessionConfigToplinkProject - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: OX mapping project provides back compatibility for toplink 10g and 11g sessions XML meta-data reading.
XMLSessionConfigToplinkProject() - Constructor for class org.eclipse.persistence.internal.sessions.factories.XMLSessionConfigToplinkProject
Default constructor.
XMLSessionConfigWriter - Class in org.eclipse.persistence.internal.sessions.factories
INTERNAL: This class is used by the Mapping Workbench Session Configuration to write the session config to XML.
XMLSetting - Interface in org.eclipse.persistence.internal.oxm
INTERNAL:
XMLStreamReaderInputSource - Class in org.eclipse.persistence.internal.oxm.record
This class is used to expose an XMLStreamReader as an InputSource.
XMLStreamReaderInputSource(XMLStreamReader) - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLStreamReaderInputSource
 
XMLStreamReaderReader - Class in org.eclipse.persistence.internal.oxm.record
Convert an XMLStreamReader into SAX events.
XMLStreamReaderReader() - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLStreamReaderReader
 
XMLStreamReaderReader(Unmarshaller) - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLStreamReaderReader
 
XMLStreamWriterRecord - Class in org.eclipse.persistence.oxm.record
Use this type of MarshalRecord when the marshal target is an XMLStreamWriter
XMLStreamWriterRecord(XMLStreamWriter) - Constructor for class org.eclipse.persistence.oxm.record.XMLStreamWriterRecord
 
xmlToObject(DOMRecord) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
INTERNAL: Find the Descriptor corresponding to the context node of the XMLRecord, and then convert the XMLRecord to an instance of the corresponding object.
xmlToObject(DOMRecord, Class<?>) - Method in class org.eclipse.persistence.internal.oxm.record.DOMUnmarshaller
INTERNAL: Convert the Oracle XMLDocument to the reference-class.
XmlTransformation - Annotation Type in org.eclipse.persistence.oxm.annotations
Transformation is an optional annotation for org.eclipse.persistence.mappings.oxm.XMLTransformationMapping.
XMLTransformationMapping - Class in org.eclipse.persistence.oxm.mappings
Transformation XML mappings are used to create a custom mapping where one or more XML nodes can be used to create the object to be stored in a Java class's attribute.
XMLTransformationMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLTransformationMapping
 
XMLTransformationRecord - Class in org.eclipse.persistence.internal.oxm.record
 
XMLTransformationRecord(String, UnmarshalRecord) - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLTransformationRecord
 
XMLTransformationRecord(UnmarshalRecord) - Constructor for class org.eclipse.persistence.internal.oxm.record.XMLTransformationRecord
 
XMLTransformer - Interface in org.eclipse.persistence.platform.xml
 
xmlType - Variable in class org.eclipse.persistence.internal.oxm.XMLConversionPair
 
XMLType - org.eclipse.persistence.platform.database.oracle.plsql.OraclePLSQLTypes
 
XMLTypePlaceholder - Class in org.eclipse.persistence.internal.platform.database
This is a dummy class which is used as a stand in for oracle.xdb.XMLType in class comparisions to prevent exceptions.
XMLTypePlaceholder() - Constructor for class org.eclipse.persistence.internal.platform.database.XMLTypePlaceholder
 
XMLUnionField - Class in org.eclipse.persistence.oxm
Subclass of XMLField for fields that are mapped to unions.
XMLUnionField() - Constructor for class org.eclipse.persistence.oxm.XMLUnionField
Constructs an XMLUnionField
XMLUnionField(String) - Constructor for class org.eclipse.persistence.oxm.XMLUnionField
Constructs an XMLUnionField with the xpath set to the specified xPath
XMLUnmarshaller<ABSTRACT_SESSION extends CoreAbstractSession,​CONTEXT extends Context,​DESCRIPTOR extends Descriptor,​ID_RESOLVER extends IDResolver,​MEDIA_TYPE extends MediaType,​ROOT extends Root,​UNMARSHALLER_HANDLER extends UnmarshallerHandler,​UNMARSHALLER_LISTENER extends Unmarshaller.Listener> - Class in org.eclipse.persistence.internal.oxm
Class used to unmarshal XML & JSON to objects.
XMLUnmarshaller - Class in org.eclipse.persistence.oxm
Class used to unmarshal XML & JSON to objects.
XMLUnmarshaller(CONTEXT) - Constructor for class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
XMLUnmarshaller(CONTEXT, Map<String, Boolean>) - Constructor for class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
XMLUnmarshaller(XMLUnmarshaller) - Constructor for class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
XMLUnmarshaller(XMLContext) - Constructor for class org.eclipse.persistence.oxm.XMLUnmarshaller
 
XMLUnmarshaller(XMLContext, Map<String, Boolean>) - Constructor for class org.eclipse.persistence.oxm.XMLUnmarshaller
 
XMLUnmarshaller(XMLUnmarshaller) - Constructor for class org.eclipse.persistence.oxm.XMLUnmarshaller
 
xmlUnmarshallerHandler - Variable in class org.eclipse.persistence.internal.oxm.XMLUnmarshaller
 
XMLUnmarshallerHandler - Class in org.eclipse.persistence.oxm
Class used to unmarshal SAX events to objects.
XMLUnmarshalListener - Interface in org.eclipse.persistence.oxm
An implementation of XMLUnmarshalListener can be set on an XMLUnmarshaller to provide additional behaviour during unmarshal operations.
XMLValidator - Class in org.eclipse.persistence.oxm
Class used to validate XML.
XMLValidator(XMLContext) - Constructor for class org.eclipse.persistence.oxm.XMLValidator
 
XMLVALUE_ALREADY_SET - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
XMLVALUE_ATTRIBUTE_CONFLICT - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
xmlValueAlreadySet(String, String, String) - Static method in exception org.eclipse.persistence.exceptions.JAXBException
This exception should be used when an attempt is made to set an XmlValue property when one has already been set.
XmlValueExtension - Annotation Type in org.eclipse.persistence.oxm.annotations
Purpose: Provide a way to allow classes, which contain property annotated with XmlValue to extend classes other than java.lang.Object.
XmlVariableNode - Annotation Type in org.eclipse.persistence.oxm.annotations
 
XmlVariableNode.DEFAULT - Class in org.eclipse.persistence.oxm.annotations
Used in XmlVariableNode.type() to signal that the type be inferred from the signature of the property.
XMLVariableXPathCollectionMapping - Class in org.eclipse.persistence.oxm.mappings
 
XMLVariableXPathCollectionMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLVariableXPathCollectionMapping
Default constructor.
XMLVariableXPathCollectionMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
 
XMLVariableXPathCollectionMappingNodeValue(VariableXPathCollectionMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLVariableXPathCollectionMappingNodeValue
 
XMLVariableXPathMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
 
XMLVariableXPathMappingNodeValue() - Constructor for class org.eclipse.persistence.internal.oxm.XMLVariableXPathMappingNodeValue
 
XMLVariableXPathObjectMapping - Class in org.eclipse.persistence.oxm.mappings
 
XMLVariableXPathObjectMapping() - Constructor for class org.eclipse.persistence.oxm.mappings.XMLVariableXPathObjectMapping
 
XMLVariableXPathObjectMappingNodeValue - Class in org.eclipse.persistence.internal.oxm
 
XMLVariableXPathObjectMappingNodeValue(VariableXPathObjectMapping) - Constructor for class org.eclipse.persistence.internal.oxm.XMLVariableXPathObjectMappingNodeValue
 
xmlVersion - Variable in class org.eclipse.persistence.internal.oxm.Root
 
XmlVirtualAccessMethods - Annotation Type in org.eclipse.persistence.oxm.annotations
The XmlVirtualAccessMethods annotation is used to indicate that this class has been configured to hold virtual properties.
XmlVirtualAccessMethodsSchema - Enum in org.eclipse.persistence.oxm.annotations
 
XmlWriteOnly - Annotation Type in org.eclipse.persistence.oxm.annotations
Purpose: This annotation indicates that a specific property should be flagged as write-only by EclipseLink.
XmlWriteTransformer - Annotation Type in org.eclipse.persistence.oxm.annotations
Annotation for org.eclipse.persistence.mappings.oxm.XMLTransformationMapping.
XmlWriteTransformers - Annotation Type in org.eclipse.persistence.oxm.annotations
Purpose: Annotation used to wrap multiple XmlWriteTransformer annotations.
XOP_PREFIX - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
XOP_URL - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
XPATH_INDEX_CLOSED - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
XPATH_INDEX_OPEN - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
XPATH_SEPARATOR - Static variable in class org.eclipse.persistence.internal.oxm.Constants
 
XPathEngine<XML_FIELD extends Field> - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XPathFragment<XML_FIELD extends Field> - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XPathFragment() - Constructor for class org.eclipse.persistence.internal.oxm.XPathFragment
 
XPathFragment(String) - Constructor for class org.eclipse.persistence.internal.oxm.XPathFragment
 
XPathFragment(String, char, boolean) - Constructor for class org.eclipse.persistence.internal.oxm.XPathFragment
 
xPathNode - Variable in class org.eclipse.persistence.internal.oxm.NodeValue
 
xPathNode(XPathNode, NullCapableValue) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
INTERNAL: When using the SAX Platform this allows a NodeValue to be registered to receive events from the TreeObjectBuilder.
xPathNode(XPathNode, NullCapableValue) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.IsSetNullPolicy
 
xPathNode(XPathNode, NullCapableValue) - Method in class org.eclipse.persistence.oxm.mappings.nullpolicy.NullPolicy
 
XPathNode - Class in org.eclipse.persistence.internal.oxm
INTERNAL:
XPathNode() - Constructor for class org.eclipse.persistence.internal.oxm.XPathNode
 
XPathObjectBuilder - Class in org.eclipse.persistence.internal.oxm
 
XPathObjectBuilder(CoreDescriptor) - Constructor for class org.eclipse.persistence.internal.oxm.XPathObjectBuilder
 
XPathPredicate - Class in org.eclipse.persistence.internal.oxm
 
XPathPredicate(XPathFragment, String) - Constructor for class org.eclipse.persistence.internal.oxm.XPathPredicate
 
XPathQName - Class in org.eclipse.persistence.internal.oxm
This class represents the pairing of a local name and a namespace uri.
XPathQName() - Constructor for class org.eclipse.persistence.internal.oxm.XPathQName
Create a new XPathQName.
XPathQName(String, boolean) - Constructor for class org.eclipse.persistence.internal.oxm.XPathQName
Create a new XPathQName with the specified local name.
XPathQName(String, String, boolean) - Constructor for class org.eclipse.persistence.internal.oxm.XPathQName
Create a new XPathQName with the specified local name and namespace
XPathQName(QName, boolean) - Constructor for class org.eclipse.persistence.internal.oxm.XPathQName
Create a new XPathQName with the specified QName
XQueryInteraction - Class in org.eclipse.persistence.eis.interactions
Defines the specification for a call to a JCA interaction that uses XQuery.
XQueryInteraction() - Constructor for class org.eclipse.persistence.eis.interactions.XQueryInteraction
Default constructor.
XQueryInteraction(String) - Constructor for class org.eclipse.persistence.eis.interactions.XQueryInteraction
Construct the interaction with the XQuery string.
xQueryString - Variable in class org.eclipse.persistence.eis.interactions.XQueryInteraction
 
XSD_IMPORT_NOT_SOURCE - Static variable in exception org.eclipse.persistence.exceptions.JAXBException
 
xsdImportNotSource() - Static method in exception org.eclipse.persistence.exceptions.JAXBException
 
XSI_NIL - org.eclipse.persistence.oxm.annotations.XmlMarshalNullRepresentation
 
XSI_NIL - org.eclipse.persistence.oxm.mappings.nullpolicy.XMLNullRepresentationType
Write out an xsi:nil="true" attribute.
XSI_NIL_ATTRIBUTE - Static variable in class org.eclipse.persistence.oxm.mappings.nullpolicy.AbstractNullPolicy
 
xsiNilRepresentsNull() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlIsSetNullPolicy
 
xsiNilRepresentsNull() - Method in annotation type org.eclipse.persistence.oxm.annotations.XmlNullPolicy
 

Z

ZERO - org.eclipse.persistence.annotations.IdValidation
null and 0 are not allowed for primitive int and long ids.
ZERO - Static variable in class org.eclipse.persistence.internal.oxm.schema.model.Occurs
 

_

_persistence_get(String) - Method in interface org.eclipse.persistence.internal.descriptors.PersistenceObject
 
_persistence_getCacheKey() - Method in interface org.eclipse.persistence.internal.descriptors.PersistenceEntity
 
_persistence_getCacheKey() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
_persistence_getFetchGroup() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
_persistence_getFetchGroup() - Method in interface org.eclipse.persistence.queries.FetchGroupTracker
Return the fetch group being tracked
_persistence_getId() - Method in interface org.eclipse.persistence.internal.descriptors.PersistenceEntity
 
_persistence_getId() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
_persistence_getPropertyChangeListener() - Method in interface org.eclipse.persistence.descriptors.changetracking.ChangeTracker
PUBLIC: Return the PropertyChangeListener for the object.
_persistence_getPropertyChangeListener() - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Return the property change listener for change tracking.
_persistence_getPropertyChangeListener() - Method in class org.eclipse.persistence.indirection.IndirectMap
Return the property change listener for change tracking.
_persistence_getPropertyChangeListener() - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Return the property change listener for change tracking.
_persistence_getPropertyChangeListener() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
_persistence_getSession() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
_persistence_getSession() - Method in interface org.eclipse.persistence.queries.FetchGroupTracker
Return the session for the object.
_persistence_isAttributeFetched(String) - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
Return true if the attribute is in the fetch group being tracked.
_persistence_isAttributeFetched(String) - Method in interface org.eclipse.persistence.queries.FetchGroupTracker
Return true if the attribute is in the fetch group being tracked.
_persistence_new(PersistenceObject) - Method in interface org.eclipse.persistence.internal.descriptors.PersistenceObject
 
_persistence_resetFetchGroup() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
Reset all attributes of the tracked object to the un-fetched state with initial default values.
_persistence_resetFetchGroup() - Method in interface org.eclipse.persistence.queries.FetchGroupTracker
Reset all attributes of the tracked object to the unfetched state with initial default values.
_persistence_set(String, Object) - Method in interface org.eclipse.persistence.internal.descriptors.PersistenceObject
 
_persistence_setCacheKey(CacheKey) - Method in interface org.eclipse.persistence.internal.descriptors.PersistenceEntity
 
_persistence_setCacheKey(CacheKey) - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
_persistence_setFetchGroup(FetchGroup) - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
_persistence_setFetchGroup(FetchGroup) - Method in interface org.eclipse.persistence.queries.FetchGroupTracker
Set a fetch group to be tracked.
_persistence_setId(Object) - Method in interface org.eclipse.persistence.internal.descriptors.PersistenceEntity
 
_persistence_setId(Object) - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
_persistence_setPropertyChangeListener(PropertyChangeListener) - Method in interface org.eclipse.persistence.descriptors.changetracking.ChangeTracker
PUBLIC: Set the PropertyChangeListener for the object.
_persistence_setPropertyChangeListener(PropertyChangeListener) - Method in class org.eclipse.persistence.indirection.IndirectList
INTERNAL: Set the property change listener for change tracking.
_persistence_setPropertyChangeListener(PropertyChangeListener) - Method in class org.eclipse.persistence.indirection.IndirectMap
INTERNAL: Set the property change listener for change tracking.
_persistence_setPropertyChangeListener(PropertyChangeListener) - Method in class org.eclipse.persistence.indirection.IndirectSet
INTERNAL: Set the property change listener for change tracking.
_persistence_setPropertyChangeListener(PropertyChangeListener) - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
_persistence_setSession(Session) - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
_persistence_setSession(Session) - Method in interface org.eclipse.persistence.queries.FetchGroupTracker
Set true if the fetch group attributes should be refreshed
_persistence_setShouldRefreshFetchGroup(boolean) - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
_persistence_setShouldRefreshFetchGroup(boolean) - Method in interface org.eclipse.persistence.queries.FetchGroupTracker
Set true if the fetch group attributes should be refreshed.
_persistence_shallow_clone() - Method in interface org.eclipse.persistence.internal.descriptors.PersistenceObject
 
_persistence_shouldRefreshFetchGroup() - Method in class org.eclipse.persistence.internal.dynamic.DynamicEntityImpl
 
_persistence_shouldRefreshFetchGroup() - Method in interface org.eclipse.persistence.queries.FetchGroupTracker
Return true if the fetch group attributes should be refreshed.
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 _ 
All Classes All Packages