Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AbstractQuery - Class in io.ebeaninternal.server.querydefn
-
Common code for Dto/Orm/RelationalQuery
- AbstractQuery() - Constructor for class io.ebeaninternal.server.querydefn.AbstractQuery
- AbstractSqlQueryRequest - Class in io.ebeaninternal.server.core
-
Wraps the objects involved in executing a SQL / Relational Query.
- active() - Method in interface io.ebeaninternal.api.SpiTransactionManager
-
Return the currently active transaction (can be null).
- active() - Method in class io.ebeaninternal.server.transaction.DefaultTransactionScopeManager
- active() - Method in class io.ebeaninternal.server.transaction.ExternalTransactionScopeManager
- active() - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Return the current active transaction.
- active() - Method in class io.ebeaninternal.server.transaction.TransactionScopeManager
-
Return the current Transaction potentially looking in external scope (like Spring).
- add(int, E) - Method in class io.ebeaninternal.json.ModifyAwareList
- add(long) - Method in class io.ebeaninternal.server.query.CQueryPlanStats
-
Add a query execution to the statistics.
- add(E) - Method in class io.ebeaninternal.json.ModifyAwareList
- add(E) - Method in class io.ebeaninternal.json.ModifyAwareListIterator
- add(E) - Method in class io.ebeaninternal.json.ModifyAwareSet
- add(BeanCollection<?>, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- add(BeanCollection<?>, EntityBean, boolean) - Method in class io.ebeaninternal.server.deploy.BeanListHelp
- add(BeanCollection<?>, EntityBean, boolean) - Method in class io.ebeaninternal.server.deploy.BeanSetHelp
- add(BeanCollection<?>, EntityBean, boolean) - Method in interface io.ebeaninternal.server.deploy.BeanCollectionHelp
-
Add a bean to the List Set or Map.
- add(BeanCollection<?>, EntityBean, boolean) - Method in class io.ebeaninternal.server.deploy.BeanListHelpElement
- add(BeanCollection<?>, EntityBean, boolean) - Method in class io.ebeaninternal.server.deploy.BeanMapHelp
- add(BeanCollection<?>, EntityBean, boolean) - Method in class io.ebeaninternal.server.deploy.BeanMapHelpElement
- add(BeanCollection<?>, EntityBean, boolean) - Method in class io.ebeaninternal.server.deploy.BeanSetHelpElement
- add(BeanCollection<?>, EntityBean, boolean) - Method in interface io.ebeaninternal.server.query.CQueryCollectionAdd
-
Add a bean to the List Set or Map.
- add(Expression) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- add(BindParams.Param) - Method in class io.ebeaninternal.api.BindParams.OrderedList
-
Add a parameter in the correct binding order.
- add(NaturalKeyEntry) - Method in class io.ebeaninternal.api.NaturalKeySet
- add(TransactionEventTable) - Method in class io.ebeaninternal.api.TransactionEvent
- add(TransactionEventTable) - Method in class io.ebeaninternal.api.TransactionEventTable
- add(TransactionEventTable.TableIUD) - Method in class io.ebeaninternal.api.TransactionEventTable
- add(BeanDescriptor<?>, PersistRequest.Type, Object) - Method in class io.ebeaninternal.server.transaction.BeanPersistIdMap
-
Add a Insert Update or Delete payload.
- add(BeanDescriptor<?>, Object) - Method in class io.ebeaninternal.server.transaction.DeleteByIdMap
-
Add a Insert Update or Delete payload.
- add(BeanFkeyProperty) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Add objects to ElPropertyDeploy etc.
- add(ElPropertyDeploy) - Method in class io.ebeaninternal.api.ManyWhereJoins
-
Add a many where join.
- add(ElPropertyValue) - Method in class io.ebeaninternal.server.el.ElPropertyChainBuilder
-
Add a ElGetValue element to the chain.
- add(BatchPostExecute) - Method in class io.ebeaninternal.server.persist.BatchedPstmt
-
Add the BatchPostExecute to the list for post execute processing.
- add(STreeProperty) - Method in class io.ebeaninternal.server.query.SqlTreeProperties
- add(STreeProperty[]) - Method in class io.ebeaninternal.server.query.SqlTreeProperties
- add(OrmQueryProperties) - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
For secondary queries add a child element.
- add(DocPropertyMapping) - Method in class io.ebeanservice.docstore.api.mapping.DocMappingBuilder
-
Add the property mapping.
- add(Object) - Method in class io.ebeaninternal.api.BindValuesKey
-
Add a bind value.
- add(String, boolean, boolean, boolean) - Method in class io.ebeaninternal.api.TransactionEvent
- add(String, boolean, boolean, boolean) - Method in class io.ebeaninternal.api.TransactionEventTable
- add(String, String) - Static method in class io.ebeaninternal.server.util.Str
-
Append two strings together.
- add(String, String[]) - Static method in class io.ebeaninternal.server.util.Str
- add(String, String, String...) - Static method in class io.ebeaninternal.server.util.Str
-
Append strings together.
- add(T, Object) - Method in class io.ebeaninternal.api.BeanCacheResult
-
Add an entry.
- addAggregationJoin(String) - Method in class io.ebeaninternal.api.ManyWhereJoins
-
Ensure we have the join required to support the aggregation properties.
- addAll(int, Collection<? extends E>) - Method in class io.ebeaninternal.json.ModifyAwareList
- addAll(ExpressionList<T>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- addAll(Collection<? extends E>) - Method in class io.ebeaninternal.json.ModifyAwareList
- addAll(Collection<? extends E>) - Method in class io.ebeaninternal.json.ModifyAwareSet
- addBatch() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- addBatch() - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
-
Add this statement to JDBC batch for later execution.
- addBatch(SpiSqlUpdate, SpiTransaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- addBatch(SpiSqlUpdate, SpiTransaction) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Add to JDBC batch for later execution.
- addBatch(SpiSqlUpdate, SpiTransaction) - Method in interface io.ebeaninternal.server.core.Persister
-
Add the statement to JDBC batch for later execution via executeBatch.
- addBatch(SpiSqlUpdate, SpiTransaction) - Method in class io.ebeaninternal.server.persist.DefaultPersister
- addBeanChange(BeanChange) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Add a bean change to the change log.
- addBeanChange(BeanChange) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- addBeanChange(BeanChange) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- addBeanChange(BeanChange) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- addBeanChange(BeanChange) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- addBeanChange(BeanChange) - Method in class io.ebeaninternal.server.transaction.TChangeLogHolder
-
Add a bean change to the change set.
- addBeanInsert(String) - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
On bean insert register table for view based entity invalidation.
- addBeanPersistIds(BeanPersistIds) - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- addBeanProperty(DeployBeanProperty) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Add a bean property.
- addBeanRemove(BeanDescriptor<T>, Object) - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
Remove a bean from the cache.
- addBeanRemoveMany(BeanDescriptor<T>, Collection<Object>) - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
Remove a bean from the cache.
- addBeanToCollectionWithCreate(EntityBean, EntityBean, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Add the bean to the appropriate collection on the parent bean.
- addBeanToCollectionWithCreate(EntityBean, EntityBean, boolean) - Method in interface io.ebeaninternal.server.query.STreePropertyAssocMany
-
Add a bean to the collection.
- addBeanUpdate(CacheChangeSet) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Build the bean update for the L2 cache.
- addBeanUpdate(BeanDescriptor<T>, String, Map<String, Object>, boolean, long) - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
Update a bean entry.
- addBindEncryptKey(Object) - Method in interface io.ebeaninternal.api.SpiExpressionBind
-
Add an encryption key to bind to this request.
- addBindEncryptKey(Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- addBindValue(Object) - Method in interface io.ebeaninternal.api.SpiExpressionBind
-
Add a bind value to this request.
- addBindValue(Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- addBindValues(SpiExpressionBind) - Method in interface io.ebeaninternal.api.SpiExpression
-
Add the parameter values to be set against query.
- addBindValues(SpiExpressionBind) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- addBindValues(SpiExpressionBind) - Method in class io.ebeaninternal.server.expression.IdInExpression
- addBindValues(SpiExpressionBind) - Method in class io.ebeaninternal.server.expression.InExpression
- addBindValues(SpiExpressionBind) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- addBindValues(SpiExpressionBind, Collection<?>) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Binds multiple id value to a request.
- addBindValues(SpiExpressionBind, Collection<?>) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- addBindValues(SpiExpressionBind, Collection<?>) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- addBindValues(DefaultSqlUpdate, Collection<?>) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Binds multiple id value to an update.
- addBindValues(DefaultSqlUpdate, Collection<?>) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- addBindValues(DefaultSqlUpdate, Collection<?>) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- addChangeLogInstances(DatabaseBuilder.Settings) - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- addChild(InheritInfo) - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Add a child node.
- addChild(DocPropertyMapping) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyMapping
-
Add a child property.
- addChildrenProperties(SqlTreeProperties) - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Add the local properties for each sub class below this one.
- addClearBean(BeanDescriptor<?>) - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
Add an entry to clear a bean cache.
- addClearQuery(BeanDescriptor<?>) - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
Add an entry to clear a query cache.
- addCollectionChange(String, Object) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Add an element collection change to L2 bean cache update.
- addColumn(String) - Method in class io.ebeaninternal.server.deploy.IntersectionBuilder
- addDbMigrationInfo(DbMigrationInfo) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- addDelete(DocStoreUpdate) - Method in class io.ebeanservice.docstore.api.DocStoreUpdates
-
Add a delete request.
- addDeleteById(BeanDescriptor<?>, Object) - Method in class io.ebeaninternal.api.TransactionEvent
- addDeleteByIdList(BeanDescriptor<?>, List<Object>) - Method in class io.ebeaninternal.api.TransactionEvent
- addDependentTables(Set<String>) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- addDocStoreUpdates(DocStoreUpdates) - Method in class io.ebeaninternal.api.TransactionEvent
-
Add any relevant PersistRequestBean's to DocStoreUpdates for later processing.
- addDocStoreUpdates(DocStoreUpdates) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
For requests that update document store add this event to either the list of queue events or list of update events.
- addElement(Object) - Method in interface io.ebeaninternal.server.deploy.ElementCollector
-
Add an element.
- addEncryptedProp(BeanProperty) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Add an encrypted property which will require additional binding.
- addEvent(String, long) - Method in class io.ebeaninternal.server.transaction.DefaultProfileStream
-
Add the commit/rollback event.
- addEvent(String, long) - Method in interface io.ebeaninternal.server.transaction.ProfileStream
-
Add the commit/rollback event.
- addExtra(STreePropertyAssocOne) - Method in class io.ebeaninternal.server.query.SqlTreeProperties
- addExtraJoin(SqlTreeJoin) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Delay adding an extra join to support inheritance discriminator in projection (IF required).
- addFindControllers(List<BeanFindController>) - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
-
Add BeanFindController instances.
- addFkeys(String) - Method in interface io.ebeaninternal.server.deploy.id.ImportedId
- addFkeys(String) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdEmbedded
- addFkeys(String) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- addFormulaWithJoin(String, String) - Method in class io.ebeaninternal.api.ManyWhereJoins
-
In findCount query found a formula property with a join clause so building a select clause specifically for the findCount query.
- addId(PersistRequest.Type, Object) - Method in class io.ebeaninternal.server.transaction.BeanPersistIds
- addIdGenerators(List<IdGenerator>) - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
-
Add IdGenerator instances (registered explicitly with the ServerConfig).
- addIndex(IndexDefinition) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Add a compound unique constraint.
- addInheritanceWhere(Query<?>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- addInvalidate(BeanDescriptor<?>) - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
Add an entry to clear a query cache.
- addInvalidate(Set<String>) - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
Add invalidation on a set of tables.
- addJoin(DbSqlContext) - Method in interface io.ebeaninternal.server.query.SqlTreeJoin
-
Add the extra join if required.
- addJoin(SqlJoinType, String, DbSqlContext) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Add table join with table alias based on prefix.
- addJoin(SqlJoinType, String, DbSqlContext) - Method in class io.ebeaninternal.server.deploy.TableJoin
- addJoin(SqlJoinType, String, DbSqlContext) - Method in interface io.ebeaninternal.server.query.STreePropertyAssoc
-
Add a Join with the given prefix (determining the alias).
- addJoin(SqlJoinType, String, DbSqlContext, String) - Method in class io.ebeaninternal.server.deploy.TableJoin
- addJoin(SqlJoinType, String, String, DbSqlContext) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Add table join with explicit table alias.
- addJoin(SqlJoinType, String, String, DbSqlContext) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Add table join with explicit table alias.
- addJoin(SqlJoinType, String, String, DbSqlContext) - Method in class io.ebeaninternal.server.deploy.TableJoin
- addJoin(SqlJoinType, String, String, DbSqlContext) - Method in interface io.ebeaninternal.server.query.STreePropertyAssoc
-
Add a Join with the given alias.
- addJoin(String, String, TableJoinColumn[], String, String, String) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Add a join to the sql query.
- addJoin(String, String, StringBuilder) - Method in class io.ebeaninternal.server.deploy.TableJoin
- addJoinColumn(DeployTableJoinColumn) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
-
Add a join pair
- addJoinColumn(DeployUtil, boolean, JoinColumn[], BeanTable) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
-
Add a JoinColumn array.
- addJoinColumn(DeployUtil, boolean, JoinColumn, BeanTable) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
-
Add a JoinColumn
- addJoinColumn(DeployUtil, boolean, Set<JoinColumn>, BeanTable) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
-
Add a JoinColumn set.
- addKeyValue(Object, Object) - Method in interface io.ebeaninternal.server.deploy.ElementCollector
-
Add an element.
- addList(BeanDescriptor<?>, List<Object>) - Method in class io.ebeaninternal.server.transaction.DeleteByIdMap
-
Add a List of Insert Update or Delete Id's.
- addListenerNotify(PersistRequestBean<?>) - Method in class io.ebeaninternal.api.TransactionEvent
-
Add post commit listeners.
- addManyClear(BeanDescriptor<T>, String) - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
Add many property clear.
- addManyPut(BeanDescriptor<T>, String, String, CachedManyIds) - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
Add many property put.
- addManyRemove(BeanDescriptor<T>, String, String) - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
Add many property remove.
- addModification(String, boolean, boolean, boolean) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- addModification(String, boolean, boolean, boolean) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- addModification(String, boolean, boolean, boolean) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- addModification(String, boolean, boolean, boolean) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- addNamedQuery(String, String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Add a named query.
- addNaturalKeyPut(BeanDescriptor<T>, String, String) - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
Update a natural key.
- addNested(String, PathProperties) - Method in class io.ebeanservice.docstore.api.support.DocStructure
-
Add an embedded property with it's document structure.
- addNested(String, OrmQueryDetail, FetchConfig) - Method in interface io.ebeaninternal.api.SpiQueryFetch
-
Add a nested fetch graph.
- addNested(String, OrmQueryDetail, FetchConfig) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- addNested(String, OrmQueryDetail, FetchConfig) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Add a nested OrmQueryDetail to this detail.
- addNested(String, String, Object) - Method in class io.ebeanservice.docstore.api.DocStoreUpdates
-
Add a nested update.
- addPersist(DocStoreUpdate) - Method in class io.ebeanservice.docstore.api.DocStoreUpdates
-
Add a persist request.
- addPersistController(BeanPersistController) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- addPersistControllers(List<BeanPersistController>) - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
-
Add BeanPersistController instances.
- addPersistEvent(String, long, String, int) - Method in class io.ebeaninternal.server.transaction.DefaultProfileStream
-
Add a persist event.
- addPersistEvent(String, long, String, int) - Method in interface io.ebeaninternal.server.transaction.ProfileStream
-
Add a persist event.
- addPersistListener(BeanPersistListener) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- addPersistListeners(List<BeanPersistListener>) - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- addPostConstructListener(BeanPostConstructListener) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- addPostConstructListeners(List<BeanPostConstructListener>) - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
-
Add BeanPostConstructListener instances.
- addPostLoad(BeanPostLoad) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- addPostLoaders(List<BeanPostLoad>) - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
-
Add BeanPostLoad instances.
- addProperty(String) - Method in class io.ebeanservice.docstore.api.support.DocStructure
-
Add a property at the root level.
- addQueryAdapter(BeanQueryAdapter) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- addQueryAdapters(List<BeanQueryAdapter>) - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- addQueryEvent(String, long, String, int, String) - Method in class io.ebeaninternal.server.transaction.DefaultProfileStream
-
Add a query execution event.
- addQueryEvent(String, long, String, int, String) - Method in interface io.ebeaninternal.server.transaction.ProfileStream
-
Add a query event.
- addRawSql(String, SpiRawSql) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Add a named RawSql from ebean.xml file.
- addRemoteCacheEvent(RemoteCacheEvent) - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
-
Set the RemoteCacheEvent.
- addRemoteTableMod(RemoteTableMod) - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- addSaveMany(SaveMany) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
The intersection table updates or element collection to the batch executed later on postExecute.
- addSelectExported(DbSqlContext, String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- addSelectExported(DbSqlContext, String) - Method in interface io.ebeaninternal.server.query.STreePropertyAssocMany
-
Append exported columns to the select.
- addServerConfigStartup(List<ServerConfigStartup>) - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- addSoftDeletePredicate(String) - Method in interface io.ebeaninternal.api.SpiQuery
- addSoftDeletePredicate(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- addSql(SpiExpressionRequest) - Method in interface io.ebeaninternal.api.SpiExpression
-
Add some sql to the query.
- addSql(SpiExpressionRequest) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- addSql(SpiExpressionRequest) - Method in class io.ebeaninternal.server.expression.IdInExpression
- addSql(SpiExpressionRequest) - Method in class io.ebeaninternal.server.expression.InExpression
- addSql(SpiExpressionRequest) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- addSqlNoAlias(SpiExpressionRequest) - Method in class io.ebeaninternal.server.expression.IdInExpression
-
For use with deleting non-attached detail beans during stateless update.
- addStmt(BatchedPstmt, BatchPostExecute) - Method in class io.ebeaninternal.server.persist.BatchedPstmtHolder
-
Add a new PreparedStatement wrapped in the BatchStatement object.
- addTableIUD(TransactionEventTable.TableIUD) - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- addTenant(SpiQuery<?>, Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Add the tenantId predicate to the query.
- addTenant(SpiQuery<?>, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- addTimingBatch(long, int) - Method in class io.ebeaninternal.server.core.PersistRequest
- addTimingBatch(long, int) - Method in class io.ebeaninternal.server.core.PersistRequestBean
- addTimingBatch(long, int) - Method in interface io.ebeaninternal.server.persist.BatchPostExecute
-
Add timing metrics for batch persist.
- addTimingNoBatch(long) - Method in class io.ebeaninternal.server.core.PersistRequest
- addTimingNoBatch(long) - Method in class io.ebeaninternal.server.core.PersistRequestBean
- addToFlushQueue(int) - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
-
Add this request to BatchControl to flush later.
- addToFlushQueue(SpiSqlUpdate, SpiTransaction, int) - Method in interface io.ebeaninternal.server.core.Persister
-
Queue the SqlUpdate for execution with position 0, 1 or 2 defining when it executes relative to the flush of beans .
- addToFlushQueue(SpiSqlUpdate, SpiTransaction, int) - Method in class io.ebeaninternal.server.persist.DefaultPersister
-
Add to the flush queue in position 0, 1 or 2.
- addToFlushQueue(PersistRequestUpdateSql, int) - Method in class io.ebeaninternal.server.persist.BatchControl
-
Add a SqlUpdate request to execute after flush.
- addToPersistMap(BeanPersistIdMap) - Method in class io.ebeaninternal.server.core.PersistRequestBean
- addToQueue(DocStoreUpdates) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Add this event to the queue entries in IndexUpdates.
- addToQueue(DocStoreUpdates) - Method in interface io.ebeanservice.docstore.api.DocStoreUpdate
-
Add to the queue for deferred processing.
- addToQueue(DocStoreUpdates) - Method in class io.ebeanservice.docstore.api.support.DocStoreDeleteEvent
-
Add this event to the queue (for queue delayed processing).
- addToQueue(DocStoreUpdates) - Method in class io.ebeanservice.docstore.api.support.DocStoreIndexEvent
-
Add this event to the queue (for queue delayed processing).
- addUpdatedManyForL2Cache(BeanPropertyAssocMany<?>) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
This many property has potential L2 cache update for many Ids.
- addWhereParentIdIn(SpiQuery<?>, List<Object>, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- alias() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return root table alias set by
QueryBuilder.alias(String)command. - alias() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- alias(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- ALL - Enum constant in enum io.ebeaninternal.server.expression.BitwiseOp
-
All flags are set (derived expression BITAND flags == flags).
- allEq(Map<String, Object>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
All Equal - Map containing property names and their values.
- allEq(Map<String, Object>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- allHits() - Method in interface io.ebeaninternal.api.CacheIdLookup
-
Return true if all beans where found in L2 cache.
- allHits() - Method in class io.ebeaninternal.api.CacheIdLookupMany
- allHits() - Method in class io.ebeaninternal.api.CacheIdLookupSingle
- allHits() - Method in class io.ebeaninternal.api.NaturalKeyQueryData
-
Return the number of entries in the IN clause left remaining (to hit the DB with).
- allProperties() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- allProperties() - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Return true if this includes all properties on the path.
- allRegions() - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- allRegions() - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
- allRegions() - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Return all the regions.
- allRegionsEnabled(boolean) - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- also(Consumer<Query<T>>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- alsoIf(BooleanSupplier, Consumer<Query<T>>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- analyzer() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- analyzer(String) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- and() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- and(Expression, Expression) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
And - join two expressions with a logical and.
- and(Expression, Expression) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- AND - Enum constant in enum io.ebeaninternal.server.expression.BitwiseOp
-
BITAND flags == match.
- ansiOffsetRows() - Method in class io.ebeaninternal.server.querydefn.OrmQueryLimitRequest
- ANY - Enum constant in enum io.ebeaninternal.server.expression.BitwiseOp
-
Any flags are set (derived expression BITAND flags !
- append(char) - Method in interface io.ebeaninternal.api.SpiExpressionRequest
-
Append to the expression sql without any parsing.
- append(char) - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- append(char) - Method in interface io.ebeaninternal.server.expression.platform.DbExpressionRequest
-
Append to the expression sql without any parsing.
- append(String) - Method in interface io.ebeaninternal.api.SpiExpressionRequest
-
Append to the expression sql without any parsing.
- append(String) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Append a string directly to the SQL buffer.
- append(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- append(String) - Method in interface io.ebeaninternal.server.expression.platform.DbExpressionRequest
-
Append to the expression sql without any parsing.
- appendCheckConstraintValues(String, Set<String>) - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Append check constraint values for the entire inheritance hierarchy.
- appendColumn(String) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Append a column with the current table alias.
- appendColumn(String, String) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Append a column with an explicit table alias.
- appendFormulaJoin(String, SqlJoinType, String) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Append a Sql Formula join.
- appendFormulaSelect(String) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Append a Sql Formula select.
- appendFrom(DbSqlContext, SqlJoinType, String) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Add any extra joins required to support this property.
- appendFrom(DbSqlContext, SqlJoinType, String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- appendFrom(DbSqlContext, SqlJoinType, String) - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- appendFrom(DbSqlContext, SqlJoinType, String) - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Append to the from clause.
- appendFromForUpdate() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Append 'for update' lock hints on FROM clause (sql server only).
- appendGroupBy(DbSqlContext, boolean) - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- appendGroupBy(DbSqlContext, boolean) - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Append to group by.
- appendHistorySysPeriod() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Append the lower and upper bound columns into the select clause for findVersions() queries.
- appendInExpression(boolean, List<Object>) - Method in interface io.ebeaninternal.api.SpiExpressionRequest
-
Append IN expression taking into account platform and type support for Multi-value.
- appendInExpression(boolean, List<Object>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- appendLike(boolean) - Method in interface io.ebeaninternal.api.SpiExpressionRequest
-
Append a DB Like clause.
- appendLike(boolean) - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
-
Append the database platform like clause.
- appendOrderById(SpiQuery<T>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Appends the Id property to the OrderBy clause if it is not believed to be already contained in the order by.
- appendParseSelect(String, String) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Parse and add formula with standard table alias replacement.
- appendRawColumn(String) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Add a raw column to the sql.
- appendSelect(DbSqlContext, boolean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- appendSelect(DbSqlContext, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- appendSelect(DbSqlContext, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- appendSelect(DbSqlContext, boolean) - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- appendSelect(DbSqlContext, boolean) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Append to the select clause.
- appendSelect(DbSqlContext, boolean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- appendSelect(DbSqlContext, boolean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- appendSelect(DbSqlContext, boolean) - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Append to the select clause.
- appendSql(String) - Method in class io.ebeaninternal.api.BindParams.OrderedList
-
Append parsedSql that has named parameters converted into ?.
- apply() - Method in interface io.ebeaninternal.server.cache.CacheChange
-
Apply the change.
- apply() - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
Apply the changes to the L2 cache except entity/view invalidation.
- apply(DocMapping) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyMapping
-
Apply mapping options to this property.
- apply(DocMapping) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
-
Apply override mapping from the document level or embedded property level.
- apply(DocProperty) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
-
Apply the property level mapping options.
- apply(FetchPath) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- apply(FetchPath) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- applyMapping() - Method in class io.ebeanservice.docstore.api.mapping.DocMappingBuilder
-
Apply any override mappings from the top level docStore annotation.
- applyPath(Query<T>) - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Apply the document structure to the query so that it fetches the required properties to build the document (typically in JSON form).
- applyPath(Query<T>) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- applyRowLimits(SpiQuery<?>) - Method in interface io.ebeaninternal.api.SpiExpressionList
-
Apply firstRow maxRows limits on the filterMany query.
- applyRowLimits(SpiQuery<?>) - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- arrayContains(DbExpressionRequest, String, boolean, Object...) - Method in interface io.ebeaninternal.server.expression.platform.DbExpressionHandler
-
Add SQL for ARRAY CONTAINS expression.
- arrayContains(String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- arrayContains(String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- arrayIsEmpty(DbExpressionRequest, String, boolean) - Method in interface io.ebeaninternal.server.expression.platform.DbExpressionHandler
-
Add SQL for ARRAY IS EMPTY expression.
- arrayIsEmpty(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- arrayIsEmpty(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- arrayIsNotEmpty(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- arrayIsNotEmpty(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- arrayNotContains(String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- arrayNotContains(String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- ArrayStack<E> - Class in io.ebeaninternal.server.util
-
Stack based on ArrayList.
- ArrayStack() - Constructor for class io.ebeaninternal.server.util.ArrayStack
-
Creates an empty Stack.
- ArrayStack(int) - Constructor for class io.ebeaninternal.server.util.ArrayStack
-
Creates an empty Stack with an initial size.
- AS_OF - Enum constant in enum io.ebeaninternal.api.SpiQuery.TemporalMode
-
Query runs 'As Of' a given date time.
- asDraft() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- asDraft() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- asDto(Class<D>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- asDto(Class<D>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- asEnumClass(Type) - Static method in class io.ebeaninternal.server.type.TypeReflectHelper
-
Return the enum class for this type taking into account wildcard type.
- asH2() - Static method in class io.ebeaninternal.api.DbOffline
-
Bring up the next EbeanServer instance using the H2 platform.
- asMany() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- asMany() - Method in interface io.ebeaninternal.server.query.STreePropertyAssocMany
-
Return as BeanPropertyAssocMany.
- asOf(Timestamp) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- asOf(Timestamp) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- asOfTableCount() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Return the count of history table AS OF predicates added via joins.
- asSet() - Method in class io.ebeaninternal.json.ModifyAwareList
-
Create an return a modify aware Set.
- assocExpr(String, String) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Build a string of the logical expressions.
- assocExpr(String, String) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- assocExpr(String, String) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- assocIdExpression(String, String) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
-
Returns null as not an AssocOne.
- assocIdExpression(String, String) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- assocIdExpression(String, String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return the Id expression to add to where clause etc.
- assocIdExpression(String, String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Return the Id expression to add to where clause etc.
- assocIdExpression(String, String) - Method in class io.ebeaninternal.server.el.ElPropertyChain
- assocIdInExpr(String) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
-
Returns null as not an AssocOne.
- assocIdInExpr(String) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- assocIdInExpr(String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return the logical id in expression taking into account embedded id's.
- assocIdInExpr(String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Return the logical id in expression taking into account embedded id's.
- assocIdInExpr(String) - Method in class io.ebeaninternal.server.el.ElPropertyChain
- assocIdInExpr(String) - Method in interface io.ebeaninternal.server.el.ElPropertyValue
-
Return the logical id in expression taking into account embedded id's.
- assocIdInValueExpr(boolean, int) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
-
Returns null as not an AssocOne.
- assocIdInValueExpr(boolean, int) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- assocIdInValueExpr(boolean, int) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return the logical id value expression taking into account embedded id's.
- assocIdInValueExpr(boolean, int) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Return the logical id value expression taking into account embedded id's.
- assocIdInValueExpr(boolean, int) - Method in class io.ebeaninternal.server.el.ElPropertyChain
- assocIdInValueExpr(boolean, int) - Method in interface io.ebeaninternal.server.el.ElPropertyValue
-
Return the logical id value expression taking into account embedded id's.
- assocIdValues(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
-
Returns null as not an AssocOne.
- assocIdValues(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- assocIdValues(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return the Id values from the given bean.
- assocIdValues(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Return the Id values from the given bean.
- assocIdValues(EntityBean) - Method in class io.ebeaninternal.server.el.ElPropertyChain
- assocInExpr(String) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Return the logical id in expression taking into account embedded id's.
- assocInExpr(String) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- assocInExpr(String) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- assocIsEmpty(SpiExpressionRequest, String) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- assocIsEmpty(SpiExpressionRequest, String) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- assocIsEmpty(SpiExpressionRequest, String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- assocIsEmpty(SpiExpressionRequest, String) - Method in class io.ebeaninternal.server.el.ElPropertyChain
- assocIsEmpty(SpiExpressionRequest, String) - Method in interface io.ebeaninternal.server.el.ElPropertyValue
-
Return the logical where clause to support "Is empty".
- asString() - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Return the detail in string form.
- asStringDebug(String, StringBuilder) - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
- asUpdate() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- asUpdate() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- asVersion(B) - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- ATTRIBUTE - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
Find single attribute.
- ATTRIBUTE_SET - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
Find single attribute set.
- auto() - Static method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- AUTO - Enum constant in enum io.ebeaninternal.server.query.SqlJoinType
-
It is automatically determined based on cardinality and optionality.
- autoToOuter() - Method in enum io.ebeaninternal.server.query.SqlJoinType
-
If this is an AUTO join set it to OUTER as we are joining to a Many.
- autoToOuter(SqlJoinType) - Method in enum io.ebeaninternal.server.query.SqlJoinType
-
If join is AUTO but deploymentJoinType is OUTER then go into OUTER join mode.
- autoTune() - Method in class io.ebeaninternal.server.core.DefaultServer
- AutoTuneService - Interface in io.ebeaninternal.server.autotune
-
Collects and manages the the profile information.
- AutoTuneServiceProvider - Interface in io.ebeaninternal.server.autotune
- autowire(Object) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPostConstructListener
B
- backgroundExecutor() - Method in class io.ebeaninternal.server.core.DefaultServer
- baseSql() - Method in interface io.ebeaninternal.api.SpiSqlUpdate
-
Return the sql taking into account bind parameter expansion.
- baseSql() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- baseTable() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the base table to use if user defined on the query.
- baseTable() - Method in interface io.ebeaninternal.api.SpiUpdate
-
Return the name of the table being modified.
- baseTable() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the base table.
- baseTable() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- baseTable() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- baseTable(SpiQuery.TemporalMode) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the base table to use given the query temporal mode.
- baseTable(SpiQuery.TemporalMode) - Method in interface io.ebeaninternal.server.query.STreeType
-
Return the base table to use given the temporalMode.
- baseTableAlias() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return the base table alias for this query.
- baseTableAlias() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the base table alias.
- BaseTablePropertyVisitor - Class in io.ebeaninternal.server.deploy.visitor
-
Used to help mark PropertyVisitor methods that need to be implemented to visit base table properties.
- BaseTablePropertyVisitor() - Constructor for class io.ebeaninternal.server.deploy.visitor.BaseTablePropertyVisitor
- batch() - Method in interface io.ebeaninternal.api.LoadBeanBuffer
- batchControl() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the BatchControl used to batch up persist requests.
- batchControl() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- batchControl() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- batchControl() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- batchControl() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- BatchControl - Class in io.ebeaninternal.server.persist
-
Controls the batch ordering of persist requests.
- BatchControl(SpiTransaction, int, boolean) - Constructor for class io.ebeaninternal.server.persist.BatchControl
-
Create for a given transaction, PersistExecute, default size and getGeneratedKeys.
- batchedPstmt(String) - Method in class io.ebeaninternal.server.persist.BatchedPstmtHolder
-
Return the BatchedPstmt that holds the batched statement.
- BatchedPstmt - Class in io.ebeaninternal.server.persist
-
A batched statement that is held in BatchedPstmtHolder.
- BatchedPstmt(PreparedStatement, boolean, String, SpiTransaction) - Constructor for class io.ebeaninternal.server.persist.BatchedPstmt
-
Create with a given statement.
- BatchedPstmtHolder - Class in io.ebeaninternal.server.persist
-
Used to hold BatchedPstmt objects for batch based execution.
- BatchedSqlException - Exception Class in io.ebeaninternal.server.persist
-
Holds the first SQLException found when executing a JDBC batch.
- BatchPostExecute - Interface in io.ebeaninternal.server.persist
-
Handles the processing required after batch execution.
- batchSize() - Method in interface io.ebeaninternal.api.LoadBeanBuffer
- batchSize() - Method in interface io.ebeaninternal.api.LoadManyBuffer
-
The batch (max) size;
- bean() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the bean associated with this request.
- BEAN - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
Find by Id or unique returning a single bean.
- beanCache(Class<?>) - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- beanCacheHits() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- beanCacheHits() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Return the bean cache hits (when all hits / no misses).
- beanCacheHitsAsMap() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- beanCacheHitsAsMap() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Return the bean cache hits for findMap (when all hits / no misses).
- beanCacheHitsAsSet() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- beanCacheHitsAsSet() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Return the bean cache hits for findMap (when all hits / no misses).
- beanCacheMode() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the cache mode for using the bean cache (Get and Put).
- beanCacheMode() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- BeanCacheResult<T> - Class in io.ebeaninternal.api
-
The results of bean cache hit.
- BeanCacheResult() - Constructor for class io.ebeaninternal.api.BeanCacheResult
- BeanCascadeInfo - Class in io.ebeaninternal.server.deploy
-
Persist info for determining if save or delete should be performed.
- BeanCascadeInfo() - Constructor for class io.ebeaninternal.server.deploy.BeanCascadeInfo
- BeanCollectionHelp<T> - Interface in io.ebeaninternal.server.deploy
-
Helper functions for performing tasks on Lists Sets or Maps.
- BeanCollectionHelpFactory - Class in io.ebeaninternal.server.deploy
-
Creates Helpers specific to the type of the property (List Set or Map).
- BeanCollectionHelpFactory() - Constructor for class io.ebeaninternal.server.deploy.BeanCollectionHelpFactory
- BeanCollectionUtil - Class in io.ebeaninternal.server.deploy
-
Utility methods for BeanCollections.
- BeanCollectionUtil() - Constructor for class io.ebeaninternal.server.deploy.BeanCollectionUtil
- BeanDescriptor<T> - Class in io.ebeaninternal.server.deploy
-
Describes Beans including their deployment information.
- BeanDescriptor(BeanDescriptorMap, DeployBeanDescriptor<T>) - Constructor for class io.ebeaninternal.server.deploy.BeanDescriptor
- BeanDescriptor.EntityType - Enum in io.ebeaninternal.server.deploy
- BeanDescriptorManager - Class in io.ebeaninternal.server.deploy
-
Creates BeanDescriptors.
- BeanDescriptorManager(InternalConfiguration) - Constructor for class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Create for a given database dbConfig.
- BeanDescriptorMap - Interface in io.ebeaninternal.server.deploy
-
Provides a method to find a BeanDescriptor.
- BeanEmbeddedMeta - Class in io.ebeaninternal.server.deploy
- beanFinder() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the beanFinder (Migrate over to getFindController).
- BeanFkeyProperty - Class in io.ebeaninternal.server.deploy
-
Used to evaluate imported foreign keys so as to avoid unnecessary joins.
- BeanFkeyProperty(String, String, int) - Constructor for class io.ebeaninternal.server.deploy.BeanFkeyProperty
- beanId() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the Id value for the bean.
- beanId(Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- beanId(Object, Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- BeanListHelp<T> - Class in io.ebeaninternal.server.deploy
-
Helper object for dealing with Lists.
- BeanListHelpElement<T> - Class in io.ebeaninternal.server.deploy
-
Helper for element collection List.
- beanLoader() - Method in class io.ebeaninternal.server.core.DefaultServer
- beanManager(Class<T>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- BeanManager<T> - Class in io.ebeaninternal.server.deploy
-
Holds the BeanDescriptor and its associated BeanPersister.
- BeanManager(BeanDescriptor<T>, BeanPersister) - Constructor for class io.ebeaninternal.server.deploy.BeanManager
- BeanMapHelp<T> - Class in io.ebeaninternal.server.deploy
-
Helper specifically for dealing with Maps.
- BeanMapHelpElement<T> - Class in io.ebeaninternal.server.deploy
- BeanNaturalKey - Class in io.ebeaninternal.server.deploy
-
Natural key for a bean type.
- BeanPersister - Interface in io.ebeaninternal.server.persist
-
Defines bean insert update and delete implementation.
- BeanPersisterFactory - Interface in io.ebeaninternal.server.persist
-
Factory for creating BeanPersister implementations.
- BeanPersistIdMap - Class in io.ebeaninternal.server.transaction
-
Organises the individual bean persist requests by type.
- BeanPersistIdMap() - Constructor for class io.ebeaninternal.server.transaction.BeanPersistIdMap
- BeanPersistIds - Class in io.ebeaninternal.server.transaction
-
Wraps the information representing a Inserted Updated or Deleted Bean.
- BeanPersistIds(BeanDescriptor<?>) - Constructor for class io.ebeaninternal.server.transaction.BeanPersistIds
-
Create the payload.
- beanProperty() - Method in interface io.ebeaninternal.api.LoadManyBuffer
- beanProperty() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- beanProperty() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- beanProperty() - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Return the Id BeanProperty.
- beanProperty() - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- beanProperty() - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- beanProperty() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- beanProperty() - Method in interface io.ebeaninternal.server.el.ElPropertyDeploy
-
Return the underlying bean property.
- beanProperty(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Get a BeanProperty by its name.
- BeanProperty - Class in io.ebeaninternal.server.deploy
-
Description of a property of a bean.
- BeanProperty(BeanDescriptor<?>, DeployBeanProperty) - Constructor for class io.ebeaninternal.server.deploy.BeanProperty
- BeanProperty(BeanProperty, BeanPropertyOverride) - Constructor for class io.ebeaninternal.server.deploy.BeanProperty
-
Create a Matching BeanProperty with some attributes overridden for Embedded beans.
- BeanProperty(DeployBeanProperty) - Constructor for class io.ebeaninternal.server.deploy.BeanProperty
- BeanPropertyAssoc<T> - Class in io.ebeaninternal.server.deploy
-
Abstract base for properties mapped to an associated bean, list, set or map.
- BeanPropertyAssocMany<T> - Class in io.ebeaninternal.server.deploy
-
Property mapped to a List Set or Map.
- BeanPropertyAssocMany(BeanDescriptor<?>, DeployBeanPropertyAssocMany<T>) - Constructor for class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Create this property.
- BeanPropertyAssocOne<T> - Class in io.ebeaninternal.server.deploy
-
Property mapped to a joined bean.
- BeanPropertyAssocOne(BeanDescriptorMap, BeanDescriptor<?>, DeployBeanPropertyAssocOne<T>) - Constructor for class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Create the property.
- BeanPropertyAssocOne(BeanDescriptorMap, DeployBeanPropertyAssocOne<T>) - Constructor for class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Create based on deploy information of an EmbeddedId.
- BeanPropertyAssocOne(BeanPropertyAssocOne<T>, BeanPropertyOverride) - Constructor for class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- BeanPropertyIdClass - Class in io.ebeaninternal.server.deploy
-
Bean property for an IdClass embeddedId.
- BeanPropertyIdClass(BeanDescriptorMap, BeanDescriptor, DeployBeanPropertyAssocOne) - Constructor for class io.ebeaninternal.server.deploy.BeanPropertyIdClass
- BeanPropertyJsonBasic - Class in io.ebeaninternal.server.deploy
-
A DbJson property that does not use Jackson ObjectMapper.
- BeanPropertyJsonBasic(BeanDescriptor<?>, DeployBeanProperty) - Constructor for class io.ebeaninternal.server.deploy.BeanPropertyJsonBasic
- BeanPropertyJsonBasic(BeanProperty, BeanPropertyOverride) - Constructor for class io.ebeaninternal.server.deploy.BeanPropertyJsonBasic
- BeanPropertyJsonMapper - Class in io.ebeaninternal.server.deploy
-
Handle json property with MutationDetection of SOURCE or HASH only.
- BeanPropertyJsonMapper(BeanDescriptor<?>, DeployBeanProperty) - Constructor for class io.ebeaninternal.server.deploy.BeanPropertyJsonMapper
- BeanPropertyOrderColumn - Class in io.ebeaninternal.server.deploy
-
Bean property for synthetic sort order value / order column.
- BeanPropertyOrderColumn(BeanDescriptor<?>, DeployBeanProperty) - Constructor for class io.ebeaninternal.server.deploy.BeanPropertyOrderColumn
- BeanPropertySimpleCollection<T> - Class in io.ebeaninternal.server.deploy
- BeanPropertySimpleCollection(BeanDescriptor<?>, DeployBeanPropertySimpleCollection<T>) - Constructor for class io.ebeaninternal.server.deploy.BeanPropertySimpleCollection
- BeanPropertyVisitor - Interface in io.ebeaninternal.server.deploy.visitor
-
Used to visit a BeanProperty given the type of bean property it is.
- BeanRequest - Class in io.ebeaninternal.server.core
-
Base class for find and persist requests.
- BeanRequest(SpiEbeanServer, SpiTransaction) - Constructor for class io.ebeaninternal.server.core.BeanRequest
- BeanSetHelp<T> - Class in io.ebeaninternal.server.deploy
-
Helper specifically for dealing with Sets.
- BeanSetHelpElement<T> - Class in io.ebeaninternal.server.deploy
-
Helper for element collection List.
- beanState(Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- beanTable() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return the underlying BeanTable for this property.
- beanTable(Class<?>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- BeanTable - Class in io.ebeaninternal.server.deploy
-
Used for associated beans in place of a BeanDescriptor.
- BeanTable(BeanDescriptorMap, String, Class<?>) - Constructor for class io.ebeaninternal.server.deploy.BeanTable
-
Construct for element collection.
- BeanTable(DeployBeanTable, BeanDescriptorMap) - Constructor for class io.ebeaninternal.server.deploy.BeanTable
-
Create the BeanTable.
- beanType() - Method in class io.ebeaninternal.api.LoadBeanRequest
- beanType() - Method in class io.ebeaninternal.api.LoadManyRequest
- beanType() - Method in class io.ebeaninternal.api.LoadRequest
-
Return the associated bean type for this load request.
- beanType() - Method in interface io.ebeaninternal.api.SpiQueryPlan
-
The related entity bean type
- beanType() - Method in interface io.ebeaninternal.api.SpiUpdate
-
Return the type of bean being updated.
- beanType() - Method in class io.ebeaninternal.server.query.CQueryPlan
- beanType() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- beanType(Class<?>) - Method in interface io.ebeaninternal.api.SpiBeanTypeManager
-
Return the bean type for the given entity class.
- beanType(Class<?>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- beanType(Class<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Return the SPI bean types for the given bean class.
- beanTypeAtPath(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- beanTypeForQueueId(String) - Method in class io.ebeaninternal.server.core.DefaultServer
- beanTypes() - Method in class io.ebeaninternal.server.core.DefaultServer
-
Return all the SPI BeanTypes.
- beanTypes(String) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Return the SPI bean types mapped to the given table.
- beanTypes(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Return the BeanDescriptors mapped to the table.
- beanVisitor(Object, Map<String, Object>) - Method in interface io.ebeaninternal.api.json.SpiJsonReader
- beanVisitor(Object, Map<String, Object>) - Method in class io.ebeaninternal.server.json.ReadJson
-
If there is a JsonReadBeanVisitor registered to the current path then call it's visit method with the bean and unmappedProperties.
- beginAssocMany(String) - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
Start a Many.
- beginAssocMany(String) - Method in class io.ebeaninternal.server.json.WriteJson
- beginAssocManyMap(String, boolean) - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
Start a Many.
- beginAssocManyMap(String, boolean) - Method in class io.ebeaninternal.server.json.WriteJson
- beginAssocOne(String, EntityBean) - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
Start an assoc one path.
- beginAssocOne(String, EntityBean) - Method in class io.ebeaninternal.server.json.WriteJson
- beginIterate() - Method in class io.ebeaninternal.server.transaction.DefaultPersistenceContext
- beginScopedTransaction(TxScope) - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Begin a scoped transaction.
- beginServerTransaction() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Begin a managed transaction (Uses scope manager / ThreadLocal).
- beginServerTransaction() - Method in class io.ebeaninternal.server.core.DefaultServer
- beginServerTransaction() - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Begin an implicit transaction.
- beginTransaction() - Method in class io.ebeaninternal.server.core.DefaultServer
- beginTransaction(TxIsolation) - Method in class io.ebeaninternal.server.core.DefaultServer
- beginTransaction(TxScope) - Method in class io.ebeaninternal.server.core.DefaultServer
- between(String, Object, Object) - Method in class io.ebeaninternal.server.el.ElFilter
- between(String, Object, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Between - property between the two given values.
- between(String, Object, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- BETWEEN - Enum constant in enum io.ebeaninternal.server.expression.Op
-
Between (JSON).
- betweenProperties(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Between - value between two given properties.
- betweenProperties(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- binary() - Method in class io.ebeaninternal.server.type.ScalarTypeBytesBase
- binary() - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- binary() - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- binary() - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- BinaryReadContext - Class in io.ebeaninternal.api
-
Context used to read binary format messages.
- BinaryReadContext(byte[]) - Constructor for class io.ebeaninternal.api.BinaryReadContext
-
Create with protocol 0 and byte data.
- BinaryReadContext(DataInputStream) - Constructor for class io.ebeaninternal.api.BinaryReadContext
-
Create with protocol version and DataInputStream data.
- BinaryTransactionEventReader - Class in io.ebeaninternal.server.cluster
-
Mechanism to convert RemoteTransactionEvent to/from byte[] content.
- BinaryTransactionEventReader(ServerLookup) - Constructor for class io.ebeaninternal.server.cluster.BinaryTransactionEventReader
- BinaryWritable - Interface in io.ebeaninternal.api
-
Messages that can be sent in binary form.
- BinaryWriteContext - Class in io.ebeaninternal.api
-
Context used to write binary message (like RemoteTransactionEvent).
- BinaryWriteContext(DataOutputStream) - Constructor for class io.ebeaninternal.api.BinaryWriteContext
- bind() - Method in enum io.ebeaninternal.server.expression.Op
-
Return the bind expression include JDBC ?
- bind(int, SqlUpdate, EntityBean) - Method in interface io.ebeaninternal.server.deploy.id.ImportedId
-
Bind the imported Id value to the SqlUpdate.
- bind(int, SqlUpdate, EntityBean) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdEmbedded
- bind(int, SqlUpdate, EntityBean) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- bind(DataBinder, byte[]) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesBase
- bind(DataBinder, byte[]) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- bind(DataBinder, int, Object) - Method in interface io.ebeaninternal.server.type.GeoTypeBinder
-
Bind the geometry type.
- bind(DataBinder, B) - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- bind(DataBinder, Boolean) - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.Native
- bind(DataBinder, String) - Method in class io.ebeaninternal.server.type.ScalarTypeString
- bind(DataBinder, UUID) - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- bind(DataBinder, T) - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- bind(BindParams, DataBind, StringBuilder) - Method in class io.ebeaninternal.server.persist.Binder
-
Bind the list of positionedParameters in BindParams.
- bind(BindParams, PreparedStatement, Connection) - Method in class io.ebeaninternal.server.persist.Binder
-
Bind the parameters to the preparedStatement returning the bind log.
- bind(DataBind) - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
-
Bind the values from the underlying expression list.
- bind(DataBind) - Method in class io.ebeaninternal.server.query.CQueryPredicates
- bind(DataBind, Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- bind(Binder, DataBind) - Method in class io.ebeaninternal.server.querydefn.OrmUpdateProperties
-
Bind all the bind values for the update set clause.
- bind(Binder, DataBind) - Method in class io.ebeaninternal.server.querydefn.OrmUpdateProperties.Value
- bind(BindableRequest, EntityBean) - Method in interface io.ebeaninternal.server.deploy.id.ImportedId
-
Bind the value from the bean.
- bind(BindableRequest, EntityBean) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdEmbedded
- bind(BindableRequest, EntityBean) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- bind(PreparedStatement, Connection) - Method in class io.ebeaninternal.server.query.CQueryPredicates
- bindCapture() - Method in class io.ebeaninternal.api.ExtraMetrics
-
Timed metric for bind capture used with query plan collection.
- bindClause() - Method in class io.ebeaninternal.server.querydefn.OrmUpdateProperties.Value
- bindElementValue(SqlUpdate, Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Bind all the property values to the SqlUpdate.
- bindElementValue(SqlUpdate, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Bind all the property values to the SqlUpdate.
- bindElementValue(SqlUpdate, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertySimpleCollection
- bindEqSql(String) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Return the sql for binding the id to.
- bindEqSql(String) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- bindEqSql(String) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- Binder - Class in io.ebeaninternal.server.persist
-
Binds bean values to a PreparedStatement.
- Binder(TypeManager, SpiLogManager, int, boolean, DbExpressionHandler, DataTimeZone, MultiValueBind) - Constructor for class io.ebeaninternal.server.persist.Binder
- bindId(DataBind, Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Bind the idValue to the preparedStatement.
- bindId(DataBind, Object) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Binds an id value to a prepared statement.
- bindId(DataBind, Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- bindId(DataBind, Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- bindId(DefaultSqlUpdate, Object) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Bind the id value to a SqlUpdate statement.
- bindId(DefaultSqlUpdate, Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- bindId(DefaultSqlUpdate, Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- bindIdValues(Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the id as an array of scalar bindable values.
- bindImport(SqlUpdate, EntityBean) - Method in interface io.ebeaninternal.server.deploy.id.ImportedId
-
Bind values to the intersection SqlUpdate.
- bindImport(SqlUpdate, EntityBean) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdEmbedded
- bindImport(SqlUpdate, EntityBean) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- bindInSql(String) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Return the sql for binding the id using an IN clause.
- bindInSql(String) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- bindInSql(String) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- bindLog - Variable in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
- bindLog() - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- bindLog() - Method in class io.ebeaninternal.server.query.CQuery
- bindMaxLength() - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- bindMaxLength() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- bindMaxLength() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- BindMaxLength - Interface in io.ebeaninternal.server.deploy
-
The max length check on bind values.
- BindMaxLength.Standard - Class in io.ebeaninternal.server.deploy
-
Standard string length implementation.
- BindMaxLength.UTF8 - Class in io.ebeaninternal.server.deploy
-
Length check based on UTF8 bytes.
- bindObject(DataBind, Object) - Method in class io.ebeaninternal.server.persist.Binder
-
Bind an Object with unknown data type.
- BindPadding - Class in io.ebeaninternal.server.core
-
Supports padding bind parameters for IN expressions.
- BindPadding() - Constructor for class io.ebeaninternal.server.core.BindPadding
- bindParams() - Method in interface io.ebeaninternal.api.SpiCallableSql
- bindParams() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the bind parameters.
- bindParams() - Method in interface io.ebeaninternal.api.SpiSqlUpdate
-
Return the Bind parameters.
- bindParams() - Method in interface io.ebeaninternal.api.SpiUpdate
-
Return the bind parameters.
- bindParams() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
-
Return the bind parameters.
- bindParams() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- bindParams() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
-
Return the bind parameters.
- BindParams - Class in io.ebeaninternal.api
-
Parameters used for binding to a statement.
- BindParams() - Constructor for class io.ebeaninternal.api.BindParams
- BindParams.OrderedList - Class in io.ebeaninternal.api
-
The bind parameters in the correct binding order.
- BindParams.Param - Class in io.ebeaninternal.api
-
A In Out capable parameter for the CallableStatement.
- BindParamsParser - Class in io.ebeaninternal.server.util
-
Parses the BindParams if they are using named parameters.
- bindSet(DmlHandler, EntityBean) - Method in interface io.ebeaninternal.api.SpiUpdatePlan
-
Bind given the request and bean.
- bindValue - Variable in class io.ebeaninternal.server.expression.SimpleExpression
- bindValues() - Method in interface io.ebeaninternal.api.SpiExpressionRequest
-
Return the ordered list of bind values for all expressions in this request.
- bindValues() - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- bindValues(Object) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Return the values as an array of scalar bindable values.
- bindValues(Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- bindValues(Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- BindValuesKey - Class in io.ebeaninternal.api
-
BindValues used for L2 query cache key matching.
- BindValuesKey() - Constructor for class io.ebeaninternal.api.BindValuesKey
- bitwise(DbExpressionRequest, String, BitwiseOp, long, String, long) - Method in interface io.ebeaninternal.server.expression.platform.DbExpressionHandler
-
Add the bitwise expression.
- bitwiseAll(String, long) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- bitwiseAll(String, long) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- bitwiseAnd(String, long, long) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- bitwiseAnd(String, long, long) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- bitwiseAny(String, long) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- bitwiseAny(String, long) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- bitwiseNot(String, long) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- BitwiseOp - Enum in io.ebeaninternal.server.expression
-
Bitwise expression operator.
- boost() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- boost(Float) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- BootupClasses - Class in io.ebeaninternal.server.core.bootup
-
Interesting classes for a EbeanServer such as Embeddable, Entity, ScalarTypes, Finders, Listeners and Controllers.
- BootupClasses() - Constructor for class io.ebeaninternal.server.core.bootup.BootupClasses
- BootupClasses(Set<Class<?>>) - Constructor for class io.ebeaninternal.server.core.bootup.BootupClasses
- BootupClassPathSearch - Class in io.ebeaninternal.server.core.bootup
-
Searches for interesting classes such as Entities, Embedded and ScalarTypes.
- broadcast(RemoteTransactionEvent) - Method in interface io.ebeaninternal.server.cluster.ClusterBroadcast
-
Send a transaction event to all the members of the cluster.
- broadcast(RemoteTransactionEvent) - Method in class io.ebeaninternal.server.cluster.ClusterManager
-
Send the message headers and payload to every server in the cluster.
- bufferFetchSizeHint() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the hint for Statement.setFetchSize().
- bufferFetchSizeHint() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- build() - Method in class io.ebeaninternal.server.deploy.IntersectionBuilder
- build() - Method in class io.ebeaninternal.server.el.ElPropertyChainBuilder
-
Build the immutable ElGetChain from the build information.
- build() - Method in class io.ebeaninternal.server.query.SqlTreeBuilder
-
Build based on the includes and using the BeanJoinTree.
- buildCacheChanges(TransactionManager) - Method in class io.ebeaninternal.api.TransactionEvent
-
Build and return the cache changeSet.
- buildElPropertyValue(String, String, ElPropertyChainBuilder, boolean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- buildElPropertyValue(String, String, ElPropertyChainBuilder, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- buildElPropertyValue(String, String, ElPropertyChainBuilder, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- buildIdentityMode() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the immutable IdentityMode.
- buildImport(IntersectionBuilder) - Method in interface io.ebeaninternal.server.deploy.id.ImportedId
-
Add DB columns to the intersection builder.
- buildImport(IntersectionBuilder) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdEmbedded
- buildImport(IntersectionBuilder) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- buildImport(IntersectionRow, EntityBean) - Method in interface io.ebeaninternal.server.deploy.id.ImportedId
-
For inserting into ManyToMany intersection.
- buildImport(IntersectionRow, EntityBean) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdEmbedded
- buildImport(IntersectionRow, EntityBean) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- buildKeys() - Method in class io.ebeaninternal.api.NaturalKeyQueryData
-
Build and return the set of natural keys we will use.
- buildManyDeleteChildren(EntityBean, Set<Object>) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- buildManyToManyDeleteChildren(EntityBean, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- buildManyToManyMapBean(EntityBean, EntityBean, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- buildPlan(DtoMappingRequest) - Method in interface io.ebeaninternal.api.SpiDtoQuery
-
Build the query plan.
- buildPlan(DtoMappingRequest) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- buildQuery(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.CQueryEngine
- buildQueryPlanHash(StringBuilder) - Method in class io.ebeaninternal.api.BindParams
-
Calculate and return a query plan bind hash with total bind count.
- buildRawSqlSelectChain(String, List<String>) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- buildRawSqlSelectChain(String, List<String>) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- buildRawSqlSelectChain(String, List<String>) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- buildRawSqlSelectChain(String, List<String>) - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- buildRawSqlSelectChain(String, List<String>) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
- buildRawSqlSelectChain(String, List<String>) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- buildRawSqlSelectChain(String, List<String>) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- buildRawSqlSelectChain(String, List<String>) - Method in interface io.ebeaninternal.server.query.STreeProperty
-
For RawSql build the select chain.
- buildSetClause(DeployParser) - Method in class io.ebeaninternal.server.querydefn.OrmUpdateProperties
-
Build the actual set clause converting logical property names to db columns etc.
- buildSql() - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
-
Build sql for the underlying expression list.
- BulkEventListenerMap - Class in io.ebeaninternal.server.transaction
- BulkEventListenerMap(List<BulkTableEventListener>) - Constructor for class io.ebeaninternal.server.transaction.BulkEventListenerMap
- BY_LAST_ACCESS - Static variable in class io.ebeaninternal.server.cache.DefaultServerCache
-
Compare by last access time (for LRU eviction).
C
- cacheApplyBeanUpdate(String, Map<String, Object>, boolean, long) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Apply the update to the cache.
- cacheApplyInvalidate(Collection<Object>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Remove a collection of beans from the cache given the ids.
- cacheBeanGet(Object, Boolean, PersistenceContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return a bean from the bean cache (or null).
- cacheBeanLoad(EntityBean, EntityBeanIntercept, Object, PersistenceContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Returns true if it managed to populate/load the bean from the cache.
- cacheBeanLoadAll(Set<EntityBeanIntercept>, PersistenceContext, int, String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Hit the bean cache trying to load a list/batch of entities.
- cacheBeanPut(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Put a bean into the bean cache (taking into account inheritance).
- cacheBeanPut(T) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Put the bean into the cache.
- cacheBeanPutAll(Collection<?>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- CacheChange - Interface in io.ebeaninternal.server.cache
-
A change to the cache.
- CacheChangeSet - Class in io.ebeaninternal.server.cache
-
List of changes to be applied to L2 cache.
- CacheChangeSet() - Constructor for class io.ebeaninternal.server.cache.CacheChangeSet
-
Construct specifying if we also need to process invalidation for entities based on views.
- cacheClear(Class<?>) - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
-
Add a cache clear event for the given bean type.
- cacheClear(String, Class<?>) - Method in class io.ebeaninternal.server.cluster.ClusterManager
-
Broadcast a cache clear event to the cluster.
- cacheClearAll() - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
-
Add a cache clearAll event.
- cacheClearAll(String) - Method in class io.ebeaninternal.server.cluster.ClusterManager
-
Broadcast a cache clear all event to the cluster.
- CachedBeanData - Class in io.ebeaninternal.server.cache
-
Data held in the bean cache for cached beans.
- CachedBeanData() - Constructor for class io.ebeaninternal.server.cache.CachedBeanData
-
Construct from serialisation.
- CachedBeanData(Object, String, Map<String, Object>, long) - Constructor for class io.ebeaninternal.server.cache.CachedBeanData
-
Construct from a loaded bean.
- CachedBeanDataFromBean - Class in io.ebeaninternal.server.cache
- CachedBeanDataFromBean() - Constructor for class io.ebeaninternal.server.cache.CachedBeanDataFromBean
- CachedBeanDataToBean - Class in io.ebeaninternal.server.cache
- CachedBeanDataToBean() - Constructor for class io.ebeaninternal.server.cache.CachedBeanDataToBean
- CachedBeanId - Class in io.ebeaninternal.server.cache
-
Bean Id value plus discriminator type.
- CachedBeanId() - Constructor for class io.ebeaninternal.server.cache.CachedBeanId
-
Construct from serialisation.
- CachedBeanId(String, Object) - Constructor for class io.ebeaninternal.server.cache.CachedBeanId
- CachedManyIds - Class in io.ebeaninternal.server.cache
-
The cached data for O2M and M2M relationships.
- CachedManyIds() - Constructor for class io.ebeaninternal.server.cache.CachedManyIds
-
Construct for serialization.
- CachedManyIds(List<Object>) - Constructor for class io.ebeaninternal.server.cache.CachedManyIds
- cacheEmbeddedBeanExtract(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Extract the raw cache data from the embedded bean.
- cacheEmbeddedBeanLoad(CachedBeanData, PersistenceContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Load the embedded bean (taking into account inheritance).
- CacheEntry(Object, Object) - Constructor for class io.ebeaninternal.server.cache.DefaultServerCache.CacheEntry
- cacheIdLookup() - Method in interface io.ebeaninternal.api.SpiQuery
-
Bean cache lookup for find by ids.
- cacheIdLookup() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- cacheIdLookup(PersistenceContext, Collection<?>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- CacheIdLookup<T> - Interface in io.ebeaninternal.api
-
Process Cache lookup by Id(s).
- CacheIdLookupMany<T> - Class in io.ebeaninternal.api
-
Used for bean cache lookup with where ids in expression.
- CacheIdLookupMany(IdInCommon) - Constructor for class io.ebeaninternal.api.CacheIdLookupMany
- CacheIdLookupSingle<T> - Class in io.ebeaninternal.api
-
Used for bean cache lookup with a single id value.
- CacheIdLookupSingle(Object) - Constructor for class io.ebeaninternal.api.CacheIdLookupSingle
- cacheKey(Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the cache key for the given id value.
- cacheKey(Object) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Return a key to use for bean caches given the id value.
- cacheKey(Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- cacheKey(Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- cacheKeyForBean(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the cache key for the given bean (based on id value).
- cacheKeyFromBean(EntityBean) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Return a key to use for bean caches given the bean.
- cacheKeyFromBean(EntityBean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- cacheKeyFromBean(EntityBean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- cacheManager() - Method in class io.ebeaninternal.server.core.DefaultServer
- cacheManager() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- cacheManager() - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- cacheManager() - Method in interface io.ebeaninternal.server.deploy.BeanDescriptorMap
-
Return the Cache Manager.
- CacheManagerOptions - Class in io.ebeaninternal.server.cache
-
Configuration options when creating the default cache manager.
- CacheManagerOptions(ClusterManager, DatabaseBuilder.Settings, boolean) - Constructor for class io.ebeaninternal.server.cache.CacheManagerOptions
- cacheManyPropClear(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- cacheManyPropLoad(BeanPropertyAssocMany<?>, BeanCollection<?>, String, Boolean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Try to load the beanCollection from cache return true if successful.
- cacheManyPropPut(BeanPropertyAssocMany<?>, BeanCollection<?>, String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Put the beanCollection into the cache.
- cacheManyPropPut(String, String, CachedManyIds) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Update the bean collection entry in the cache.
- cacheManyPropRemove(String, String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- cacheNaturalKeyPut(String, String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- cacheNotify(TransactionEventTable.TableIUD, CacheChangeSet) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
For SQL based modifications we need to invalidate appropriate parts of the cache.
- cacheOptions() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the cache options.
- CacheOptions - Class in io.ebeaninternal.server.core
-
Options for controlling cache behaviour for a given type.
- CacheOptions(Cache, String[]) - Constructor for class io.ebeaninternal.server.core.CacheOptions
-
Construct with cache annotation.
- cachePersistDelete(Object, PersistRequestBean<T>, CacheChangeSet) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Remove a bean from the cache given its Id.
- cachePersistDeleteByIds(Collection<Object>, CacheChangeSet) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Remove a bean from the cache given its Id.
- cachePersistInsert(PersistRequestBean<T>, CacheChangeSet) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Add the insert changes to the changeSet.
- cachePersistUpdate(Object, PersistRequestBean<T>, CacheChangeSet) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Add the update to the changeSet.
- cacheUpdateQuery(boolean, SpiTransaction) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Check if bulk update or delete query has a cache impact.
- calcQueryPlanHash() - Method in class io.ebeaninternal.api.BindParams
-
Return the hash that should be included with the query plan.
- calculateKey(Map<String, Object>) - Method in class io.ebeaninternal.server.deploy.BeanNaturalKey
-
Return the cache key given the bind values.
- call() - Method in class io.ebeaninternal.server.query.CallableQueryCount
-
Execute the query returning the row count.
- call() - Method in class io.ebeaninternal.server.query.CallableQueryIds
-
Execute the find Id's query returning the list of Id's.
- call() - Method in class io.ebeaninternal.server.query.CallableQueryList
-
Execute the query returning the resulting List.
- CallableQueryCount<T> - Class in io.ebeaninternal.server.query
-
Represent the findCount query as a Callable.
- CallableQueryCount(SpiEbeanServer, SpiQuery<T>, boolean) - Constructor for class io.ebeaninternal.server.query.CallableQueryCount
-
Note that the transaction passed in is always a new transaction solely to find the row count so it must be cleaned up by this CallableQueryRowCount.
- CallableQueryIds<T> - Class in io.ebeaninternal.server.query
-
Represent the fetch Id's query as a Callable.
- CallableQueryIds(SpiEbeanServer, SpiQuery<T>, boolean) - Constructor for class io.ebeaninternal.server.query.CallableQueryIds
- CallableQueryList<T> - Class in io.ebeaninternal.server.query
-
Represent the findList query as a Callable.
- CallableQueryList(SpiEbeanServer, SpiQuery<T>, boolean) - Constructor for class io.ebeaninternal.server.query.CallableQueryList
- callableSql() - Method in class io.ebeaninternal.server.core.PersistRequestCallableSql
-
Return the CallableSql.
- CALLABLESQL - Enum constant in enum io.ebeaninternal.server.core.PersistRequest.Type
- CallOriginFactory - Interface in io.ebeaninternal.server.core
-
Creates CallOrigin based on the stack trace.
- cancel() - Method in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
- cancel() - Method in interface io.ebeaninternal.server.query.CancelableQuery
-
Cancel the query.
- cancel() - Method in class io.ebeaninternal.server.query.CQuery
- cancel() - Method in class io.ebeaninternal.server.querydefn.AbstractQuery
- cancel(boolean) - Method in class io.ebeaninternal.server.query.QueryFutureIds
- cancel(boolean) - Method in class io.ebeaninternal.server.query.QueryFutureList
- cancel(boolean) - Method in class io.ebeaninternal.server.query.QueryFutureRowCount
- CancelableQuery - Interface in io.ebeaninternal.server.query
-
Defines a cancelable query.
- cascadeInfo() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Get the persist info.
- caughtError(Error) - Method in class io.ebeaninternal.api.ScopedTransaction
-
Rollback for Error.
- caughtError(Error) - Method in class io.ebeaninternal.api.ScopeTrans
-
An Error was caught and this ALWAYS causes a rollback to occur.
- caughtThrowable(Exception) - Method in class io.ebeaninternal.api.ScopedTransaction
-
Maybe rollback based on TxScope rollback on settings.
- caughtThrowable(T) - Method in class io.ebeaninternal.api.ScopeTrans
-
An Exception was caught and may or may not cause a rollback to occur.
- ChainedBeanPersistController - Class in io.ebeaninternal.server.deploy
-
Chains multiple BeanPersistController's together.
- ChainedBeanPersistController(BeanPersistController, BeanPersistController) - Constructor for class io.ebeaninternal.server.deploy.ChainedBeanPersistController
-
Construct adding 2 BeanPersistController's.
- ChainedBeanPersistController(List<BeanPersistController>) - Constructor for class io.ebeaninternal.server.deploy.ChainedBeanPersistController
-
Construct given the list of BeanPersistController's.
- ChainedBeanPersistListener - Class in io.ebeaninternal.server.deploy
-
Handles multiple BeanPersistListener's for a given entity type.
- ChainedBeanPersistListener(List<BeanPersistListener>) - Constructor for class io.ebeaninternal.server.deploy.ChainedBeanPersistListener
-
Construct given the list of BeanPersistListener's.
- ChainedBeanPostConstructListener - Class in io.ebeaninternal.server.deploy
-
Handles multiple BeanPostLoad's for a given entity type.
- ChainedBeanPostConstructListener(List<BeanPostConstructListener>) - Constructor for class io.ebeaninternal.server.deploy.ChainedBeanPostConstructListener
-
Construct given the list of BeanPostCreate's.
- ChainedBeanPostLoad - Class in io.ebeaninternal.server.deploy
-
Handles multiple BeanPostLoad's for a given entity type.
- ChainedBeanPostLoad(List<BeanPostLoad>) - Constructor for class io.ebeaninternal.server.deploy.ChainedBeanPostLoad
-
Construct given the list of BeanPostLoad's.
- ChainedBeanQueryAdapter - Class in io.ebeaninternal.server.deploy
-
Handles multiple BeanQueryAdapter for a given entity type.
- ChainedBeanQueryAdapter(List<BeanQueryAdapter>) - Constructor for class io.ebeaninternal.server.deploy.ChainedBeanQueryAdapter
-
Construct given the list of BeanQueryAdapter's.
- changedProps() - Method in class io.ebeaninternal.server.core.DefaultBeanState
- changeLogBean(PersistRequestBean<T>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this request should be included in the change log.
- changeLogListener() - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Return the changeLogListener (that actually does the logging).
- changeLogListener(ChangeLogListener) - Method in class io.ebeaninternal.server.core.InternalConfiguration
-
Return the ChangeLogListener to use with a default implementation if none defined.
- changeLogPrepare() - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Return the changeLogPrepare (for setting user context into the ChangeSet in the foreground thread).
- changeLogPrepare(ChangeLogPrepare) - Method in class io.ebeaninternal.server.core.InternalConfiguration
-
Return the ChangeLogPrepare to use with a default implementation if none defined.
- changeLogRegister(ChangeLogRegister) - Method in class io.ebeaninternal.server.core.InternalConfiguration
-
Return the ChangeLogRegister to use with a default implementation if none defined.
- CharMatch - Class in io.ebeaninternal.server.el
-
Case insensitive string matching.
- CharMatch(String) - Constructor for class io.ebeaninternal.server.el.CharMatch
- checkAllMutableProperties(EntityBeanIntercept) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Check all mutable scalar types and mark as dirty if necessary.
- checkAnyMutableProperties(EntityBeanIntercept) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if any mutable properties are dirty.
- checkBatchEscalationOnCascade() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Check for batch escalation on cascade.
- checkBatchEscalationOnCascade(PersistRequestBean<?>) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return true if batch mode got escalated for this request (and associated cascades).
- checkBatchEscalationOnCascade(PersistRequestBean<?>) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- checkBatchEscalationOnCascade(PersistRequestBean<?>) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- checkBatchEscalationOnCascade(PersistRequestBean<?>) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- checkBatchEscalationOnCascade(PersistRequestBean<?>) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- checkBatchEscalationOnCollection() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Potentially escalate batch mode on saving or deleting a collection.
- checkBatchEscalationOnCollection() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- checkBatchEscalationOnCollection() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- checkBatchEscalationOnCollection() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- checkBatchEscalationOnCollection() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- checkCancelled() - Method in interface io.ebeaninternal.api.SpiCancelableQuery
-
Checks if the query was cancelled.
- checkCancelled() - Method in class io.ebeaninternal.server.querydefn.AbstractQuery
- checkDraft() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Checks for @Draftable entity beans with @Draft property that the bean is a 'draft'.
- checkEmpty() - Method in class io.ebeaninternal.api.LoadBeanRequest
-
Return true if the batch is empty.
- checkForEmpty(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyJsonBasic
- checkInheritanceMapping() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Check the mapping for class inheritance
- checkNamedParameters() - Method in interface io.ebeaninternal.api.SpiQuery
-
Check that the named parameters have had their values set.
- checkNamedParameters() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- checkPagingOrderBy() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if the query should have an order by appended automatically.
- checkPagingOrderBy() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- checkPrimitiveBoolean() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Primitive boolean check so see if not null default false should be applied.
- checkRowCount(int) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Check for optimistic concurrency exception.
- checkRowCount(int) - Method in class io.ebeaninternal.server.core.PersistRequestCallableSql
-
Note the rowCount of the execution.
- checkRowCount(int) - Method in class io.ebeaninternal.server.core.PersistRequestOrmUpdate
-
No concurrency checking so just note the rowCount.
- checkRowCount(int) - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
-
No concurrency checking so just note the rowCount.
- checkRowCount(int) - Method in interface io.ebeaninternal.server.persist.BatchPostExecute
-
Check that the rowCount is correct for this execute.
- checksum(String) - Static method in class io.ebeaninternal.server.util.Checksum
-
Return the checksum for the given String input.
- Checksum - Class in io.ebeaninternal.server.util
-
Compute a checksum for String content.
- Checksum() - Constructor for class io.ebeaninternal.server.util.Checksum
- checkUniqueness(Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- checkUniqueness(Object, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- children() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyMapping
-
Return the child nested properties.
- ClassPathScanners - Class in io.ebeaninternal.server.core
-
Utility to finds and return the list of ClassPathScanner services.
- ClassPathScanners() - Constructor for class io.ebeaninternal.server.core.ClassPathScanners
- clear() - Method in class io.ebeaninternal.json.ModifyAwareList
- clear() - Method in class io.ebeaninternal.json.ModifyAwareMap
- clear() - Method in class io.ebeaninternal.json.ModifyAwareSet
- clear() - Method in class io.ebeaninternal.server.cache.DefaultServerCache
-
Clear the cache.
- clear() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
-
Clear the join columns due to an implied mappedBy.
- clear() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- clear() - Method in class io.ebeaninternal.server.persist.BatchControl
-
Clears the batch, discarding all batched statements.
- clear() - Method in class io.ebeaninternal.server.persist.BatchedPstmtHolder
- clear() - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- clear() - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Remove all joins and properties.
- clear() - Method in class io.ebeaninternal.server.transaction.DefaultPersistenceContext
- clear() - Method in class io.ebeaninternal.server.transaction.DefaultTransactionScopeManager
- clear() - Method in class io.ebeaninternal.server.transaction.TransactionScopeManager
-
Clears the current Transaction from thread local scope (for implicit transactions).
- clear(Class<?>) - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- clear(Class<?>) - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
- clear(Class<?>) - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Clear the caches for the given bean type.
- clear(Class<?>) - Method in class io.ebeaninternal.server.transaction.DefaultPersistenceContext
- clear(Class<?>, Object) - Method in class io.ebeaninternal.server.transaction.DefaultPersistenceContext
- clearAll() - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- clearAll() - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
-
Clear all caches.
- clearAll() - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Clear all the caches.
- clearAllLocal() - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- clearAllLocal() - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
- clearAllLocal() - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Clear all local caches.
- clearBeanCache() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- clearContext() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- clearCount - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- clearExternal() - Method in class io.ebeaninternal.server.transaction.DefaultTransactionScopeManager
- clearExternal() - Method in class io.ebeaninternal.server.transaction.TransactionScopeManager
-
Clears the current Transaction from thread local scope without any check for active transactions.
- clearLocal(Class<?>) - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- clearLocal(Class<?>) - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
- clearLocal(Class<?>) - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Clear local caches for the given bean type.
- clearQueryCache() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Clear the query cache.
- clearQueryStatistics() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Clear the query execution statistics.
- clearQueryStatistics() - Method in class io.ebeaninternal.server.core.DefaultServer
-
Clear the query execution statistics.
- clearQueryStatistics() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Reset the statistics on all the query plans.
- clearServerTransaction() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Clear an implicit transaction from the scope.
- clearServerTransaction() - Method in class io.ebeaninternal.server.core.DefaultServer
- clearServerTransaction() - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Clear an implicit transaction from thread local scope.
- clearTableJoin() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Clear the table join due to an implied mappedBy.
- clearTransIfRequired() - Method in class io.ebeaninternal.server.core.BeanRequest
-
Clear the transaction from the thread local for implicit transactions.
- clockNow() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return the NOW time from the Clock.
- clockNow() - Method in class io.ebeaninternal.server.core.DefaultServer
- clockSeq - Variable in class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
- ClockService - Class in io.ebeaninternal.server.core
-
Wraps the Clock such that we can change the Clock for testing purposes.
- ClockService(Clock) - Constructor for class io.ebeaninternal.server.core.ClockService
- close() - Method in class io.ebeaninternal.api.ScopedTransaction
- close() - Method in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
-
Close the underlying resources.
- close() - Method in class io.ebeaninternal.server.persist.BatchedPstmt
-
Close the underlying statement.
- close() - Method in class io.ebeaninternal.server.query.CQuery
-
Close the resources.
- close() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Alias for end(), which enables this class to be used in try-with-resources.
- close() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Alias for end(), which enables this class to be used in try-with-resources.
- close() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Alias for end(), which enables this class to be used in try-with-resources.
- close() - Method in class io.ebeaninternal.server.type.RsetDataReader
- ClusterBroadcast - Interface in io.ebeaninternal.server.cluster
-
Sends messages to the cluster members.
- ClusterBroadcastFactory - Interface in io.ebeaninternal.server.cluster
-
Factory to create the cluster broadcast service.
- ClusterManager - Class in io.ebeaninternal.server.cluster
-
Manages the cluster service.
- ClusterManager(ContainerConfig) - Constructor for class io.ebeaninternal.server.cluster.ClusterManager
- code() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- code(Boolean) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- collect(QueryPlanRequest) - Method in interface io.ebeaninternal.api.QueryPlanManager
-
Collect the database query plans.
- collect(QueryPlanRequest) - Method in class io.ebeaninternal.server.query.CQueryPlanManager
- collect(String, long) - Method in interface io.ebeaninternal.server.core.RelationalQueryEngine
-
Collect SQL query execution statistics.
- collect(String, long) - Method in class io.ebeaninternal.server.query.DefaultRelationalQueryEngine
- collectFor(long) - Method in interface io.ebeaninternal.api.SpiQueryBindCapture
-
Return true if the query just executed should be bind captured to collect the query plan from (as the query time is large / interesting).
- collection() - Method in interface io.ebeaninternal.server.deploy.ElementCollector
-
Return the populated collection/map.
- collectionIdsCache(Class<?>, String) - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- collectOrmUpdate(String, long) - Method in interface io.ebeaninternal.server.persist.PersistExecute
-
Collect execution metrics for sql update.
- collectPlan(Connection, SpiQueryPlan, BindCapture) - Method in class io.ebeaninternal.server.query.CQueryPlanManager
- collectPlan(Connection, SpiQueryPlan, BindCapture) - Method in class io.ebeaninternal.server.query.QueryPlanLoggerExplain
- collectPlan(Connection, SpiQueryPlan, BindCapture) - Method in class io.ebeaninternal.server.query.QueryPlanLoggerOracle
- collectPlan(Connection, SpiQueryPlan, BindCapture) - Method in class io.ebeaninternal.server.query.QueryPlanLoggerSqlServer
- collectProfiling() - Method in interface io.ebeaninternal.server.autotune.AutoTuneService
-
Fire a garbage collection (hint to the JVM).
- collectProfiling() - Method in class io.ebeaninternal.server.autotune.NoAutoTuneService
- collectQueryInfo(ObjectGraphNode, long, long) - Method in interface io.ebeaninternal.server.autotune.ProfilingListener
-
Collect summary statistics for a query executed for the given node.
- collectSortable() - Method in class io.ebeanservice.docstore.api.mapping.DocMappingBuilder
-
Collect the mapping of properties to 'raw' properties for those marked as sortable.
- collectSqlCall(String, long) - Method in interface io.ebeaninternal.server.persist.PersistExecute
-
Collect execution metrics for sql callable.
- collectSqlUpdate(String, long) - Method in interface io.ebeaninternal.server.persist.PersistExecute
-
Collect execution metrics for sql update.
- collectTransactionProfile(TransactionProfile) - Method in interface io.ebeaninternal.api.SpiProfileHandler
-
Process the collected transaction profiling information.
- collectTransactionProfile(TransactionProfile) - Method in class io.ebeaninternal.server.transaction.DefaultProfileHandler
-
Low contention adding the transaction profile to the queue.
- collectTransactionProfile(TransactionProfile) - Method in class io.ebeaninternal.server.transaction.NoopProfileHandler
- Column(int, String, String) - Constructor for class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping.Column
-
Construct a Column.
- columnMapping(String, String) - Method in class io.ebeaninternal.server.rawsql.DRawSqlBuilder
- columnMappingIgnore(String) - Method in class io.ebeaninternal.server.rawsql.DRawSqlBuilder
- columns() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
-
Return the join columns.
- columns() - Method in class io.ebeaninternal.server.deploy.TableJoin
-
Return the join columns.
- commit() - Method in class io.ebeaninternal.api.ScopedTransaction
- commit() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
This will always throw a PersistenceException.
- commit() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Commit the transaction.
- commit() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Commit the transaction.
- commit(DocStoreTransaction) - Method in interface io.ebeanservice.docstore.api.DocStoreUpdateProcessor
-
Perform commit/flush of the changes made via the document store transaction.
- commitAndContinue() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- commitAndContinue() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Perform a commit, fire callbacks and notify l2 cache etc.
- commitAndContinue() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Perform a commit, fire callbacks and notify l2 cache etc.
- commitAndContinue() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Perform a commit, fire callbacks and notify l2 cache etc.
- commitMicros - Variable in class io.ebeaninternal.server.transaction.TransactionProfile.Summary
- commitTransIfRequired() - Method in class io.ebeaninternal.server.core.BeanRequest
-
Commit this transaction if it was created for this request.
- compare(DefaultServerCache.CacheEntry, DefaultServerCache.CacheEntry) - Method in class io.ebeaninternal.server.cache.DefaultServerCache.CompareByLastAccess
- compare(T, T) - Method in interface io.ebeaninternal.server.el.ElComparator
-
Compare given 2 beans.
- compare(T, T) - Method in class io.ebeaninternal.server.el.ElComparatorCompound
- compare(T, T) - Method in class io.ebeaninternal.server.el.ElComparatorNoop
- compare(T, T) - Method in class io.ebeaninternal.server.el.ElComparatorProperty
- CompareByLastAccess() - Constructor for class io.ebeaninternal.server.cache.DefaultServerCache.CompareByLastAccess
- compareTo(ImportedIdSimple) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- compareValue(Object, T) - Method in interface io.ebeaninternal.server.el.ElComparator
-
Compare with a fixed value to a given bean.
- compareValue(Object, T) - Method in class io.ebeaninternal.server.el.ElComparatorCompound
- compareValue(Object, T) - Method in class io.ebeaninternal.server.el.ElComparatorNoop
- compareValue(Object, T) - Method in class io.ebeaninternal.server.el.ElComparatorProperty
- compareValues(Object, Object) - Method in class io.ebeaninternal.server.el.ElComparatorProperty
- compileQuery(SpiQuery.Type, SpiQuery<T>, Transaction) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Compile a query.
- compileQuery(SpiQuery.Type, SpiQuery<T>, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Compile a query.
- complete() - Method in class io.ebeaninternal.api.ScopedTransaction
-
Internal programmatic complete - finally block, try to commit.
- complete() - Method in class io.ebeaninternal.api.ScopeTrans
-
Complete the transaction programmatically.
- complete() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Completed insert or delete request.
- complete(Object, int) - Method in class io.ebeaninternal.api.ScopedTransaction
-
Exiting an enhanced transactional method.
- completeUpdate() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Completed update request handling cases for element collection and where ONLY many properties were updated.
- computeNanoOffset() - Method in class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
-
Computes the internal offset between System.nanoTime() and System.currentTimeMillis().
- concat(String, String, String, String) - Method in interface io.ebeaninternal.server.expression.platform.DbExpressionHandler
-
Performs a "CONCAT" operation for that platform.
- concurrencyMode() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the concurrency mode used for this persist.
- concurrencyMode(EntityBeanIntercept) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- ConcurrencyMode - Enum in io.ebeaninternal.api
-
Optimistic concurrency mode used for updates and deletes.
- config() - Method in class io.ebeaninternal.server.core.DefaultServer
- config() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the DatabaseConfig.
- config() - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- config() - Method in interface io.ebeaninternal.server.deploy.BeanDescriptorMap
-
Return the DatabaseConfig.
- configure(SpiServer) - Method in class io.ebeaninternal.server.transaction.DefaultProfileHandler
- configureBeanQuery(SpiQuery<?>) - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Define the select and joins for this query.
- configureQuery(SpiQuery<?>) - Method in interface io.ebeaninternal.api.LoadManyBuffer
- configureQuery(SpiQuery<?>, String) - Method in interface io.ebeaninternal.api.LoadBeanBuffer
- conjunction() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- conjunction(Query<T>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Return a list of expressions that will be joined by AND's.
- conjunction(Query<T>, ExpressionList<T>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Return a list of expressions that will be joined by AND's.
- connection() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- connection() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- connection() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Return the underlying connection for public use.
- connection() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Return the underlying connection for public use.
- connection(Object) - Method in interface io.ebeaninternal.server.transaction.DataSourceSupplier
-
Return a connection from the DataSource taking into account a tenantId for multi-tenant lazy loading.
- contains(E) - Method in class io.ebeaninternal.server.util.ArrayStack
- contains(Object) - Method in class io.ebeaninternal.json.ModifyAwareList
- contains(Object) - Method in class io.ebeaninternal.json.ModifyAwareSet
- contains(String) - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping
-
Return true if the property is mapped.
- contains(String, String) - Method in class io.ebeaninternal.server.el.ElFilter
- contains(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Contains - property like %value%.
- contains(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- containsAll(Collection<?>) - Method in class io.ebeaninternal.json.ModifyAwareList
- containsAll(Collection<?>) - Method in class io.ebeaninternal.json.ModifyAwareSet
- containsFormulaWithJoin() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- containsFormulaWithJoin() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- containsFormulaWithJoin() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- containsFormulaWithJoin() - Method in interface io.ebeaninternal.server.el.ElPropertyDeploy
-
Return true if the property is a formula with a join clause.
- containsKey(Object) - Method in class io.ebeaninternal.json.ModifyAwareMap
- containsKey(Object) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- containsMany() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
-
Returns false.
- containsMany() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- containsMany() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Returns true.
- containsMany() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- containsMany() - Method in interface io.ebeaninternal.server.el.ElPropertyDeploy
-
Return true if there is a property on the path that is a many property.
- containsMany(BeanDescriptor<?>, ManyWhereJoins) - Method in interface io.ebeaninternal.api.SpiExpression
-
Process "Many" properties populating ManyWhereJoins.
- containsMany(BeanDescriptor<?>, ManyWhereJoins) - Method in class io.ebeaninternal.server.expression.InExpression
- containsMany(BeanDescriptor<?>, ManyWhereJoins) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- containsMany(BeanDescriptor<?>, ManyWhereJoins) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Return true if one of the expressions is related to a Many property.
- containsMany(BeanDescriptor<?>, ManyWhereJoins) - Method in class io.ebeaninternal.server.expression.IdInExpression
- containsManySince(String) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- containsManySince(String) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- containsManySince(String) - Method in class io.ebeaninternal.server.el.ElPropertyChain
-
Return true if there is a many property from sinceProperty to the end of this chain.
- containsManySince(String) - Method in interface io.ebeaninternal.server.el.ElPropertyDeploy
-
Return true if there is a property is on the path after sinceProperty that is a 'many' property.
- containsValue(Object) - Method in class io.ebeaninternal.json.ModifyAwareMap
- containsValue(Object) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- content() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Return the current context of the sql context.
- contextClear(PersistenceContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Clear a bean from the persistence context.
- contextClear(PersistenceContext, Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Clear a bean from the persistence context.
- contextDeleted(PersistenceContext, Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Delete a bean from the persistence context (such that we don't fetch it in the same transaction).
- contextGet(PersistenceContext, Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Get the bean from the persistence context.
- contextGetWithOption(PersistenceContext, Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Get the bean from the persistence context with delete check option.
- contextPut(PersistenceContext, Object, Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Put the bean into the persistence context.
- contextPutIfAbsent(PersistenceContext, Object, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Put the bean into the persistence context if it is absent.
- contextPutIfAbsent(PersistenceContext, Object, EntityBean) - Method in interface io.ebeaninternal.server.query.STreeType
-
Put the entity bean into the persistence context.
- contextRef(PersistenceContext, Boolean, boolean, Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Create a reference bean and put it in the persistence context (and return it).
- convert(Object) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- convert(Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- convert(Object) - Method in class io.ebeaninternal.server.el.ElPropertyChain
- convert(Object, int) - Method in class io.ebeaninternal.server.type.DefaultTypeManager
-
Convert the Object to the required datatype.
- convertForJson(EntityBean) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
For EmbeddedId convert the idValue into a simple map.
- convertForJson(EntityBean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
-
Convert from embedded bean to Map.
- convertForJson(EntityBean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- convertFromJson(Object) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
For EmbeddedId the value is assumed to be a Map and this is takes the values from the map and builds an embedded id bean.
- convertFromJson(Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
-
Convert back from a Map to embedded bean.
- convertFromJson(Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- convertId(Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Convert the type of the idValue if required.
- convertId(Object) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Cast or convert the Id value if necessary.
- convertId(Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- convertId(Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- convertJoins() - Method in interface io.ebeaninternal.api.SpiQuery
-
Convert joins as necessary to query joins etc.
- convertJoins() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- convertOrmUpdateToSql(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Convert the logical orm update statement into sql by converting the bean properties and bean name to database columns and table.
- convertSetId(Object, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Convert and set the id value.
- convertSetId(Object, EntityBean) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Cast or convert the Id value if necessary and optionally set it.
- convertSetId(Object, EntityBean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- convertSetId(Object, EntityBean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- convertToBytes(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesBase
- convertWord() - Method in class io.ebeaninternal.server.deploy.DeployParser
- convertWord() - Method in class io.ebeaninternal.server.deploy.DeployPropertyParser
- convertWord() - Method in class io.ebeaninternal.server.deploy.DeployPropertyParserMap
- convertWord() - Method in class io.ebeaninternal.server.deploy.DeployUpdateParser
- copy() - Method in class io.ebeaninternal.api.BindParams
-
Return a deep copy of the BindParams.
- copy() - Method in class io.ebeaninternal.api.BindParams.Param
-
Create a deep copy of the Param.
- copy() - Method in interface io.ebeaninternal.api.SpiExpression
-
Return a copy of the expression (as part of creating a query copy).
- copy() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return a copy of the query.
- copy() - Method in interface io.ebeaninternal.api.SpiSqlUpdate
-
Return a copy of the SqlUpdate with empty bind parameters.
- copy() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- copy() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- copy() - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Return a deep copy of the OrmQueryDetail.
- copy() - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Creates a copy of the OrmQueryProperties.
- copy() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
-
Create a copy of this such that it can be overridden on a per index basis.
- copy(boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoinColumn
- copy(FetchConfig) - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Create a copy with the given fetch config.
- copy(Query<T>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Return a copy of the expression list.
- copy(SpiEbeanServer) - Method in interface io.ebeaninternal.api.SpiQuery
-
Return a copy of the query attaching to a different EbeanServer.
- copy(SpiEbeanServer) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- copyForPlanKey() - Method in interface io.ebeaninternal.api.SpiExpression
-
Return a copy of the expression for use in the query plan key.
- copyForPlanKey() - Method in class io.ebeaninternal.server.expression.InExpression
- copyForPlanKey() - Method in class io.ebeaninternal.server.expression.SimpleExpression
- copyForPlanKey() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- copyForPlanKey() - Method in class io.ebeaninternal.server.expression.IdInExpression
- copyTo() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- copyTo(DeployTableJoin, boolean, String) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
- copyTo(String) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- copyWithoutType(DeployTableJoin, boolean, String) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
- CoreLog - Class in io.ebeaninternal.api
-
Common loggers used in ebean-core.
- CoreLog() - Constructor for class io.ebeaninternal.api.CoreLog
- COUNT - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
Find rowCount.
- countDistinctOrder() - Method in interface io.ebeaninternal.api.SpiQuery
-
Returns the count distinct order setting.
- countDistinctOrder() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- counter() - Method in class io.ebeaninternal.api.BinaryWriteContext
-
Return the number of message parts that have been written.
- CQuery<T> - Class in io.ebeaninternal.server.query
-
An object that represents a SqlSelect statement.
- CQuery(OrmQueryRequest<T>, CQueryPredicates, CQueryPlan) - Constructor for class io.ebeaninternal.server.query.CQuery
-
Create the Sql select based on the request.
- CQueryCollectionAdd<T> - Interface in io.ebeaninternal.server.query
-
Defines interface for adding beans to the collection which might be a List, Set or Map.
- CQueryEngine - Class in io.ebeaninternal.server.query
-
Handles the Object Relational fetching.
- CQueryEngine(DatabaseBuilder.Settings, DatabasePlatform, Binder, Map<String, String>, Map<String, String>) - Constructor for class io.ebeaninternal.server.query.CQueryEngine
- CQueryPlan - Class in io.ebeaninternal.server.query
-
Represents a query for a given SQL statement.
- CQueryPlanKey - Interface in io.ebeaninternal.api
-
Key used for caching query plans for ORM and RawSql queries.
- CQueryPlanManager - Class in io.ebeaninternal.server.query
- CQueryPlanManager(TransactionManager, long, QueryPlanLogger, ExtraMetrics) - Constructor for class io.ebeaninternal.server.query.CQueryPlanManager
- CQueryPlanStats - Class in io.ebeaninternal.server.query
-
Statistics for a specific query plan that can accumulate.
- CQueryPredicates - Class in io.ebeaninternal.server.query
-
Compile Query Predicates.
- create() - Method in class io.ebeaninternal.server.deploy.DeployDocPropertyOptions
-
Return the DocPropertyOptions with the collected options.
- create() - Method in class io.ebeaninternal.server.rawsql.DRawSqlBuilder
- create(DatabaseBuilder.Settings) - Method in class io.ebeaninternal.server.core.DatabasePlatformFactory
-
Create the appropriate database specific platform.
- create(DatabaseBuilder, BackgroundExecutor) - Method in class io.ebeaninternal.server.cache.DefaultServerCachePlugin
-
Creates the default ServerCacheFactory.
- create(SpiServer) - Method in interface io.ebeanservice.docstore.api.DocStoreFactory
-
Create and return the DocStore integration components.
- create(SpiEbeanServer, DatabaseBuilder) - Method in interface io.ebeaninternal.server.autotune.AutoTuneServiceProvider
- create(SpiQuery.Type, OrmQueryRequest<T>) - Static method in class io.ebeaninternal.server.deploy.BeanCollectionHelpFactory
- create(ClusterManager, ContainerConfig) - Method in interface io.ebeaninternal.server.cluster.ClusterBroadcastFactory
-
Create the cluster transport with the manager and deployment properties.
- create(BeanDescriptor<?>) - Method in interface io.ebeaninternal.server.persist.BeanPersisterFactory
-
Create the BeanPersister implemenation for a given type.
- create(BeanPropertyAssocMany<T>) - Static method in class io.ebeaninternal.server.deploy.BeanCollectionHelpFactory
-
Create the helper based on the many property.
- create(String) - Method in interface io.ebeaninternal.api.SpiLoggerFactory
-
Create the logger given the name.
- create(String, boolean) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- create(String, String, String) - Method in class io.ebeanservice.docstore.api.mapping.DocMappingBuilder
-
Create the document mapping.
- createAdapter(BeanDescriptor<T>, DeployBeanDescriptor<T>) - Method in interface io.ebeanservice.docstore.api.DocStoreFactory
-
Create the doc store specific adapter for the given bean type.
- createBatchControl(SpiTransaction) - Method in interface io.ebeaninternal.server.persist.PersistExecute
-
Create a BatchControl for the current transaction.
- createBean() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- createBeanReader(BeanType<T>, JsonParser, JsonReadOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- createBeanReader(Class<T>, JsonParser, JsonReadOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- createBeanUsingDisc(Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- createBindCapture(SpiQueryPlan) - Method in interface io.ebeaninternal.api.QueryPlanManager
-
Create the bind capture for the given query plan.
- createBindCapture(SpiQueryPlan) - Method in class io.ebeaninternal.server.query.CQueryPlanManager
- createBinder(DatabaseBuilder.Settings) - Method in interface io.ebeaninternal.api.GeoTypeProvider
-
Create a binder for binding geometry types.
- createCallableSql(String) - Method in class io.ebeaninternal.server.core.DefaultServer
- createCallOrigin() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Create an object to represent the current CallStack.
- createCallOrigin() - Method in interface io.ebeaninternal.server.core.CallOriginFactory
-
Create and return the CallStack given the stack trace elements.
- createCallOrigin() - Method in class io.ebeaninternal.server.core.DefaultServer
-
Create a CallStack object.
- createCollectionBeanTable(String, Class<?>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Return a BeanTable for an ElementCollection.
- createDataReader(ResultSet) - Method in class io.ebeaninternal.server.persist.Binder
- createDataReader(ResultSet) - Method in class io.ebeaninternal.server.query.CQueryPlan
- createDelete(SpiEbeanServer, DeleteMode) - Method in class io.ebeaninternal.server.deploy.IntersectionRow
- createDeleteChildren(SpiEbeanServer) - Method in class io.ebeaninternal.server.deploy.IntersectionRow
- createDeployBeanTable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- createDeployDescriptor(Class<A>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Create a DeployBeanDescriptor for an ElementCollection target.
- createDeployParser() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- createDocMapping() - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Create the document mapping.
- createDocMapping() - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- createDocStoreBeanAdapter(BeanDescriptor<T>, DeployBeanDescriptor<T>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- createDocStoreBeanAdapter(BeanDescriptor<T>, DeployBeanDescriptor<T>) - Method in interface io.ebeaninternal.server.deploy.BeanDescriptorMap
-
Create a doc store specific adapter for this bean type.
- createdTransaction - Variable in class io.ebeaninternal.server.core.BeanRequest
- createElementDescriptor(DeployBeanDescriptor<A>, ManyType, boolean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Create a BeanDescriptor for an ElementCollection target.
- createEmbeddedId() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Create a bean of the target type to be used as an embeddedId value.
- createEmpty(EntityBean) - Method in interface io.ebeaninternal.server.deploy.BeanCollectionHelp
-
Create an empty collection of the correct type.
- createEmpty(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanListHelp
- createEmpty(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanMapHelp
- createEmpty(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- createEmpty(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanSetHelp
- createEmptyNoParent() - Method in interface io.ebeaninternal.server.deploy.BeanCollectionHelp
-
Create an empty collection of the correct type without a parent bean.
- createEmptyNoParent() - Method in class io.ebeaninternal.server.deploy.BeanListHelp
- createEmptyNoParent() - Method in class io.ebeaninternal.server.deploy.BeanMapHelp
- createEmptyNoParent() - Method in class io.ebeaninternal.server.deploy.BeanSetHelp
- createEmptyNoParent() - Method in interface io.ebeaninternal.server.query.CQueryCollectionAdd
-
Create an empty collection.
- createEmptyReference() - Method in interface io.ebeaninternal.server.deploy.BeanCollectionHelp
-
Create and return an empty 'vanilla' collection that does not support lazy loading.
- createEmptyReference() - Method in class io.ebeaninternal.server.deploy.BeanListHelp
- createEmptyReference() - Method in class io.ebeaninternal.server.deploy.BeanMapHelp
- createEmptyReference() - Method in class io.ebeaninternal.server.deploy.BeanSetHelp
- createEmptyReference(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- createEmptyReference(EntityBean) - Method in interface io.ebeaninternal.server.query.STreePropertyAssocMany
-
Populate the collection for read-only disabled lazy loading (aka Java Collections non mutable empty collection).
- createEntityBean() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Creates a new entity bean without invoking
BeanPostConstructListener.postCreate(Object) - createEntityBean() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Create an EntityBean for this type.
- createEntityBean() - Method in interface io.ebeaninternal.server.query.STreeType
-
Create a new entity bean instance.
- createEntityBean(Class<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Create a new EntityBean bean.
- createEntityBean2(boolean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- createEntityBean2(boolean) - Method in interface io.ebeaninternal.server.query.STreeType
-
Create a new entity bean instance with option for read only optimisation.
- createEntityBeanForJson() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Create an entity bean for JSON marshalling (which differs for the element collection case).
- createExpressionFactory() - Method in interface io.ebeaninternal.api.SpiExpressionFactory
-
Create another expression factory with a given sub path.
- createExpressionFactory() - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- createGenerator(Writer) - Method in class io.ebeaninternal.server.json.DJsonContext
- createIdBinder(BeanProperty) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- createIdBinder(BeanProperty) - Method in interface io.ebeaninternal.server.deploy.BeanDescriptorMap
-
Create a IdBinder for this bean property.
- createIdBinder(BeanProperty) - Method in class io.ebeaninternal.server.deploy.id.IdBinderFactory
-
Create the IdConvertSet for the given type of Id properties.
- createIdProperty(BeanDescriptorMap) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanTable
-
Return the id properties.
- createImplicitTransIfRequired() - Method in class io.ebeaninternal.server.core.BeanRequest
-
A helper method for creating an implicit transaction is it is required.
- createInsert(SpiEbeanServer) - Method in class io.ebeaninternal.server.deploy.IntersectionRow
- createIntersectionTableJoin() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Create the immutable version of the intersection join.
- createInverse(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
- createInverseTableJoin() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Create the immutable version of the inverse join.
- createJoinColumn(String, DeployTableJoin, boolean, String) - Method in class io.ebeaninternal.server.deploy.BeanTable
- createJoinTable() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Returns true, if we must create a m2m join table.
- createJsonRead(BeanType<?>, String) - Method in interface io.ebeaninternal.api.SpiJsonContext
-
Create a Json Reader for reading the JSON content.
- createJsonRead(BeanType<?>, String) - Method in class io.ebeaninternal.server.json.DJsonContext
- createJsonReadOptions() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return the JsonReadOptions taking into account lazy loading and persistence context.
- createJsonReadOptions() - Method in interface io.ebeanservice.docstore.api.DocQueryRequest
-
Create JsonReadOptions taking into account persistence context and lazy loading support.
- createJsonWriter(JsonGenerator, JsonWriteOptions) - Method in interface io.ebeaninternal.api.SpiJsonContext
-
Create a Json Writer for writing beans as JSON.
- createJsonWriter(JsonGenerator, JsonWriteOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- createJsonWriter(Writer) - Method in interface io.ebeaninternal.api.SpiJsonContext
-
Create a Json Writer for writing beans as JSON supplying a writer.
- createJsonWriter(Writer) - Method in class io.ebeaninternal.server.json.DJsonContext
- createMeta(String, String) - Method in interface io.ebeaninternal.api.SpiQueryPlan
-
Return as Database query plan.
- createMeta(String, String) - Method in class io.ebeaninternal.server.query.CQueryPlan
- createMutableInfo(String) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
creates a mutableHash for the given JSON value.
- createMutableInfo(String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyJsonMapper
- createNamedDtoQuery(Class<T>, String) - Method in class io.ebeaninternal.server.core.DefaultServer
- createNamedParameter(String) - Method in interface io.ebeaninternal.api.SpiQuery
-
Create a named parameter placeholder.
- createNamedParameter(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- createNamedQuery(Class<T>, String) - Method in class io.ebeaninternal.server.core.DefaultServer
- createNewRow() - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
-
Read and return the next SqlRow.
- createOrderedList() - Method in class io.ebeaninternal.api.BindParams
-
Create a new positioned parameters orderedList.
- createParser(Reader) - Method in class io.ebeaninternal.server.json.DJsonContext
- createProfileStream(ProfileLocation) - Method in interface io.ebeaninternal.api.SpiProfileHandler
-
Create a profiling stream if we are profiling this transaction.
- createProfileStream(ProfileLocation) - Method in class io.ebeaninternal.server.transaction.DefaultProfileHandler
-
Create and return a ProfileStream.
- createProfileStream(ProfileLocation) - Method in class io.ebeaninternal.server.transaction.NoopProfileHandler
- createQuery(SpiEbeanServer) - Method in class io.ebeaninternal.api.LoadBeanRequest
- createQuery(SpiEbeanServer) - Method in class io.ebeaninternal.api.LoadManyRequest
- createQuery(Class<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Override in order to return SpiQuery
- createQuery(Class<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- createQuery(Class<T>, String) - Method in class io.ebeaninternal.server.core.DefaultServer
- createQueryBindCapture(SpiQueryPlan) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Create a query bind capture for the given query plan.
- createQueryBindCapture(SpiQueryPlan) - Method in class io.ebeaninternal.server.core.DefaultServer
- createQueryUpdate(BeanType<T>, int) - Method in interface io.ebeanservice.docstore.api.DocStoreUpdateProcessor
-
Create a processor to handle updates per bean via a findEach query.
- createReadOnlyTransaction(Object, boolean) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Create a ServerTransaction for query purposes.
- createReadOnlyTransaction(Object, boolean) - Method in class io.ebeaninternal.server.core.DefaultServer
- createReadOnlyTransaction(Object, boolean) - Method in class io.ebeaninternal.server.transaction.DocStoreTransactionManager
- createReadOnlyTransaction(Object, boolean) - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Create a new Transaction for query only purposes (can use read only datasource).
- createRef(Object, PersistenceContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- createReference() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Create and return a new reference bean matching this beans Id value.
- createReference(EntityBean) - Method in interface io.ebeaninternal.server.deploy.BeanCollectionHelp
-
Create a lazy loading proxy for a List Set or Map.
- createReference(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanListHelp
- createReference(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanMapHelp
- createReference(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- createReference(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanSetHelp
- createReference(EntityBean, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- createReference(EntityBean, boolean) - Method in interface io.ebeaninternal.server.query.STreePropertyAssocMany
-
Return a reference collection forcing a new reference on REFRESH query.
- createReference(Boolean, boolean, Object, PersistenceContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Create a reference bean based on the id.
- createReference(Boolean, Object, PersistenceContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Create a reference with a check for the bean in the persistence context.
- createReference(Object, PersistenceContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Create a non read only reference bean without checking cacheSharableBeans.
- createReferenceIfNull(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- createReferenceIfNull(EntityBean) - Method in interface io.ebeaninternal.server.query.STreePropertyAssocMany
-
Return a reference collection.
- createServer(DatabaseBuilder) - Method in class io.ebeaninternal.server.core.DefaultContainer
-
Create the implementation from the configuration.
- createServer(String) - Method in class io.ebeaninternal.server.core.DefaultContainer
-
Create the server reading configuration information from ebean.properties.
- createSqlRow(int) - Method in interface io.ebeaninternal.server.core.RelationalQueryEngine
-
Return a new SqlRow with appropriate mapping for DB true and optimised binary UUID etc.
- createSqlRow(int) - Method in class io.ebeaninternal.server.query.DefaultRelationalQueryEngine
- createTransaction() - Method in class io.ebeaninternal.server.core.DefaultServer
-
Creates a new Transaction that is NOT stored in TransactionThreadLocal.
- createTransaction(boolean, int) - Method in class io.ebeaninternal.server.transaction.DocStoreTransactionManager
- createTransaction(boolean, int) - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Create a new Transaction.
- createTransaction(boolean, Connection) - Method in class io.ebeaninternal.server.transaction.DocStoreTransactionManager
- createTransaction(int) - Method in interface io.ebeanservice.docstore.api.DocStoreUpdateProcessor
-
Create a document store transaction hinting at the batch size.
- createTransaction(TxIsolation) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Create a transaction additionally specify the Isolation level.
- createUnidirectional(DeployBeanDescriptor<?>, Class<A>, BeanTable, DeployTableJoin) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Create and add a Unidirectional property (for ElementCollection) which maps to the foreign key.
- createUpdate(Class<T>, String) - Method in class io.ebeaninternal.server.core.DefaultServer
- ctx() - Method in class io.ebeaninternal.server.query.SqlBeanLoad
-
Return the DB read context.
- current() - Method in class io.ebeaninternal.api.ScopedTransaction
-
Return the current transaction.
- CURRENT - Enum constant in enum io.ebeaninternal.api.SpiQuery.TemporalMode
-
Query runs against current data (normal).
- currentServerTransaction() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return the current transaction or null if there is no current transaction.
- currentServerTransaction() - Method in class io.ebeaninternal.server.core.DefaultServer
- currentTenantId() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return the current Tenant Id.
- currentTenantId() - Method in class io.ebeaninternal.server.core.DefaultServer
- currentTenantId() - Method in interface io.ebeaninternal.server.transaction.DataSourceSupplier
-
Obtain the current TenantId *IF* it is required for the DataSource.
- currentTransaction() - Method in class io.ebeaninternal.server.core.DefaultServer
D
- database() - Method in class io.ebeaninternal.server.core.BeanRequest
-
Return the server processing the request.
- databasePlatform() - Method in class io.ebeaninternal.server.core.DefaultServer
- DatabasePlatformFactory - Class in io.ebeaninternal.server.core
-
Create a DatabasePlatform from the configuration.
- DatabasePlatformFactory() - Constructor for class io.ebeaninternal.server.core.DatabasePlatformFactory
- dataBind(PreparedStatement, Connection) - Method in class io.ebeaninternal.server.persist.Binder
-
Create and return a DataBind for the statement.
- DataEncryptSupport - Class in io.ebeaninternal.server.type
- DataEncryptSupport(EncryptKeyManager, Encryptor, String, String) - Constructor for class io.ebeaninternal.server.type.DataEncryptSupport
- dataReader() - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Return the DataReader.
- dataReader() - Method in class io.ebeaninternal.server.query.CQuery
- dataSource() - Method in interface io.ebeaninternal.api.SpiTransactionManager
-
Return the main DataSource.
- dataSource() - Method in class io.ebeaninternal.server.core.DefaultServer
- dataSource() - Method in interface io.ebeaninternal.server.transaction.DataSourceSupplier
-
Return the DataSource to use for the current request.
- dataSource() - Method in class io.ebeaninternal.server.transaction.TransactionManager
- DataSourceSupplier - Interface in io.ebeaninternal.server.transaction
-
Supply the DataSource to the transaction manager.
- dataTimeZone() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return the DataTimeZone to use when reading/writing timestamps via JDBC.
- dataTimeZone() - Method in class io.ebeaninternal.server.core.BeanRequest
-
Return the DataTimeZone to use.
- dataTimeZone() - Method in class io.ebeaninternal.server.core.DefaultServer
- DataTimeZone - Interface in io.ebeaninternal.server.core.timezone
-
Define if a Calendar representing the time zone should be used in JDBC calls.
- dbArrayType(Class<?>, Type, boolean) - Method in class io.ebeaninternal.server.type.DefaultTypeManager
- dbArrayType(Class<?>, Type, boolean) - Method in interface io.ebeaninternal.server.type.TypeManager
-
Return the ScalarType used to handle DB ARRAY.
- dbBind() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the DB bind parameter.
- dbCheckConstraintValues() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the DB constraint expression (can be null).
- dbColumn() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- dbColumn() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
The database column name this is mapped to.
- dbColumn() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- dbColumn() - Method in interface io.ebeaninternal.server.el.ElPropertyDeploy
-
Return the deployment db column for this property.
- dbColumnDefault() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the DB column default to use for DDL.
- dbColumnDefn() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return a specific column DDL definition if specified (otherwise null).
- dbComment() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the DB comment for the base table.
- dbComment() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the comment for the associated DB column.
- dbEncryptedType() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- DbExpressionHandler - Interface in io.ebeaninternal.server.expression.platform
-
Adds the db platform specific json expression.
- DbExpressionHandlerFactory - Class in io.ebeaninternal.server.expression.platform
- DbExpressionHandlerFactory() - Constructor for class io.ebeaninternal.server.expression.platform.DbExpressionHandlerFactory
- DbExpressionRequest - Interface in io.ebeaninternal.server.expression.platform
-
Request building the expression sql.
- dbJsonType(DeployBeanProperty, int, int) - Method in class io.ebeaninternal.server.type.DefaultTypeManager
- dbJsonType(DeployBeanProperty, int, int) - Method in interface io.ebeaninternal.server.type.TypeManager
-
Return the ScalarType used to handle JSON content.
- dbLength() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the DB max length (varchar) or precision (decimal).
- dbLikeClause(boolean) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return the database platform like clause.
- dbLikeClause(boolean) - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Return the Database platform like clause.
- dbMapType() - Method in class io.ebeaninternal.server.type.DefaultTypeManager
- dbMapType() - Method in interface io.ebeaninternal.server.type.TypeManager
-
Return the ScalarType used to handle HSTORE (Mapinvalid input: '<'String,String>).
- DbMigrationInfo - Class in io.ebeaninternal.server.deploy
-
Class to hold the DDL-migration information that is needed to do correct alters.
- DbMigrationInfo(String[], String[], String[], String[], Platform[]) - Constructor for class io.ebeaninternal.server.deploy.DbMigrationInfo
- dbMigrationInfos() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the DDL-Migration Infos
- DbOffline - Class in io.ebeaninternal.api
-
Helper to indicate that an EbeanServer should come up offline typically for DDL generation purposes.
- DbOffline() - Constructor for class io.ebeaninternal.api.DbOffline
- DbReadContext - Interface in io.ebeaninternal.server.deploy
-
Context provided when a BeanProperty reads from a ResultSet.
- dbScale() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the DB scale for numeric columns.
- DbSqlContext - Interface in io.ebeaninternal.server.deploy
-
Used to provide context during sql construction.
- dbType(boolean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the database jdbc data type this is mapped to.
- DCacheRegion - Class in io.ebeaninternal.server.deploy
- DCacheRegion(String) - Constructor for class io.ebeaninternal.server.deploy.DCacheRegion
- deactivate() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- deactivateExternal() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Set the transaction to be inactive via external transaction manager.
- deactivateExternal() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- deactivateExternal() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- deactivateExternal() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- deactivateExternal() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- debug(String, Object...) - Method in interface io.ebeaninternal.api.SpiLogger
-
Log a debug level message.
- decrypt(byte[]) - Method in class io.ebeaninternal.server.type.DataEncryptSupport
- decrypt(byte[], EncryptKey) - Method in class io.ebeaninternal.server.type.SimpleAesEncryptor
- decryptObject(byte[]) - Method in class io.ebeaninternal.server.type.DataEncryptSupport
- decryptProperty(String) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- decryptString(byte[], EncryptKey) - Method in class io.ebeaninternal.server.type.SimpleAesEncryptor
- DefaultBeanState - Class in io.ebeaninternal.server.core
-
Default implementation of BeanState.
- DefaultBeanState(EntityBean) - Constructor for class io.ebeaninternal.server.core.DefaultBeanState
- DefaultCacheAdapter - Class in io.ebeaninternal.server.cache
-
Adapts SpiCacheManager to ServerCacheManager.
- DefaultCacheAdapter(SpiCacheManager) - Constructor for class io.ebeaninternal.server.cache.DefaultCacheAdapter
- DefaultContainer - Class in io.ebeaninternal.server.core
-
Default Server side implementation of ServerFactory.
- DefaultContainer(ContainerConfig) - Constructor for class io.ebeaninternal.server.core.DefaultContainer
- DefaultDtoQuery<T> - Class in io.ebeaninternal.server.querydefn
-
Default implementation of DtoQuery.
- DefaultDtoQuery(SpiEbeanServer, DtoBeanDescriptor<T>, SpiQuery<?>) - Constructor for class io.ebeaninternal.server.querydefn.DefaultDtoQuery
-
Create given an underlying ORM query.
- DefaultDtoQuery(SpiEbeanServer, DtoBeanDescriptor<T>, String) - Constructor for class io.ebeaninternal.server.querydefn.DefaultDtoQuery
-
Create given a native SQL query.
- DefaultExpressionFactory - Class in io.ebeaninternal.server.expression
-
Default Expression factory for creating standard expressions.
- DefaultExpressionFactory(boolean, boolean) - Constructor for class io.ebeaninternal.server.expression.DefaultExpressionFactory
- DefaultExpressionList<T> - Class in io.ebeaninternal.server.expression
-
Default implementation of ExpressionList.
- DefaultExpressionList(ExpressionFactory) - Constructor for class io.ebeaninternal.server.expression.DefaultExpressionList
- DefaultExpressionList(Query<T>) - Constructor for class io.ebeaninternal.server.expression.DefaultExpressionList
-
Construct for Text root expression list - this handles implicit Bool Should, Must etc.
- DefaultExpressionList(Query<T>, ExpressionList<T>) - Constructor for class io.ebeaninternal.server.expression.DefaultExpressionList
- DefaultExpressionRequest - Class in io.ebeaninternal.server.expression
- DefaultExpressionRequest(SpiOrmQueryRequest<?>, DeployParser, Binder, SpiExpressionList<?>) - Constructor for class io.ebeaninternal.server.expression.DefaultExpressionRequest
- DefaultExpressionRequest(BeanDescriptor<?>) - Constructor for class io.ebeaninternal.server.expression.DefaultExpressionRequest
- defaultOrderBy() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the default order by that may need to be added if a many property is included in the query.
- DefaultOrmQuery<T> - Class in io.ebeaninternal.server.querydefn
-
Default implementation of an Object Relational query.
- DefaultOrmQuery(BeanDescriptor<T>, SpiEbeanServer, ExpressionFactory) - Constructor for class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- DefaultOrmQueryEngine - Class in io.ebeaninternal.server.query
- DefaultOrmQueryEngine(CQueryEngine, Binder) - Constructor for class io.ebeaninternal.server.query.DefaultOrmQueryEngine
-
Create the Finder.
- DefaultOrmUpdate<T> - Class in io.ebeaninternal.server.querydefn
-
Default implementation of OrmUpdate.
- DefaultOrmUpdate(Class<?>, Database, String, String) - Constructor for class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
-
Create with a specific server.
- DefaultPersistenceContext - Class in io.ebeaninternal.server.transaction
-
Default implementation of PersistenceContext.
- DefaultPersistenceContext() - Constructor for class io.ebeaninternal.server.transaction.DefaultPersistenceContext
-
Create a new PersistenceContext.
- DefaultPersister - Class in io.ebeaninternal.server.persist
-
Persister implementation using DML.
- DefaultPersister(SpiEbeanServer, Binder, BeanDescriptorManager) - Constructor for class io.ebeaninternal.server.persist.DefaultPersister
- DefaultProfileHandler - Class in io.ebeaninternal.server.transaction
-
Default profile handler.
- DefaultProfileHandler(ProfilingConfig) - Constructor for class io.ebeaninternal.server.transaction.DefaultProfileHandler
- DefaultProfileStream - Class in io.ebeaninternal.server.transaction
-
Default transaction profiling event collection.
- DefaultRelationalQuery - Class in io.ebeaninternal.server.querydefn
-
Default implementation of SQuery - SQL Query.
- DefaultRelationalQuery(SpiEbeanServer, String) - Constructor for class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
-
Additional supply a query detail object.
- DefaultRelationalQueryEngine - Class in io.ebeaninternal.server.query
-
Perform native sql fetches.
- DefaultRelationalQueryEngine(Binder, String, boolean, int, int) - Constructor for class io.ebeaninternal.server.query.DefaultRelationalQueryEngine
- defaultSelect() - Method in enum io.ebeaninternal.api.SpiQuery.Type
-
Return true if this allows default select clause.
- defaultSelectClause() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the default select clause.
- DefaultServer - Class in io.ebeaninternal.server.core
-
The default server side implementation of EbeanServer.
- DefaultServer(InternalConfiguration, ServerCacheManager) - Constructor for class io.ebeaninternal.server.core.DefaultServer
-
Create the DefaultServer.
- DefaultServerCache - Class in io.ebeaninternal.server.cache
-
The default cache implementation.
- DefaultServerCache(DefaultServerCacheConfig) - Constructor for class io.ebeaninternal.server.cache.DefaultServerCache
- DefaultServerCache.CacheEntry - Class in io.ebeaninternal.server.cache
-
Wraps the value to additionally hold createTime and lastAccessTime and hit counter.
- DefaultServerCache.CompareByLastAccess - Class in io.ebeaninternal.server.cache
-
Comparator for sorting by last access sort, a copy of last access time that should not mutate during trim processing.
- DefaultServerCache.EvictionRunnable - Class in io.ebeaninternal.server.cache
-
Runnable that calls the eviction routine.
- DefaultServerCacheConfig - Class in io.ebeaninternal.server.cache
- DefaultServerCacheConfig(ServerCacheConfig) - Constructor for class io.ebeaninternal.server.cache.DefaultServerCacheConfig
- DefaultServerCacheConfig(ServerCacheConfig, Map<Object, SoftReference<DefaultServerCache.CacheEntry>>) - Constructor for class io.ebeaninternal.server.cache.DefaultServerCacheConfig
- DefaultServerCacheManager - Class in io.ebeaninternal.server.cache
-
Manages the bean and query caches.
- DefaultServerCacheManager() - Constructor for class io.ebeaninternal.server.cache.DefaultServerCacheManager
-
Construct when l2 cache is disabled.
- DefaultServerCacheManager(CacheManagerOptions) - Constructor for class io.ebeaninternal.server.cache.DefaultServerCacheManager
-
Create with a cache factory and default cache options.
- DefaultServerCachePlugin - Class in io.ebeaninternal.server.cache
-
Default implementation of ServerCachePlugin.
- DefaultServerCachePlugin() - Constructor for class io.ebeaninternal.server.cache.DefaultServerCachePlugin
- DefaultServerQueryCache - Class in io.ebeaninternal.server.cache
-
Server cache for query caching.
- DefaultServerQueryCache(DefaultServerCacheConfig) - Constructor for class io.ebeaninternal.server.cache.DefaultServerQueryCache
- DefaultSqlRow - Class in io.ebeaninternal.server.query
-
Used to return raw SQL query results.
- DefaultSqlRow(int, float, String, boolean) - Constructor for class io.ebeaninternal.server.query.DefaultSqlRow
-
Create with an initialCapacity and loadFactor.
- DefaultSqlUpdate - Class in io.ebeaninternal.server.core
-
A SQL Update Delete or Insert statement that can be executed.
- DefaultSqlUpdate(SpiEbeanServer, String) - Constructor for class io.ebeaninternal.server.core.DefaultSqlUpdate
-
Create with a specific server.
- DefaultSqlUpdate(SpiEbeanServer, String, BindParams) - Constructor for class io.ebeaninternal.server.core.DefaultSqlUpdate
-
Create with server sql and bindParams object.
- DefaultSqlUpdate(String) - Constructor for class io.ebeaninternal.server.core.DefaultSqlUpdate
-
Create with some sql.
- DefaultTransactionScopeManager - Class in io.ebeaninternal.server.transaction
-
Manages the transaction scoping using a Ebean thread local.
- DefaultTransactionScopeManager() - Constructor for class io.ebeaninternal.server.transaction.DefaultTransactionScopeManager
- DefaultTypeManager - Class in io.ebeaninternal.server.type
-
Default implementation of TypeManager.
- DefaultTypeManager(DatabaseBuilder.Settings, BootupClasses) - Constructor for class io.ebeaninternal.server.type.DefaultTypeManager
-
Create the DefaultTypeManager.
- DefaultUpdateQuery<T> - Class in io.ebeaninternal.server.querydefn
-
Default implementation of UpdateQuery.
- DefaultUpdateQuery(DefaultOrmQuery<T>) - Constructor for class io.ebeaninternal.server.querydefn.DefaultUpdateQuery
- deferredRelationship(EntityBean, ImportedId, EntityBean) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Register the derived relationships to get executed later (on JDBC batch flush or commit).
- delete - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
Behavior on delete.
- delete() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- delete() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute the query as a delete.
- delete() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- delete() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- delete(EntityBean, Transaction, boolean) - Method in interface io.ebeaninternal.server.core.Persister
-
Delete the bean.
- delete(EntityBean, Transaction, boolean) - Method in class io.ebeaninternal.server.persist.DefaultPersister
-
Delete the bean with the explicit transaction.
- delete(Database, boolean) - Method in class io.ebeaninternal.server.deploy.IntersectionTable
-
Return a SqlUpdate for deleting from the intersection table.
- delete(Transaction) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- delete(Transaction) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- delete(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- delete(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- delete(OrmQueryRequest<T>) - Method in interface io.ebeaninternal.server.core.OrmQueryEngine
-
Execute the query as a delete statement.
- delete(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.CQueryEngine
- delete(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.DefaultOrmQueryEngine
- delete(PersistRequestBean<?>) - Method in interface io.ebeaninternal.server.persist.BeanPersister
-
execute the delete bean request.
- delete(Class<?>, Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- delete(Class<?>, Object, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- delete(Class<?>, Object, Transaction, boolean) - Method in interface io.ebeaninternal.server.core.Persister
-
Delete a bean given it's type and id value.
- delete(Class<?>, Object, Transaction, boolean) - Method in class io.ebeaninternal.server.persist.DefaultPersister
-
Delete by Id.
- delete(Object) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Delete the bean.
- delete(Object, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Delete the bean with the explicit transaction.
- DELETE - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
Delete query.
- DELETE - Enum constant in enum io.ebeaninternal.api.SpiUpdate.OrmUpdateType
- DELETE - Enum constant in enum io.ebeaninternal.server.core.PersistRequest.Type
- DELETE_PERMANENT - Enum constant in enum io.ebeaninternal.server.core.PersistRequest.Type
- DELETE_SOFT - Enum constant in enum io.ebeaninternal.server.core.PersistRequest.Type
- deleteAll(Class<?>, Collection<?>) - Method in class io.ebeaninternal.server.core.DefaultServer
- deleteAll(Class<?>, Collection<?>, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- deleteAll(Collection<?>) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Delete all the beans in the collection.
- deleteAll(Collection<?>, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Delete all the beans in the collection.
- deleteAllPermanent(Class<?>, Collection<?>) - Method in class io.ebeaninternal.server.core.DefaultServer
- deleteAllPermanent(Class<?>, Collection<?>, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- deleteAllPermanent(Collection<?>) - Method in class io.ebeaninternal.server.core.DefaultServer
- deleteAllPermanent(Collection<?>, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- deleteById(Object, DocUpdateContext) - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Process a delete by id of a given document.
- deleteById(Object, DocUpdateContext) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- deleteById(Object, List<Object>, DeleteMode) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- deleteByIdInSql() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the "delete by id" sql.
- deleteByIdMap() - Method in class io.ebeaninternal.api.TransactionEvent
- DeleteByIdMap - Class in io.ebeaninternal.server.transaction
-
Beans deleted by Id used for updating L2 Cache.
- DeleteByIdMap() - Constructor for class io.ebeaninternal.server.transaction.DeleteByIdMap
- deleteByIds(BeanDescriptor<?>, List<Object>, Transaction, boolean) - Method in interface io.ebeaninternal.server.core.Persister
-
Delete multiple beans when escalated from a delete query.
- deleteByIds(BeanDescriptor<?>, List<Object>, Transaction, boolean) - Method in class io.ebeaninternal.server.persist.DefaultPersister
- deleteByParentId(Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Create SqlUpdate statement to delete all child beans of the parent
id. - deleteByParentId(Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- deleteByParentId(Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- deleteByParentIdList(List<Object>) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Create SqlUpdate statement to delete all child beans of the parent ids in
idList. - deleteByParentIdList(List<Object>) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- deleteByParentIdList(List<Object>) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- deleted(Class<?>, Object) - Method in class io.ebeaninternal.server.transaction.DefaultPersistenceContext
- deleted(Object) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistListener
- deleteEvents() - Method in class io.ebeanservice.docstore.api.DocStoreUpdates
-
Return delete events.
- deleteMany(Class<?>, Collection<?>, Transaction, boolean) - Method in interface io.ebeaninternal.server.core.Persister
-
Delete multiple beans given a collection of Id values.
- deleteMany(Class<?>, Collection<?>, Transaction, boolean) - Method in class io.ebeaninternal.server.persist.DefaultPersister
-
Delete by a List of Id's.
- deleteMode() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the delete mode - Soft or Hard.
- DeleteMode - Enum in io.ebeaninternal.server.persist
-
The delete mode of the persistence request.
- deletePermanent(Class<?>, Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- deletePermanent(Class<?>, Object, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- deletePermanent(Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- deletePermanent(Object, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- dependentTables() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the dependent tables for a view based entity.
- dependentTables() - Method in class io.ebeaninternal.server.query.CQuery
- dependentTables() - Method in class io.ebeaninternal.server.query.CQueryPlan
- deploy(Class<T>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Return the bean deploy info for the given class.
- deploy(List<XmapEbean>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Deploy returning the asOfTableMap (which is required by the SQL builders).
- DeployBeanDescriptor<T> - Class in io.ebeaninternal.server.deploy.meta
-
Describes Beans including their deployment information.
- DeployBeanDescriptor(BeanDescriptorManager, Class<T>, DatabaseBuilder.Settings) - Constructor for class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Construct the BeanDescriptor.
- DeployBeanEmbedded - Class in io.ebeaninternal.server.deploy.meta
-
Collects Deployment information on Embedded beans.
- DeployBeanEmbedded() - Constructor for class io.ebeaninternal.server.deploy.meta.DeployBeanEmbedded
- DeployBeanProperty - Class in io.ebeaninternal.server.deploy.meta
-
Description of a property of a bean.
- DeployBeanProperty(DeployBeanDescriptor<?>, Class<?>, ScalarType<?>, ScalarTypeConverter<?, ?>) - Constructor for class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- DeployBeanProperty(DeployBeanDescriptor<?>, Class<?>, Type) - Constructor for class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- DeployBeanPropertyAssoc<T> - Class in io.ebeaninternal.server.deploy.meta
-
Abstract base for properties mapped to an associated bean, list, set or map.
- DeployBeanPropertyAssocMany<T> - Class in io.ebeaninternal.server.deploy.meta
-
Property mapped to a List Set or Map.
- DeployBeanPropertyAssocMany(DeployBeanDescriptor<?>, Class<T>, ManyType) - Constructor for class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Create this property.
- DeployBeanPropertyAssocOne<T> - Class in io.ebeaninternal.server.deploy.meta
-
Property mapped to a joined bean.
- DeployBeanPropertyAssocOne(DeployBeanDescriptor<?>, Class<T>) - Constructor for class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
-
Create the property.
- DeployBeanPropertyLists - Class in io.ebeaninternal.server.deploy.meta
-
Helper object to classify BeanProperties into appropriate lists.
- DeployBeanPropertyLists(BeanDescriptorMap, BeanDescriptor<?>, DeployBeanDescriptor<?>) - Constructor for class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- DeployBeanPropertySimpleCollection<T> - Class in io.ebeaninternal.server.deploy.meta
- DeployBeanPropertySimpleCollection(DeployBeanDescriptor<?>, Class<T>, ManyType) - Constructor for class io.ebeaninternal.server.deploy.meta.DeployBeanPropertySimpleCollection
- DeployBeanTable - Class in io.ebeaninternal.server.deploy.meta
-
Used for associated beans in place of a BeanDescriptor.
- DeployDocPropertyOptions - Class in io.ebeaninternal.server.deploy
-
The options for document property collected when reading deployment mapping.
- DeployDocPropertyOptions() - Constructor for class io.ebeaninternal.server.deploy.DeployDocPropertyOptions
- DeployIdentityMode - Class in io.ebeaninternal.server.deploy.meta
- DeployIdentityMode(Identity) - Constructor for class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- deployOrder() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the order this property appears in the bean.
- DeployOrderColumn - Class in io.ebeaninternal.server.deploy.meta
- DeployOrderColumn(OrderColumn) - Constructor for class io.ebeaninternal.server.deploy.meta.DeployOrderColumn
- DeployParser - Class in io.ebeaninternal.server.deploy
-
Converts logical property names to database columns.
- DeployParser() - Constructor for class io.ebeaninternal.server.deploy.DeployParser
- DeployPropertyParser - Class in io.ebeaninternal.server.deploy
-
Converts logical property names to database columns with table alias.
- DeployPropertyParserMap - Class in io.ebeaninternal.server.deploy
-
Converts logical property names to database columns using a Map.
- DeployPropertyParserMap(Map<String, String>) - Constructor for class io.ebeaninternal.server.deploy.DeployPropertyParserMap
- DeployTableJoin - Class in io.ebeaninternal.server.deploy.meta
-
Represents a join to another table during deployment phase.
- DeployTableJoin() - Constructor for class io.ebeaninternal.server.deploy.meta.DeployTableJoin
-
Create a DeployTableJoin.
- DeployTableJoinColumn - Class in io.ebeaninternal.server.deploy.meta
-
A join pair of local and foreign properties.
- DeployTableJoinColumn(boolean, String, String, boolean, boolean, BeanTable) - Constructor for class io.ebeaninternal.server.deploy.meta.DeployTableJoinColumn
- DeployTableJoinColumn(String, String) - Constructor for class io.ebeaninternal.server.deploy.meta.DeployTableJoinColumn
-
Construct when automatically determining the join.
- DeployTableJoinColumn(String, String, boolean, boolean) - Constructor for class io.ebeaninternal.server.deploy.meta.DeployTableJoinColumn
-
Construct with explicit insertable and updateable flags.
- DeployUpdateParser - Class in io.ebeaninternal.server.deploy
-
For updates converts logical property names to database columns and bean type to base table.
- DeployUpdateParser(BeanDescriptor<?>) - Constructor for class io.ebeaninternal.server.deploy.DeployUpdateParser
- deployWord(String) - Method in class io.ebeaninternal.server.deploy.DeployParser
- deployWord(String) - Method in class io.ebeaninternal.server.deploy.DeployPropertyParser
- deployWord(String) - Method in class io.ebeaninternal.server.deploy.DeployPropertyParserMap
- deployWord(String) - Method in class io.ebeaninternal.server.deploy.DeployUpdateParser
- depth() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the current depth.
- depth() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- depth() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- depth() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- depth() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- depth(int) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Modify the current 'depth' of the transaction.
- depth(int) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- depth(int) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- depth(int) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- depth(int) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- depthDecrement() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Decrement the depth BUT only if depth is greater than 0.
- depthDecrement() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- depthDecrement() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- depthDecrement() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- depthDecrement() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- depthReset() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Reset the depth back to 0 - done at the end of top level insert and update.
- depthReset() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- depthReset() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- depthReset() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- depthReset() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- deregister(BeanPersistController) - Method in class io.ebeaninternal.server.core.DefaultServer
- deregister(BeanPersistController) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
De-register the BeanPersistController.
- deregister(BeanPersistController) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistController
-
De-register a BeanPersistController and return the resulting chain.
- deregister(BeanPersistListener) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
De-register the BeanPersistListener.
- deregister(BeanPersistListener) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistListener
-
De-register a BeanPersistListener and return the resulting chain.
- deregister(BeanPostConstructListener) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPostConstructListener
-
De-register a BeanPostCreate and return the resulting chain.
- deregister(BeanPostLoad) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPostLoad
-
De-register a BeanPostLoad and return the resulting chain.
- deregister(BeanQueryAdapter) - Method in class io.ebeaninternal.server.deploy.ChainedBeanQueryAdapter
-
De-register a BeanQueryAdapter and return the resulting chain.
- derive(BeanType<?>, String) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
Return the supplied value or default to the bean name lower case.
- derivePathProperties(PathProperties) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
Return the pathProperties which defines the JSON document to index.
- derivePropertyName(String, String) - Static method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping.Column
- desc - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
The associated BeanDescriptor.
- desc() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return the associated BeanDescriptor for this node.
- description() - Method in class io.ebeaninternal.api.LoadBeanRequest
- description() - Method in class io.ebeaninternal.api.LoadManyRequest
- descriptor() - Method in interface io.ebeaninternal.api.LoadBeanBuffer
- descriptor() - Method in interface io.ebeaninternal.api.LoadManyBuffer
- descriptor() - Method in interface io.ebeaninternal.api.SpiExpressionBind
-
Return the bean descriptor for the root type.
- descriptor() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the bean descriptor for this query.
- descriptor() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return the BeanDescriptor for the associated bean.
- descriptor() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the BeanDescriptor for the associated bean.
- descriptor() - Method in class io.ebeaninternal.server.core.PersistRequestOrmUpdate
- descriptor() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Return the associated BeanDescriptor.
- descriptor() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the BeanDescriptor that owns this property.
- descriptor() - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- descriptor() - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- descriptor() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- descriptor(Class<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return the BeanDescriptor for a given type of bean.
- descriptor(Class<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Return the BeanDescriptor for a given type of bean.
- descriptor(Class<T>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- descriptor(Class<T>) - Method in interface io.ebeaninternal.server.deploy.BeanDescriptorMap
-
Return the BeanDescriptor for a given class.
- descriptor(Class<U>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the BeanDescriptor of another bean type.
- descriptor(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the BeanDescriptor for a given path of Associated One or Many beans.
- descriptorByClassName(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- descriptorById(String) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return BeanDescriptor using it's unique id.
- descriptorById(String) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Return the BeanDescriptor using its class name.
- descriptorByQueueId(String) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return BeanDescriptor using it's unique doc store queueId.
- descriptorByQueueId(String) - Method in class io.ebeaninternal.server.core.DefaultServer
- descriptorByQueueId(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- descriptorId() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return bean class name.
- descriptorList() - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Return an immutable list of all the BeanDescriptors.
- descriptorManager() - Method in class io.ebeaninternal.server.transaction.TransactionManager
- descriptors() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return all the descriptors.
- descriptors() - Method in class io.ebeaninternal.server.core.DefaultServer
-
Return all the BeanDescriptors.
- descriptors(String) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return BeanDescriptors mapped to this table.
- descriptors(String) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Return the BeanDescriptor's for a given table name.
- descriptors(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Return the BeanDescriptors mapped to the table.
- detail() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the query detail.
- detail() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- detail() - Method in interface io.ebeaninternal.server.querydefn.SpiFetchGroup
-
Return the detail to use for query execution.
- determineTrimFrequency() - Method in class io.ebeaninternal.server.cache.DefaultServerCacheConfig
-
Determine a good trimFrequency as half of maxIdleSecs (or maxSecsToLive).
- determineTrimOnPut() - Method in class io.ebeaninternal.server.cache.DefaultServerCacheConfig
-
Determine the number of mutations/puts required to trigger a runEviction() in the foreground.
- DFetchGroupService - Class in io.ebeaninternal.server.query
-
Default implementation of SpiFetchGroupService.
- DFetchGroupService() - Constructor for class io.ebeaninternal.server.query.DFetchGroupService
- diff(EntityBean, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the diff comparing the bean values.
- diff(Object, Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- diff(Object, Object, BeanDescriptor<?>) - Static method in class io.ebeaninternal.server.core.DiffHelp
-
Return a map of the differences between a and b.
- diff(String, Map<String, ValuePair>, EntityBean, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Populate the diff for updates with flattened non-null property values.
- diff(String, Map<String, ValuePair>, EntityBean, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Populate diff map comparing the property values between the beans.
- diff(String, Map<String, ValuePair>, EntityBean, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- DiffHelp - Class in io.ebeaninternal.server.core
-
Helper to perform a diff given two beans of the same type.
- dirtyBeans(SpiBeanTypeManager) - Method in interface io.ebeaninternal.api.SpiPersistenceContext
-
Return the list of dirty beans held by this persistence context.
- dirtyBeans(SpiBeanTypeManager) - Method in class io.ebeaninternal.server.transaction.DefaultPersistenceContext
- dirtyProperties() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the dirty properties on this request.
- dirtyValues() - Method in class io.ebeaninternal.server.core.DefaultBeanState
- discColumn() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- discValue() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the discriminator value for this bean type (or null when there is no inheritance).
- disjunction() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- disjunction(Query<T>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Return a list of expressions that will be joined by OR's.
- disjunction(Query<T>, ExpressionList<T>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Return a list of expressions that will be joined by OR's.
- distinctOn() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the distinct on clause.
- distinctOn() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- distinctOn(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- DJsonBeanReader<T> - Class in io.ebeaninternal.server.json
-
A 'context' for reading entity beans from JSON.
- DJsonBeanReader(BeanDescriptor<T>, SpiJsonReader) - Constructor for class io.ebeaninternal.server.json.DJsonBeanReader
- DJsonContext - Class in io.ebeaninternal.server.json
-
Default implementation of JsonContext.
- DJsonContext(SpiEbeanServer, JsonFactory, TypeManager) - Constructor for class io.ebeaninternal.server.json.DJsonContext
- DJsonScalar - Class in io.ebeaninternal.server.json
-
Default implementation of JsonScalar.
- DJsonScalar(TypeManager) - Constructor for class io.ebeaninternal.server.json.DJsonScalar
- DJsonService - Class in io.ebeaninternal.json
-
Utility that converts between JSON content and simple java Maps/Lists.
- DJsonService() - Constructor for class io.ebeaninternal.json.DJsonService
- dmlAppend(GenerateDmlRequest) - Method in interface io.ebeaninternal.server.deploy.id.ImportedId
-
Append to the DML statement.
- dmlAppend(GenerateDmlRequest) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdEmbedded
- dmlAppend(GenerateDmlRequest) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- DmlUtil - Class in io.ebeaninternal.server.persist
-
Utility object with helper methods for DML.
- DmlUtil() - Constructor for class io.ebeaninternal.server.persist.DmlUtil
- doc() - Method in class io.ebeanservice.docstore.api.support.DocStructure
-
Return the document structure.
- DOC - Enum constant in enum io.ebeaninternal.server.deploy.BeanDescriptor.EntityType
- docExp() - Method in enum io.ebeaninternal.server.expression.Op
-
Return the doc store expression.
- docMapping() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- DocMappingBuilder - Class in io.ebeanservice.docstore.api.mapping
-
Builds the DocumentMapping for a given bean type.
- DocMappingBuilder(PathProperties, DocStore) - Constructor for class io.ebeanservice.docstore.api.mapping.DocMappingBuilder
-
Create with the document structure paths and docStore deployment annotation.
- DocPropertyAdapter - Class in io.ebeanservice.docstore.api.mapping
-
Adapter for DocPropertyVisitor that does not do anything.
- DocPropertyAdapter() - Constructor for class io.ebeanservice.docstore.api.mapping.DocPropertyAdapter
- DocPropertyMapping - Class in io.ebeanservice.docstore.api.mapping
-
Property mapping in a doc store document structure.
- DocPropertyMapping() - Constructor for class io.ebeanservice.docstore.api.mapping.DocPropertyMapping
-
Construct ROOT.
- DocPropertyMapping(String, DocPropertyType) - Constructor for class io.ebeanservice.docstore.api.mapping.DocPropertyMapping
-
Construct property mapping.
- DocPropertyMapping(String, DocPropertyType, DocPropertyOptions) - Constructor for class io.ebeanservice.docstore.api.mapping.DocPropertyMapping
-
Construct property mapping with options.
- DocPropertyOptions - Class in io.ebeanservice.docstore.api.mapping
-
Options for mapping a property for document storage.
- DocPropertyOptions() - Constructor for class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
-
Construct with no values set.
- DocPropertyVisitor - Interface in io.ebeanservice.docstore.api.mapping
-
Used to visit the properties in a document structure.
- DocQueryContext - Interface in io.ebeaninternal.server.expression
-
Context for writing a doc store query.
- DocQueryRequest<T> - Interface in io.ebeanservice.docstore.api
-
A Query request for the document store.
- docStore() - Method in class io.ebeaninternal.server.core.DefaultServer
- docStore() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the doc store helper for this bean type.
- docStoreAdapter() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return doc store adapter for internal use for processing persist requests.
- DocStoreBeanAdapter<T> - Interface in io.ebeanservice.docstore.api
-
Doc store specific adapter to process doc store events for a given bean type.
- DocStoreBeanBaseAdapter<T> - Class in io.ebeanservice.docstore.api.support
-
Base implementation for much of DocStoreBeanAdapter.
- DocStoreBeanBaseAdapter(BeanDescriptor<T>, DeployBeanDescriptor<T>) - Constructor for class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- docStoreDeleteById(Object, DocStoreUpdateContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- DocStoreDeleteEvent - Class in io.ebeanservice.docstore.api.support
-
A 'Delete by Id' request that is send to the document store.
- DocStoreDeleteEvent(BeanType<?>, Object) - Constructor for class io.ebeanservice.docstore.api.support.DocStoreDeleteEvent
- DocStoreEmbeddedInvalidation - Class in io.ebeanservice.docstore.api.support
-
Checks if a persist request means an embedded/nested object in another document needs updating.
- DocStoreEmbeddedInvalidation(String, String) - Constructor for class io.ebeanservice.docstore.api.support.DocStoreEmbeddedInvalidation
- DocStoreEmbeddedInvalidationProperties - Class in io.ebeanservice.docstore.api.support
-
Checks if a persist request means an embedded/nested object in another document needs updating.
- DocStoreEmbeddedInvalidationProperties(String, String, int[]) - Constructor for class io.ebeanservice.docstore.api.support.DocStoreEmbeddedInvalidationProperties
- DocStoreFactory - Interface in io.ebeanservice.docstore.api
-
Creates the integration components for DocStore integration.
- docStoreInclude(boolean, DocStructure) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Append this property to the document store based on includeByDefault setting.
- docStoreInclude(boolean, DocStructure) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Determine if and how the associated bean is included in the doc store document.
- docStoreIncludeByDefault(PathProperties) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- DocStoreIndexEvent<T> - Class in io.ebeanservice.docstore.api.support
-
A 'Delete by Id' request that is send to the document store.
- DocStoreIndexEvent(BeanType<T>, Object, T) - Constructor for class io.ebeanservice.docstore.api.support.DocStoreIndexEvent
- docStoreInsert(Object, PersistRequestBean<T>, DocStoreUpdateContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- DocStoreIntegration - Interface in io.ebeanservice.docstore.api
-
All the required features for DocStore integration.
- docStoreMapping(DocMappingBuilder, String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Build the Document mapping recursively with the given prefix relative to the root of the document.
- docStoreMapping(DocMappingBuilder, String) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Add to the document mapping if this property is included for this index.
- docStoreMapping(DocMappingBuilder, String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
- docStoreMode() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the batchSize specifically set for this transaction or 0.
- docStoreMode() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- docStoreMode() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- docStoreMode() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- docStoreMode() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- docStoreMode(PersistRequest.Type, DocStoreMode) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the type of DocStoreMode that should occur for this type of persist request given the transactions requested mode.
- DocStoreOnlyTransaction - Class in io.ebeaninternal.server.transaction
-
Document store only transaction.
- DocStoreOnlyTransaction(boolean, TransactionManager) - Constructor for class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Create a new DocStore only Transaction.
- docStorePersist() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Persist to the document store now (via buffer, not post commit).
- DocStoreQueryUpdate<T> - Interface in io.ebeanservice.docstore.api
-
Update the document store using a Ebean ORM query.
- docStoreQueueId() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the queueId used to uniquely identify this type when queuing an index updateAdd.
- docStoreTransaction() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return a document store transaction.
- docStoreTransaction() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- docStoreTransaction() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- docStoreTransaction() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- docStoreTransaction() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- DocStoreTransaction - Interface in io.ebeanservice.docstore.api
-
A document store transaction.
- DocStoreTransactionManager - Class in io.ebeaninternal.server.transaction
-
Transaction manager used for doc store only EbeanServer instance.
- DocStoreTransactionManager(TransactionManagerOptions) - Constructor for class io.ebeaninternal.server.transaction.DocStoreTransactionManager
-
Create the TransactionManager
- docStoreUpdate(DocStoreUpdateContext) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Process the persist request updating the document store.
- docStoreUpdate(DocStoreUpdateContext) - Method in interface io.ebeanservice.docstore.api.DocStoreUpdate
-
Add the event to the doc store bulk update.
- docStoreUpdate(DocStoreUpdateContext) - Method in class io.ebeanservice.docstore.api.support.DocStoreDeleteEvent
-
Add appropriate JSON content for sending to the ElasticSearch Bulk API.
- docStoreUpdate(DocStoreUpdateContext) - Method in class io.ebeanservice.docstore.api.support.DocStoreIndexEvent
-
Add appropriate JSON content for sending to the ElasticSearch Bulk API.
- docStoreUpdate(Object, PersistRequestBean<T>, DocStoreUpdateContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- DocStoreUpdate - Interface in io.ebeanservice.docstore.api
-
For persist events that know how to publish or queue their change to the Document store.
- DocStoreUpdateContext - Interface in io.ebeanservice.docstore.api
-
The doc store specific context/transaction used to collect updates to send to the document store.
- docStoreUpdateEmbedded(PersistRequestBean<T>, DocStoreUpdates) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Check if this update invalidates an embedded part of a doc store document.
- DocStoreUpdateProcessor - Interface in io.ebeanservice.docstore.api
-
Processes index updates.
- DocStoreUpdates - Class in io.ebeanservice.docstore.api
-
Collection of document store updates that are either sent to the document store or queued for future processing
- DocStoreUpdates() - Constructor for class io.ebeanservice.docstore.api.DocStoreUpdates
- docStructure - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
Nested path properties defining the doc structure for indexing.
- docStructure(PathProperties, boolean) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- DocStructure - Class in io.ebeanservice.docstore.api.support
-
Document structure for mapping to document store.
- DocStructure(PathProperties) - Constructor for class io.ebeanservice.docstore.api.support.DocStructure
-
Create given an initial deployment doc mapping.
- docType() - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.BooleanBase
- docType() - Method in class io.ebeaninternal.server.type.ScalarTypeBytesBase
- docType() - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- docType() - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- docType() - Method in class io.ebeaninternal.server.type.ScalarTypeString
- docType() - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- docType() - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- documentMapping - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- DocumentMapping - Class in io.ebeanservice.docstore.api.mapping
-
Mapping for a document stored in a doc store (like ElasticSearch).
- DocumentMapping(String, String, String, FetchPath, DocPropertyMapping, int, int) - Constructor for class io.ebeanservice.docstore.api.mapping.DocumentMapping
- DocumentNotFoundException - Exception Class in io.ebeanservice.docstore.api
-
Can be thrown when a document is unexpectedly not found in a document store.
- DocumentNotFoundException(String) - Constructor for exception class io.ebeanservice.docstore.api.DocumentNotFoundException
-
Construct with a message.
- documentStore() - Method in interface io.ebeanservice.docstore.api.DocStoreIntegration
-
Return the DocStore.
- docValues() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- docValues(Boolean) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- DRAFT - Enum constant in enum io.ebeaninternal.api.SpiQuery.TemporalMode
-
Query runs against draft tables.
- draftQueryOptimise(Query<T>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Optimise the draft query fetching any draftable element relationships.
- draftReset(T) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Reset properties on the draft bean based on @DraftDirty and @DraftReset.
- draftRestore(Query<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- draftRestore(Query<T>, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- draftRestore(Query<T>, Transaction) - Method in interface io.ebeaninternal.server.core.Persister
-
Restore the draft beans back to the matching live beans.
- draftRestore(Query<T>, Transaction) - Method in class io.ebeaninternal.server.persist.DefaultPersister
-
Restore draft beans to match live beans given the query.
- draftRestore(Class<T>, Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- draftRestore(Class<T>, Object, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- draftTable() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the associated draft table.
- draftTableMap() - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Return the map of base tables to draft tables.
- DRawSql - Class in io.ebeaninternal.server.rawsql
-
Default implementation of SpiRawSql.
- DRawSql(ResultSet, String...) - Constructor for class io.ebeaninternal.server.rawsql.DRawSql
-
Construct with a ResultSet and properties that the columns map to.
- DRawSqlBuilder - Class in io.ebeaninternal.server.rawsql
- DRawSqlService - Class in io.ebeaninternal.server.rawsql
- DRawSqlService() - Constructor for class io.ebeaninternal.server.rawsql.DRawSqlService
- DSelectColumnsParser - Class in io.ebeaninternal.server.util
-
Splits a select clause into 'logical columns' taking into account functions and quotes.
- DtoQueryEngine - Class in io.ebeaninternal.server.query
- DtoQueryEngine(Binder, int, int) - Constructor for class io.ebeaninternal.server.query.DtoQueryEngine
- DtoQueryRequest<T> - Class in io.ebeaninternal.server.core
-
Wraps the objects involved in executing a DtoQuery.
- DynamicPropertyAggregationFormulaMTO - Class in io.ebeaninternal.server.deploy
E
- ebeanServer() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the EbeanServer instance that owns this BeanDescriptor.
- elComparator(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- ElComparator<T> - Interface in io.ebeaninternal.server.el
-
Comparator for use with the expression objects.
- ElComparatorCompound<T> - Class in io.ebeaninternal.server.el
-
Comparator based on multiple ordered comparators.
- ElComparatorCompound(ElComparator<T>[]) - Constructor for class io.ebeaninternal.server.el.ElComparatorCompound
- ElComparatorNoop<T> - Class in io.ebeaninternal.server.el
-
Comparator with no operation for unsortable properties.
- ElComparatorNoop() - Constructor for class io.ebeaninternal.server.el.ElComparatorNoop
- ElComparatorProperty<T> - Class in io.ebeaninternal.server.el
-
Comparator based on a ElGetValue.
- ElComparatorProperty(ElPropertyValue, boolean, boolean) - Constructor for class io.ebeaninternal.server.el.ElComparatorProperty
- ElementCollector - Interface in io.ebeaninternal.server.deploy
-
Collects (List/Set/Map) of elements.
- elementDescriptor() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return the element bean descriptor (for an element collection only).
- ElFilter<T> - Class in io.ebeaninternal.server.el
-
Default implementation of the Filter interface.
- ElFilter(BeanDescriptor<T>) - Constructor for class io.ebeaninternal.server.el.ElFilter
- elGetValue(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Get an Expression language Value object.
- ElMatcher<T> - Interface in io.ebeaninternal.server.el
-
Interface for defining matches for filter expressions.
- elName() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- elName() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- elName() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- elName() - Method in interface io.ebeaninternal.server.el.ElPropertyDeploy
-
The ElPrefix plus name.
- elPlaceholder(boolean) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- elPlaceholder(boolean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- elPlaceholder(boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- elPlaceholder(boolean) - Method in class io.ebeaninternal.server.el.ElPropertyChain
- elPlaceholder(boolean) - Method in interface io.ebeaninternal.server.el.ElPropertyDeploy
-
Return the place holder in the form of ${elPrefix}dbColumn.
- elPrefix() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- elPrefix() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- elPrefix() - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- elPrefix() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- elPrefix() - Method in interface io.ebeaninternal.server.el.ElPropertyDeploy
-
Return the prefix path of the property.
- elPrefix() - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Return the Expression language prefix (join path).
- ElPropertyChain - Class in io.ebeaninternal.server.el
-
A ElGetValue based on a chain of properties.
- ElPropertyChain(boolean, boolean, String, ElPropertyValue[]) - Constructor for class io.ebeaninternal.server.el.ElPropertyChain
- ElPropertyChainBuilder - Class in io.ebeaninternal.server.el
-
Utility object used to build a ElPropertyChain.
- ElPropertyChainBuilder(boolean, String) - Constructor for class io.ebeaninternal.server.el.ElPropertyChainBuilder
-
Create with the original expression.
- elPropertyDeploy(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Similar to ElPropertyValue but also uses foreign key shortcuts.
- ElPropertyDeploy - Interface in io.ebeaninternal.server.el
-
Used to parse expressions in queries (where, orderBy etc).
- ElPropertyValue - Interface in io.ebeaninternal.server.el
-
The expression language object that can get values.
- embedded(String) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- embedded(String) - Method in class io.ebeanservice.docstore.api.support.DocStructure
-
Return the document structure for an embedded path.
- EMBEDDED - Enum constant in enum io.ebeaninternal.server.deploy.BeanDescriptor.EntityType
- embeddedInvalidate(PersistRequestBean<?>, DocStoreUpdates) - Method in class io.ebeanservice.docstore.api.support.DocStoreEmbeddedInvalidation
- embeddedInvalidate(PersistRequestBean<?>, DocStoreUpdates) - Method in class io.ebeanservice.docstore.api.support.DocStoreEmbeddedInvalidationProperties
- embeddedInvalidation - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
List of embedded paths from other documents that include this document type.
- embeddedInvalidation(String, String, Set<String>) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
Return the DsInvalidationListener based on the properties, path.
- embeddedManyRoot(String) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- embeddedManyRoot(String) - Method in class io.ebeanservice.docstore.api.support.DocStructure
- enableBindLog() - Method in interface io.ebeaninternal.api.SpiLogManager
-
Enable bind logging.
- enabled() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- enabled(Boolean) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- enabledRegions(String) - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- encrypt(byte[]) - Method in class io.ebeaninternal.server.type.DataEncryptSupport
- encrypt(byte[], EncryptKey) - Method in class io.ebeaninternal.server.type.SimpleAesEncryptor
- EncryptAlias - Interface in io.ebeaninternal.server.core
-
Used to create column alias for encrypted columns.
- encryptedProps() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Return a list of encrypted properties which require additional binding.
- encryptKey() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the encrypt key for the column matching this property.
- encryptKey(BeanProperty) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the Encrypt key given the BeanProperty.
- encryptKey(String, String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the Encrypt key given the table and column name.
- encryptKey(String, String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Return the Encrypt key given the table and column name.
- encryptKey(String, String) - Method in interface io.ebeaninternal.server.deploy.BeanDescriptorMap
-
Return the Encrypt key given the table and column name.
- encryptKeyAsString() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- encryptKeyAsString() - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- encryptKeyAsString() - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Return the encryption key as a string value (when the property is encrypted).
- encryptObject(String) - Method in class io.ebeaninternal.server.type.DataEncryptSupport
- encryptString(String, EncryptKey) - Method in class io.ebeaninternal.server.type.SimpleAesEncryptor
- end() - Method in class io.ebeaninternal.api.BinaryWriteContext
-
End of message parts.
- end() - Method in class io.ebeaninternal.api.ScopedTransaction
- end() - Method in class io.ebeaninternal.api.ScopeTrans
- end() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
This will always throw a PersistenceException.
- end() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
If the transaction is active then perform rollback.
- end() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
If the transaction is active then perform rollback.
- end(TransactionManager) - Method in class io.ebeaninternal.server.transaction.DefaultProfileStream
-
End the transaction profiling.
- end(TransactionManager) - Method in interface io.ebeaninternal.server.transaction.ProfileStream
-
Transaction completed collect the profiling information.
- endAnd() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- endAssocMany() - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
End a Many.
- endAssocMany() - Method in class io.ebeaninternal.server.json.WriteJson
- endAssocManyMap(boolean) - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
End a Many.
- endAssocManyMap(boolean) - Method in class io.ebeaninternal.server.json.WriteJson
- endAssocOne() - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
End an assoc one path.
- endAssocOne() - Method in class io.ebeaninternal.server.json.WriteJson
- endBool() - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
End a bool expression/group.
- endBoolGroup() - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
End the Bool group.
- endBoolGroupList() - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
End a Must, Must Not or Should list.
- endIterate() - Method in class io.ebeaninternal.server.transaction.DefaultPersistenceContext
- endJunction() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- endNested() - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
End nested path expressions.
- endNot() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- endNot() - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
End a not wrapper.
- endOr() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- endsWith(String) - Method in class io.ebeaninternal.server.el.CharMatch
- endsWith(String, String) - Method in class io.ebeaninternal.server.el.ElFilter
- endsWith(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Ends With - property like %value.
- endsWith(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- endTransaction() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
End the current transaction if it is active.
- endTransaction() - Method in class io.ebeaninternal.server.core.DefaultServer
- endTransIfRequired() - Method in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
-
End the transaction if it was locally created.
- endTransIfRequired() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Will end a locally created transaction.
- endTransIfRequired() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Will end a locally created transaction.
- enter(TxScope) - Static method in class io.ebeaninternal.api.HelpScopeTrans
-
Entering an enhanced transactional method.
- entityBean() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- entityType() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the type of this domain object.
- entries() - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Return the underlying fetch path entries.
- entrySet() - Method in class io.ebeaninternal.json.ModifyAwareMap
- entrySet() - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- enumType(Class<? extends Enum<?>>, EnumType) - Method in class io.ebeaninternal.server.type.DefaultTypeManager
-
Create a ScalarType for an Enum that has additional mapping.
- enumType(Class<? extends Enum<?>>, EnumType) - Method in interface io.ebeaninternal.server.type.TypeManager
-
Create a ScalarType for an Enum using a mapping (rather than JPA Ordinal or String which has limitations).
- eq(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- eq(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- eq(String, Object) - Method in class io.ebeaninternal.server.el.ElFilter
- eq(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Equal To - property equal to the given value.
- eq(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- EQ - Enum constant in enum io.ebeaninternal.server.expression.Op
-
Equal to
- eqIfPresent(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- EqlParser - Class in io.ebeaninternal.server.grammer
-
Parse EQL query language applying it to an ORM query object.
- EqlParser() - Constructor for class io.ebeaninternal.server.grammer.EqlParser
- eqOrNull(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- eqOrNull(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- eqSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- eqSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- equals(Object) - Method in class io.ebeaninternal.api.BindParams.Param
- equals(Object) - Method in class io.ebeaninternal.api.BindValuesKey
- equals(Object) - Method in class io.ebeaninternal.api.HashQuery
- equals(Object) - Method in class io.ebeaninternal.json.ModifyAwareList
- equals(Object) - Method in class io.ebeaninternal.json.ModifyAwareMap
- equals(Object) - Method in class io.ebeaninternal.json.ModifyAwareSet
- equals(Object) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- equals(Object) - Method in class io.ebeaninternal.server.deploy.TableJoin
- equals(Object) - Method in class io.ebeaninternal.server.deploy.TableJoinColumn
- equals(Object) - Method in class io.ebeaninternal.server.deploy.TablespaceMeta
- equals(Object) - Method in class io.ebeaninternal.server.query.NativeSqlQueryPlanKey
- equals(Object) - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping.Column
- equals(Object) - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping
- equals(Object) - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.Key
- escapeLikeString(String) - Method in interface io.ebeaninternal.api.SpiExpressionBind
-
Escapes a string to use it as exact match in Like clause.
- escapeLikeString(String) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return the database platform escaped like string.
- escapeLikeString(String) - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Escapes a string to use it as exact match in Like clause.
- escapeLikeString(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- event() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Get the object that holds the event details.
- event() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- event() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Return the underlying TransactionEvent.
- event() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Return the underlying TransactionEvent.
- event() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Return the underlying TransactionEvent.
- eventTables() - Method in class io.ebeaninternal.api.TransactionEvent
- evictCount - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- EvictionRunnable() - Constructor for class io.ebeaninternal.server.cache.DefaultServerCache.EvictionRunnable
- EVT_CALLABLESQL - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- EVT_COMMIT - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- EVT_DELETE - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- EVT_DELETE_PERMANENT - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- EVT_DELETE_SOFT - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- EVT_INSERT - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- EVT_ORMUPDATE - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- EVT_ROLLBACK - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- EVT_UPDATE - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- EVT_UPDATESQL - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- exampleLike(Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Create the query by Example expression which is case-sensitive and using LikeType.RAW (you need to add you own wildcards % and _).
- exampleLike(Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- exampleLike(Object, boolean, LikeType) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Create the query by Example expression specifying more options.
- execute() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- execute() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- execute(boolean) - Method in interface io.ebeaninternal.api.SpiDdlGenerator
-
Generate and run the DDL for drop-all and create-all scripts.
- execute(TxScope, Runnable) - Method in class io.ebeaninternal.server.core.DefaultServer
- execute(CallableSql) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Execute the CallableSql.
- execute(CallableSql, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Execute the CallableSql with an explicit transaction.
- execute(SqlUpdate) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Execute the updateSql.
- execute(SqlUpdate, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Execute the updateSql with an explicit transaction.
- execute(Update<?>) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Execute the orm update.
- execute(Update<?>, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Execute the updateSql with an explicit transaction.
- execute(SpiTransaction) - Method in class io.ebeaninternal.server.core.PersistDeferredRelationship
-
Build and execute a SqlUpdate to set the importId value (as it will be available now).
- execute(Runnable) - Method in class io.ebeaninternal.server.core.DefaultServer
- execute(String, boolean) - Method in class io.ebeaninternal.server.persist.BatchControl
-
Execute a batched statement.
- execute(String, boolean) - Method in class io.ebeaninternal.server.persist.BatchedPstmtHolder
-
Execute one of the batched statements returning the row counts.
- executeAddBatch() - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
-
Execute using jdbc batch.
- executeAsSql(Binder) - Method in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
- executeBatch() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- executeBatch(boolean) - Method in class io.ebeaninternal.server.persist.BatchedPstmt
-
Execute the statement using executeBatch().
- executeBatch(SpiSqlUpdate, SpiTransaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- executeBatch(SpiSqlUpdate, SpiTransaction) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Execute the batched statement.
- executeBatch(SpiSqlUpdate, SpiTransaction) - Method in interface io.ebeaninternal.server.core.Persister
-
Execute the associated batched statement.
- executeBatch(SpiSqlUpdate, SpiTransaction) - Method in class io.ebeaninternal.server.persist.DefaultPersister
- executeCall(TxScope, Callable<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- executeCall(Callable<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- executeCallable(CallableSql, Transaction) - Method in interface io.ebeaninternal.server.core.Persister
-
Execute the CallableSql.
- executeCallable(CallableSql, Transaction) - Method in class io.ebeaninternal.server.persist.DefaultPersister
-
Execute the CallableSql.
- executeGetKey() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- executeNow() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- executeNow() - Method in class io.ebeaninternal.server.core.PersistRequest
-
Execute the request right now.
- executeNow() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- executeNow() - Method in class io.ebeaninternal.server.core.PersistRequestCallableSql
- executeNow() - Method in class io.ebeaninternal.server.core.PersistRequestOrmUpdate
- executeNow() - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
- executeNow(SpiSqlUpdate) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Execute the sql update regardless of transaction batch mode.
- executeNow(SpiSqlUpdate) - Method in class io.ebeaninternal.server.core.DefaultServer
- executeOrmUpdate(Update<?>, Transaction) - Method in interface io.ebeaninternal.server.core.Persister
-
Execute the Update.
- executeOrmUpdate(Update<?>, Transaction) - Method in class io.ebeaninternal.server.persist.DefaultPersister
-
Execute the orm update.
- executeOrmUpdate(PersistRequestOrmUpdate) - Method in interface io.ebeaninternal.server.persist.PersistExecute
-
Execute a Update.
- executeOrQueue() - Method in class io.ebeaninternal.server.core.PersistRequest
-
Execute a the request or queue/batch it for later execution.
- executeOrQueue() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- executeOrQueue() - Method in class io.ebeaninternal.server.core.PersistRequestCallableSql
- executeOrQueue() - Method in class io.ebeaninternal.server.core.PersistRequestOrmUpdate
- executeOrQueue() - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
- executeOrQueue(SpiSqlUpdate, SpiTransaction, boolean, int) - Method in interface io.ebeaninternal.server.core.Persister
-
Execute or queue the update.
- executeOrQueue(SpiSqlUpdate, SpiTransaction, boolean, int) - Method in class io.ebeaninternal.server.persist.DefaultPersister
- executeOrQueue(PersistRequestBean<?>, boolean) - Method in class io.ebeaninternal.server.persist.BatchControl
-
Entity Bean insert, update or delete.
- executePlugins(boolean) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Execute all the plugins with an online flag indicating the DB is up or not.
- executeSecondaryQueries(boolean) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- executeSecondaryQueries(boolean) - Method in interface io.ebeanservice.docstore.api.DocQueryRequest
-
Execute secondary queries.
- executeSecondaryQueries(OrmQueryRequest<?>, boolean) - Method in interface io.ebeaninternal.api.LoadContext
-
Execute any secondary (+query) queries if there are any defined.
- executeSql(Binder, SpiQuery.Type) - Method in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
-
Prepare and execute the SQL using the Binder.
- executeSql(Binder, SpiQuery.Type) - Method in class io.ebeaninternal.server.core.DtoQueryRequest
-
Prepare and execute the SQL using the Binder.
- executeSqlCallable(PersistRequestCallableSql) - Method in interface io.ebeaninternal.server.persist.PersistExecute
-
Execute a CallableSql.
- executeSqlUpdate(SqlUpdate, Transaction) - Method in interface io.ebeaninternal.server.core.Persister
-
Execute the SqlUpdate (taking into account transaction batch mode).
- executeSqlUpdate(SqlUpdate, Transaction) - Method in class io.ebeaninternal.server.persist.DefaultPersister
-
Execute the updateSql.
- executeSqlUpdate(PersistRequestUpdateSql) - Method in interface io.ebeaninternal.server.persist.PersistExecute
-
Execute a UpdateSql.
- executeSqlUpdateNow(SpiSqlUpdate, Transaction) - Method in interface io.ebeaninternal.server.core.Persister
-
Execute the SqlUpdate now regardless of transaction batch mode.
- executeSqlUpdateNow(SpiSqlUpdate, Transaction) - Method in class io.ebeaninternal.server.persist.DefaultPersister
- executeStatementOrBatch(PersistRequest, boolean, boolean) - Method in class io.ebeaninternal.server.persist.BatchControl
-
Execute a Orm Update, SqlUpdate or CallableSql.
- executeUpdate() - Method in class io.ebeaninternal.server.core.PersistRequestCallableSql
-
Execute the statement in normal non batch mode.
- exists() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- exists() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- exists() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- exists(Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Exists subquery
- exists(Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- exists(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- exists(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- exists(Class<?>, Object, Transaction) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return true if a row for the bean type and id exists.
- exists(Class<?>, Object, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- exists(String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
In - using a subQuery.
- exists(String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- EXISTS - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
Find exists.
- EXISTS - Enum constant in enum io.ebeaninternal.server.expression.Op
-
Exists (JSON).
- exit(Object, int) - Static method in class io.ebeaninternal.api.HelpScopeTrans
-
Exiting an enhanced transactional method.
- exitScopedTransaction(Object, int) - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Exit a scoped transaction (that can be inactive - already committed etc).
- expr - Variable in class io.ebeaninternal.server.expression.DefaultExpressionList
- expression() - Method in class io.ebeaninternal.server.el.ElPropertyChainBuilder
- expressionFactory() - Method in class io.ebeaninternal.server.core.DefaultServer
- expressionList() - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- expressionPath(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- extended() - Method in class io.ebeaninternal.server.core.DefaultServer
- externalBeginTransaction(SpiTransaction, TxScope) - Method in interface io.ebeaninternal.api.SpiTransactionManager
-
Push an externally managed transaction into scope (e.g.
- externalBeginTransaction(SpiTransaction, TxScope) - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Push an externally created transaction into scope.
- ExternalJdbcTransaction - Class in io.ebeaninternal.server.transaction
-
Transaction based on a java.sql.Connection supplied by an external transaction manager such as Spring.
- ExternalJdbcTransaction(boolean, Connection, TransactionManager) - Constructor for class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Construct will all explicit parameters.
- ExternalJdbcTransaction(Connection) - Constructor for class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Create a Transaction that will have no transaction logging support.
- externalModification(TransactionEventTable) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Process committed changes from another framework.
- externalModification(TransactionEventTable) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Process committed beans from another framework or server in another cluster.
- externalModification(TransactionEventTable) - Method in class io.ebeaninternal.server.transaction.TransactionManager
- externalModification(String, boolean, boolean, boolean) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Developer informing eBean that tables where modified outside of eBean.
- externalRemoveTransaction() - Method in interface io.ebeaninternal.api.SpiTransactionManager
-
Called when an externally managed transaction has completed.
- externalRemoveTransaction() - Method in class io.ebeaninternal.server.transaction.TransactionManager
- ExternalTransactionScopeManager - Class in io.ebeaninternal.server.transaction
-
A TransactionScopeManager aware of external transaction managers.
- ExternalTransactionScopeManager(ExternalTransactionManager) - Constructor for class io.ebeaninternal.server.transaction.ExternalTransactionScopeManager
-
Instantiates transaction scope manager.
- extract(BeanDescriptor<?>, EntityBean) - Static method in class io.ebeaninternal.server.cache.CachedBeanDataFromBean
- extraIncludes(Set<String>) - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- extraIncludes(Set<String>) - Method in interface io.ebeaninternal.server.query.STreeProperty
- extraJoin(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- extraJoin(String) - Method in interface io.ebeaninternal.server.query.STreeType
-
Return an extra join if the property path requires it.
- ExtraJoin - Class in io.ebeaninternal.server.query
- ExtraJoin(STreePropertyAssoc, boolean) - Constructor for class io.ebeaninternal.server.query.ExtraJoin
- ExtraMetrics - Class in io.ebeaninternal.api
-
Extra metrics collected to measure internal behaviour.
- ExtraMetrics() - Constructor for class io.ebeaninternal.api.ExtraMetrics
-
Create the extra metrics.
- extraWhere() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return an extra clause to add to the query for loading or joining to this bean type.
- extraWhere() - Method in interface io.ebeaninternal.server.query.STreePropertyAssoc
-
Return the extra where clause if set.
F
- fetch(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- fetch(String, FetchConfig) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- fetch(String, String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- fetch(String, String, FetchConfig) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- fetch(String, String, FetchConfig) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Set the fetch properties and configuration for a given path.
- fetch(String, LinkedHashSet<String>) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Add for raw sql etc when the properties are already parsed into a set.
- fetchCache(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- fetchCache(String, String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- fetchLazy(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- fetchLazy(String, String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- fetchOrderBy() - Method in interface io.ebeaninternal.api.SpiQueryManyJoin
-
Order by clause defined via mapping on the ToMany property.
- fetchOrderBy() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return the order by clause used to order the fetching of the data for this list, set or map.
- fetchOrderBy() - Method in interface io.ebeaninternal.server.el.ElPropertyDeploy
- fetchPreference() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- fetchPreference() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- fetchPreference() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
- fetchPreference() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- fetchPreference() - Method in interface io.ebeaninternal.server.el.ElPropertyDeploy
-
Return the fetch preference.
- fetchProperties(String, OrmQueryProperties) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the fetch properties for the given path.
- fetchProperties(String, OrmQueryProperties) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- fetchProperties(String, Set<String>, FetchConfig) - Method in interface io.ebeaninternal.api.SpiQueryFetch
-
Specify the fetch properties for the given path.
- fetchProperties(String, Set<String>, FetchConfig) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- fetchProperties(String, Set<String>, FetchConfig) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Set fetch properties that are already parsed.
- fetchQuery(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- fetchQuery(String, String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- filter(Class<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- filter(List<T>) - Method in class io.ebeaninternal.server.el.ElFilter
- FilterExpressionList<T> - Class in io.ebeaninternal.server.expression
- FilterExpressionList(FilterExprPath, ExpressionFactory, Query<T>) - Constructor for class io.ebeaninternal.server.expression.FilterExpressionList
- FilterExpressionList(FilterExprPath, FilterExpressionList<T>) - Constructor for class io.ebeaninternal.server.expression.FilterExpressionList
- FilterExprPath - Class in io.ebeaninternal.server.expression
-
This is the path prefix for filterMany.
- FilterExprPath(String) - Constructor for class io.ebeaninternal.server.expression.FilterExprPath
- filterMany(Query<T>) - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Return the expressions used to filter on this path.
- filterMany(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- filterMany(String) - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- filterMany(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- filterMany(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- filterManyInline() - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Adjust filterMany expressions for inclusion in main query.
- filterManyRaw(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- find(DatabaseBuilder.Settings) - Static method in class io.ebeaninternal.server.core.ClassPathScanners
-
Return the list of ClassPathScanner services using DatabaseConfig service loader.
- find(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.CQueryEngine
-
Find and return a single bean using its unique id.
- find(Class<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- find(Class<T>, Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- find(Class<T>, Object, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Find a bean using its unique id.
- FIND_ATTRIBUTE - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- FIND_ATTRIBUTE_SET - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- FIND_COUNT - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- FIND_DELETE - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- FIND_EXISTS - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- FIND_ID_LIST - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- FIND_ITERATE - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- FIND_MANY - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- FIND_MANY_LAZY - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- FIND_ONE - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- FIND_ONE_LAZY - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- FIND_SUBQUERY - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- FIND_UPDATE - Static variable in interface io.ebeaninternal.api.TxnProfileEventCodes
- findBeanPath(String, String, String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the property path given the db table and column.
- findBeanProperty(String) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Find a BeanProperty that is mapped to the database column.
- findBeanProperty(String) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- findBeanProperty(String) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- findController() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the find controller (SPI interface).
- findCount() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- findCount() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute the find row count query.
- findCount() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findCount() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- findCount() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findCount(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findCount(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findCount(OrmQueryRequest<T>) - Method in interface io.ebeaninternal.server.core.OrmQueryEngine
-
Execute the row count query.
- findCount(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.CQueryEngine
-
Build and execute the row count query.
- findCount(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.DefaultOrmQueryEngine
- findCountWithCopy(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Execute the findCount query but without copying the query.
- findCountWithCopy(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findDto(Class<D>, SpiQuery<?>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return / wrap the ORM query as a DTO query.
- findDto(Class<T>, SpiQuery<?>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findDto(Class<T>, String) - Method in class io.ebeaninternal.server.core.DefaultServer
- findDtoEach(SpiDtoQuery<T>, int, Consumer<List<T>>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
DTO findEach batch query.
- findDtoEach(SpiDtoQuery<T>, int, Consumer<List<T>>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findDtoEach(SpiDtoQuery<T>, Consumer<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
DTO findEach query.
- findDtoEach(SpiDtoQuery<T>, Consumer<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findDtoEachWhile(SpiDtoQuery<T>, Predicate<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
DTO findEachWhile query.
- findDtoEachWhile(SpiDtoQuery<T>, Predicate<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findDtoIterate(SpiDtoQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
DTO findIterate query.
- findDtoIterate(SpiDtoQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findDtoList(SpiDtoQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
DTO findList query.
- findDtoList(SpiDtoQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findDtoOne(SpiDtoQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
DTO findOne query.
- findDtoOne(SpiDtoQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findDtoStream(SpiDtoQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
DTO findStream query.
- findDtoStream(SpiDtoQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findEach(int, Consumer<List<T>>) - Method in class io.ebeaninternal.server.core.DtoQueryRequest
- findEach(int, Consumer<List<T>>) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- findEach(int, Consumer<List<T>>) - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute findEach with a batch consumer.
- findEach(int, Consumer<List<T>>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findEach(int, Consumer<List<T>>) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- findEach(int, Consumer<List<T>>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findEach(SpiQuery<T>, int, Consumer<List<T>>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findEach(SpiQuery<T>, int, Consumer<List<T>>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findEach(SpiQuery<T>, Consumer<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findEach(SpiQuery<T>, Consumer<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findEach(SpiSqlQuery, Consumer<SqlRow>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findEach(SpiSqlQuery, Consumer<SqlRow>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findEach(DtoQueryRequest<T>, int, Consumer<List<T>>) - Method in class io.ebeaninternal.server.query.DtoQueryEngine
- findEach(DtoQueryRequest<T>, Consumer<T>) - Method in class io.ebeaninternal.server.query.DtoQueryEngine
- findEach(RelationalQueryRequest, RowConsumer) - Method in interface io.ebeaninternal.server.core.RelationalQueryEngine
-
Find each via raw consumer.
- findEach(RelationalQueryRequest, RowConsumer) - Method in class io.ebeaninternal.server.query.DefaultRelationalQueryEngine
- findEach(RelationalQueryRequest, RowReader<T>, Predicate<T>) - Method in interface io.ebeaninternal.server.core.RelationalQueryEngine
-
Find each while query using relational query.
- findEach(RelationalQueryRequest, RowReader<T>, Predicate<T>) - Method in class io.ebeaninternal.server.query.DefaultRelationalQueryEngine
- findEach(Consumer<SqlRow>) - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
- findEach(Consumer<SqlRow>) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- findEach(Consumer<T>) - Method in class io.ebeaninternal.server.core.DtoQueryRequest
- findEach(Consumer<T>) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- findEach(Consumer<T>) - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute findEach iterating results one bean at a time.
- findEach(Consumer<T>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findEach(Consumer<T>) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- findEach(Consumer<T>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findEachRow(RowConsumer) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- findEachRow(SpiSqlQuery, RowConsumer) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
SqlQuery find each with consumer.
- findEachRow(SpiSqlQuery, RowConsumer) - Method in class io.ebeaninternal.server.core.DefaultServer
- findEachWhile(SpiQuery<T>, Predicate<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findEachWhile(SpiQuery<T>, Predicate<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findEachWhile(SpiSqlQuery, Predicate<SqlRow>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findEachWhile(SpiSqlQuery, Predicate<SqlRow>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findEachWhile(DtoQueryRequest<T>, Predicate<T>) - Method in class io.ebeaninternal.server.query.DtoQueryEngine
- findEachWhile(Predicate<SqlRow>) - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
- findEachWhile(Predicate<SqlRow>) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- findEachWhile(Predicate<T>) - Method in class io.ebeaninternal.server.core.DtoQueryRequest
- findEachWhile(Predicate<T>) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- findEachWhile(Predicate<T>) - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute the find returning a QueryIterator and visitor pattern.
- findEachWhile(Predicate<T>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findEachWhile(Predicate<T>) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- findEachWhile(Predicate<T>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- finder() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return a bean specific finder if one has been set.
- findFutureCount() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findFutureCount() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- findFutureCount() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findFutureCount(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findFutureCount(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findFutureIds() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findFutureIds() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- findFutureIds() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findFutureIds(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findFutureIds(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findFutureList() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findFutureList() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- findFutureList() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findFutureList(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findFutureList(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findId() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- findId() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute the query as findById.
- findId(OrmQueryRequest<T>) - Method in interface io.ebeaninternal.server.core.OrmQueryEngine
-
Execute the 'find by id' query returning a single bean.
- findId(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.DefaultOrmQueryEngine
-
Find a single bean using its unique id.
- findIds() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- findIds() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute the find ids query.
- findIds() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findIds() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findIds(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findIds(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findIds(OrmQueryRequest<?>) - Method in interface io.ebeaninternal.server.core.OrmQueryEngine
-
Execute the find id's query.
- findIds(OrmQueryRequest<?>) - Method in class io.ebeaninternal.server.query.CQueryEngine
-
Build and execute the find Id's query.
- findIds(OrmQueryRequest<?>) - Method in class io.ebeaninternal.server.query.DefaultOrmQueryEngine
- findIdsByParentId(Object, Transaction, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Find child beans of the parent
id. - findIdsByParentId(Object, Transaction, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Find the Id's of detail beans given a parent Id
- findIdsByParentId(Object, Transaction, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- findIdsByParentId(Object, Transaction, boolean, Set<Object>) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Find the Id's of detail beans given a parent Id and optionally exclude detail IDs
- findIdsByParentIdList(List<Object>, Transaction, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Find child beans of the parent ids in
idList. - findIdsByParentIdList(List<Object>, Transaction, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Find the Id's of detail beans given a list of parent Id's.
- findIdsByParentIdList(List<Object>, Transaction, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- findIdsWithCopy(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Execute the findId's query but without copying the query.
- findIdsWithCopy(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findIterate() - Method in class io.ebeaninternal.server.core.DtoQueryRequest
- findIterate() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- findIterate() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute the find returning a QueryIterator.
- findIterate() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findIterate() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- findIterate() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findIterate(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findIterate(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findIterate(DtoQueryRequest<T>) - Method in class io.ebeaninternal.server.query.DtoQueryEngine
- findIterate(OrmQueryRequest<T>) - Method in interface io.ebeaninternal.server.core.OrmQueryEngine
-
Execute the query using a QueryIterator.
- findIterate(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.CQueryEngine
-
Read many beans using an iterator (except you need to close() the iterator when you have finished).
- findIterate(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.DefaultOrmQueryEngine
- findJoinToTable(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- findList() - Method in class io.ebeaninternal.server.core.DtoQueryRequest
- findList() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- findList() - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
- findList() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute the query as findList.
- findList() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findList() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- findList() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- findList() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findList() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- findList(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findList(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findList(SpiSqlQuery) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findList(SpiSqlQuery) - Method in class io.ebeaninternal.server.core.DefaultServer
- findList(DtoQueryRequest<T>) - Method in class io.ebeaninternal.server.query.DtoQueryEngine
- findList(RelationalQueryRequest, RowReader<T>) - Method in interface io.ebeaninternal.server.core.RelationalQueryEngine
-
Find a list of beans using relational query.
- findList(RelationalQueryRequest, RowReader<T>) - Method in class io.ebeaninternal.server.query.DefaultRelationalQueryEngine
- findListMapper(SpiSqlQuery, RowMapper<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
SqlQuery find list with mapper.
- findListMapper(SpiSqlQuery, RowMapper<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findMany(OrmQueryRequest<T>) - Method in interface io.ebeaninternal.server.core.OrmQueryEngine
-
Execute the findList, findSet, findMap query returning an appropriate BeanCollection.
- findMany(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.DefaultOrmQueryEngine
- findMap() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- findMap() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute the query as findMap.
- findMap() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findMap() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- findMap() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findMap(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findMap(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findMatchImport(String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Find and return a matching imported id property.
- findMatchImport(String) - Method in interface io.ebeaninternal.server.deploy.id.ImportedId
-
Used to derive a missing concatenated key from multiple imported keys.
- findMatchImport(String) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdEmbedded
-
Not supported for embedded id.
- findMatchImport(String) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- findNative(Class<T>, String) - Method in class io.ebeaninternal.server.core.DefaultServer
- findOne() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findOne() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- findOne() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- findOne() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findOne() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- findOne(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findOne(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findOne(SpiSqlQuery) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findOne(SpiSqlQuery) - Method in class io.ebeaninternal.server.core.DefaultServer
- findOne(RelationalQueryRequest, RowMapper<T>) - Method in interface io.ebeaninternal.server.core.RelationalQueryEngine
-
Find one via mapper.
- findOne(RelationalQueryRequest, RowMapper<T>) - Method in class io.ebeaninternal.server.query.DefaultRelationalQueryEngine
- findOneMapper(SpiSqlQuery, RowMapper<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
SqlQuery find one with mapper.
- findOneMapper(SpiSqlQuery, RowMapper<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findOneOrEmpty() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findOneOrEmpty() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- findOneOrEmpty() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- findOneOrEmpty() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findOneOrEmpty() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- findOneOrEmpty(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findOneOrEmpty(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findPagedList() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findPagedList() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findPagedList(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findPagedList(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findProperty(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Find a BeanProperty including searching the inheritance hierarchy.
- findProperty(String) - Method in interface io.ebeaninternal.server.query.STreeType
-
Find a known property.
- findPropertyFromPath(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the bean property traversing the object graph and taking into account inheritance.
- findPropertyFromPath(String) - Method in interface io.ebeaninternal.server.query.STreeType
-
Return the bean property traversing the object graph and taking into account inheritance.
- findPropertyWithDynamic(String, String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return a property that is part of the SQL tree.
- findPropertyWithDynamic(String, String) - Method in interface io.ebeaninternal.server.query.STreeType
-
Find and return property allowing for dynamic formula properties.
- findResultSet() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- findResultSet() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute returning the ResultSet.
- findResultSet(SpiQuery<?>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Execute the underlying ORM query returning as a JDBC ResultSet to map to DTO beans.
- findResultSet(SpiQuery<?>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findResultSet(OrmQueryRequest<T>) - Method in interface io.ebeaninternal.server.core.OrmQueryEngine
-
Execute the ORM query returning the JDBC ResultSet (for DTO query processing).
- findResultSet(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.CQueryEngine
-
Execute returning the ResultSet and PreparedStatement for processing (by DTO query usually).
- findResultSet(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.DefaultOrmQueryEngine
- findSet() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- findSet() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute the query as findSet.
- findSet() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findSet() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- findSet() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findSet(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findSet(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findSingleAttribute() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findSingleAttribute(SpiSqlQuery, Class<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
SqlQuery find single attribute.
- findSingleAttribute(SpiSqlQuery, Class<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findSingleAttribute(RelationalQueryRequest, Class<T>) - Method in interface io.ebeaninternal.server.core.RelationalQueryEngine
-
Find single attribute.
- findSingleAttribute(RelationalQueryRequest, Class<T>) - Method in class io.ebeaninternal.server.query.DefaultRelationalQueryEngine
- findSingleAttribute(Class<T>) - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
- findSingleAttributeCollection(A) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- findSingleAttributeCollection(A) - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute the findSingleAttributeCollection query.
- findSingleAttributeCollection(OrmQueryRequest<?>, A) - Method in interface io.ebeaninternal.server.core.OrmQueryEngine
-
Execute the findSingleAttributeCollection query.
- findSingleAttributeCollection(OrmQueryRequest<?>, A) - Method in class io.ebeaninternal.server.query.DefaultOrmQueryEngine
- findSingleAttributeEach(SpiSqlQuery, Class<T>, Consumer<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
SqlQuery find single attribute streaming the result to a consumer.
- findSingleAttributeEach(SpiSqlQuery, Class<T>, Consumer<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findSingleAttributeEach(RelationalQueryRequest, Class<T>, Consumer<T>) - Method in interface io.ebeaninternal.server.core.RelationalQueryEngine
-
Find single attribute streaming the result to a consumer.
- findSingleAttributeEach(RelationalQueryRequest, Class<T>, Consumer<T>) - Method in class io.ebeaninternal.server.query.DefaultRelationalQueryEngine
- findSingleAttributeEach(Class<T>, Consumer<T>) - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
- findSingleAttributeList() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findSingleAttributeList() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findSingleAttributeList(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findSingleAttributeList(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findSingleAttributeList(SpiSqlQuery, Class<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
SqlQuery find single attribute list.
- findSingleAttributeList(SpiSqlQuery, Class<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findSingleAttributeList(OrmQueryRequest<?>, A) - Method in class io.ebeaninternal.server.query.CQueryEngine
-
Build and execute the findSingleAttributeList query.
- findSingleAttributeList(RelationalQueryRequest, Class<T>) - Method in interface io.ebeaninternal.server.core.RelationalQueryEngine
-
Find single attribute list.
- findSingleAttributeList(RelationalQueryRequest, Class<T>) - Method in class io.ebeaninternal.server.query.DefaultRelationalQueryEngine
- findSingleAttributeList(Class<T>) - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
- findSingleAttributeOrEmpty() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findSingleAttributeSet() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findSingleAttributeSet() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findSingleAttributeSet(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findSingleAttributeSet(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findStream() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- findStream() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findStream(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findStream(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findVersions() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- findVersions() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute the finVersions() query.
- findVersions() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findVersions() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findVersions(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- findVersions(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- findVersions(OrmQueryRequest<T>) - Method in interface io.ebeaninternal.server.core.OrmQueryEngine
-
Execute the findVersions query.
- findVersions(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.CQueryEngine
-
Execute the find versions query returning version beans.
- findVersions(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.DefaultOrmQueryEngine
- findVersionsBetween(Timestamp, Timestamp) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- findVersionsBetween(Timestamp, Timestamp) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- findWordLower(String) - Method in class io.ebeaninternal.server.querydefn.SimpleTextParser
- findWordLower(String, int) - Method in class io.ebeaninternal.server.querydefn.SimpleTextParser
- firstProp() - Method in class io.ebeaninternal.server.deploy.DeployPropertyParser
-
Return the first property found by the parser.
- flagInsert() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Set the request flags indicating this is an insert.
- flags() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the flags set on this persist request.
- Flags - Class in io.ebeaninternal.server.persist
-
Flags used in persistence.
- Flags() - Constructor for class io.ebeaninternal.server.persist.Flags
- flagUpdate() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Unset the request insert flag indicating this is an update.
- flush() - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
Flush the buffer.
- flush() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- flush() - Method in class io.ebeaninternal.server.core.DefaultServer
- flush() - Method in class io.ebeaninternal.server.json.WriteJson
- flush() - Method in class io.ebeaninternal.server.persist.BatchControl
-
Flush without resetting the depth info.
- flush() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Flush any queued persist requests.
- flush() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Flush any queued persist requests.
- flush() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Flush any queued persist requests.
- flush() - Method in interface io.ebeanservice.docstore.api.DocStoreQueryUpdate
-
Flush the changes to the document store.
- flush() - Method in interface io.ebeanservice.docstore.api.DocStoreTransaction
-
Flush all changes to the document store.
- flush(boolean, boolean) - Method in class io.ebeaninternal.server.persist.BatchedPstmtHolder
-
Execute all batched PreparedStatements.
- flushBatchOnCascade() - Method in interface io.ebeaninternal.api.SpiTransaction
-
If batch mode was turned on for the request then flush the batch.
- flushBatchOnCascade() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- flushBatchOnCascade() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
If using batch on cascade flush if required.
- flushBatchOnCascade() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Flush after completing persist cascade.
- flushBatchOnCascade() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Flush after completing persist cascade.
- flushBatchOnCascade() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Flush after completing persist cascade.
- flushBatchOnCollection() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Flush batch if we escalated batch mode on saving or deleting a collection.
- flushBatchOnCollection() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- flushBatchOnCollection() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- flushBatchOnCollection() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- flushBatchOnCollection() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- flushBatchOnRollback() - Method in interface io.ebeaninternal.api.SpiTransaction
-
If batch was on then effectively clear the batch such that we can handle exceptions and continue.
- flushBatchOnRollback() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- flushBatchOnRollback() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- flushBatchOnRollback() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- flushBatchOnRollback() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- flushExtraJoins() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Add extra joins *IF* required to support inheritance discriminator in projection.
- flushJdbcBatchOnQuery() - Method in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
- flushOnCommit() - Method in class io.ebeaninternal.server.persist.BatchControl
- flushReset() - Method in class io.ebeaninternal.server.persist.BatchControl
-
Flush with a reset of the depth info.
- flushTransparent(SpiPersistenceContext, SpiTransaction) - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Experimental - find dirty beans in the persistence context and persist them.
- foreignKey() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return the extra configuration for the foreign key.
- forFetchGroup(Query<P>) - Static method in class io.ebeaninternal.server.expression.DefaultExpressionList
- forJson(JsonParser) - Method in interface io.ebeaninternal.api.json.SpiJsonReader
- forJson(JsonParser) - Method in class io.ebeaninternal.server.json.DJsonBeanReader
- forJson(JsonParser) - Method in class io.ebeaninternal.server.json.ReadJson
-
Return a new instance of ReadJson using the existing context but with a new JsonParser.
- format(Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the value in String format (for bean cache key).
- format(Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- format(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- formatValue(byte[]) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesBase
- formatValue(byte[]) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- formatValue(B) - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- formatValue(Boolean) - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.BooleanBase
- formatValue(String) - Method in class io.ebeaninternal.server.type.ScalarTypeString
- formatValue(UUID) - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- formatValue(T) - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- formulaJoinProperties(String) - Method in class io.ebeaninternal.api.ManyWhereJoins
-
Return the formula properties to build the select clause for a findCount query.
- forSort() - Method in class io.ebeaninternal.server.cache.DefaultServerCache.CacheEntry
-
Store a copy of lastAccessTime used for sorting.
- forUpdate() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- forUpdate() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- forUpdateNoWait() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- forUpdateNoWait() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- forUpdateSkipLocked() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- forUpdateSkipLocked() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- forwardOnlyFetchSize() - Method in interface io.ebeaninternal.server.core.OrmQueryEngine
- forwardOnlyFetchSize() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- forwardOnlyFetchSize() - Method in class io.ebeaninternal.server.query.CQueryEngine
- forwardOnlyFetchSize() - Method in class io.ebeaninternal.server.query.DefaultOrmQueryEngine
- from(DatabasePlatform) - Static method in class io.ebeaninternal.server.expression.platform.DbExpressionHandlerFactory
-
Create and return the appropriate platform specific handing of expressions.
- fullName() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Returns a description of the request.
- fullName() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the bean class name this descriptor is used for.
- fullName() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the full name of this property.
- fullName() - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- fullName() - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Return the full property name (for error messages).
- fullPath() - Method in interface io.ebeaninternal.api.LoadBeanBuffer
- fullPath() - Method in interface io.ebeaninternal.api.LoadManyBuffer
- futureFetchAudit() - Method in interface io.ebeaninternal.api.SpiQuery
-
Read the readEvent for future queries (null otherwise).
- futureFetchAudit() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- futureTask() - Method in class io.ebeaninternal.server.query.QueryFutureIds
- futureTask() - Method in class io.ebeaninternal.server.query.QueryFutureList
- futureTask() - Method in class io.ebeaninternal.server.query.QueryFutureRowCount
G
- gcCount - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- ge(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- ge(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- ge(String, Object) - Method in class io.ebeaninternal.server.el.ElFilter
- ge(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Greater Than or Equal to - property greater than or equal to the given value.
- ge(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- geIfPresent(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- gen() - Method in class io.ebeaninternal.server.json.WriteJson
- generatedProperty() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the GeneratedValue.
- generatedSql() - Method in class io.ebeaninternal.server.query.CQuery
-
Return the generated sql.
- generator(SpiEbeanServer) - Method in interface io.ebeaninternal.api.SpiDdlGeneratorProvider
-
Provide the DDL generator.
- geOrNull(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- geOrNull(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- geoTypeBinder() - Method in class io.ebeaninternal.server.type.DefaultTypeManager
- geoTypeBinder() - Method in interface io.ebeaninternal.server.type.TypeManager
-
Return the Geometry type binder if provided.
- GeoTypeBinder - Interface in io.ebeaninternal.server.type
-
Binder for Geometry types.
- GeoTypeProvider - Interface in io.ebeaninternal.api
-
Provider of Geometry type binder support.
- geSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- geSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- get() - Method in class io.ebeaninternal.server.query.QueryFutureIds
- get() - Method in class io.ebeaninternal.server.query.QueryFutureList
- get() - Method in class io.ebeaninternal.server.query.QueryFutureRowCount
- get(int) - Method in interface io.ebeaninternal.api.LoadManyBuffer
-
Get the
ith element from buffer. - get(int) - Method in class io.ebeaninternal.json.ModifyAwareList
- get(long, TimeUnit) - Method in class io.ebeaninternal.server.query.QueryFutureIds
- get(long, TimeUnit) - Method in class io.ebeaninternal.server.query.QueryFutureList
- get(long, TimeUnit) - Method in class io.ebeaninternal.server.query.QueryFutureRowCount
- get(Class<?>, Object) - Method in class io.ebeaninternal.server.transaction.DefaultPersistenceContext
-
Return an object given its type and unique id.
- get(Object) - Method in class io.ebeaninternal.json.ModifyAwareMap
- get(Object) - Method in class io.ebeaninternal.server.cache.DefaultServerCache
-
Return a value from the cache.
- get(Object) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- getActualDetails(Object) - Static method in class io.ebeaninternal.server.deploy.BeanCollectionUtil
-
Return the details (map values) of the collection or map taking care to avoid unnecessary fetching of the data.
- getActualEntries(Object) - Static method in class io.ebeaninternal.server.deploy.BeanCollectionUtil
-
Return the details (map entry set) of the collection or map taking care to avoid unnecessary fetching of the data.
- getAggregates() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getAlias(String) - Method in interface io.ebeaninternal.api.SpiQuery
-
Return root table alias with default option.
- getAlias(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getArray() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getAsOf() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the asOf Timestamp which the query should run as.
- getAsOf() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getAsOfBindCount() - Method in class io.ebeaninternal.server.persist.Binder
-
Return the bind count per predicate for 'As Of' query predicates.
- getAsOfTableCount() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the table alias used for the base table.
- getAsOfTableCount() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getAttributeConverters() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
-
Return the list of AttributeConverters found.
- getBackgroundExecutor() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- getBaseScalar() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
-
Return the base scalar properties (excludes Id and secondary table properties).
- getBaseTable() - Method in class io.ebeaninternal.server.deploy.BeanTable
-
Return the base table for this BeanTable.
- getBaseTable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the base table.
- getBaseTable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanTable
-
Return the base table for this BeanTable.
- getBaseTableAsOf() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the base table with as of suffix.
- getBaseTableFull() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the base table with full structure.
- getBaseTableVersionsBetween() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the base table with versions between suffix.
- getBatchGetGeneratedKeys() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the getGeneratedKeys setting for this transaction.
- getBatchGetGeneratedKeys() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- getBatchGetGeneratedKeys() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- getBatchGetGeneratedKeys() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- getBatchGetGeneratedKeys() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- getBatchSize() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the batchSize specifically set for this transaction or 0.
- getBatchSize() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- getBatchSize() - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
- getBatchSize() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Return the batchSize specifically set for this transaction or 0.
- getBatchSize() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Return the batchSize specifically set for this transaction or 0.
- getBatchSize() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Return the batchSize specifically set for this transaction or 0.
- getBeanCache(Class<?>) - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
-
Return the bean cache for a given bean type.
- getBeanCache(Class<?>) - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Return the cache for beans of a particular type.
- getBeanCollectionAdd(Object, String) - Method in interface io.ebeaninternal.server.deploy.BeanCollectionHelp
-
Return the mechanism to add beans to the underlying collection.
- getBeanCollectionAdd(Object, String) - Method in class io.ebeaninternal.server.deploy.BeanListHelp
- getBeanCollectionAdd(Object, String) - Method in class io.ebeaninternal.server.deploy.BeanMapHelp
- getBeanCollectionAdd(Object, String) - Method in class io.ebeaninternal.server.deploy.BeanSetHelp
- getBeanDefault() - Method in class io.ebeaninternal.server.cache.CacheManagerOptions
- getBeanDescriptor() - Method in class io.ebeaninternal.server.deploy.BeanManager
-
Return the BeanDescriptor.
- getBeanDescriptor() - Method in class io.ebeaninternal.server.transaction.BeanPersistIds
- getBeanFindControllers() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- getBeanFinder() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the beanFinder.
- getBeanPersistControllers() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- getBeanPersister() - Method in class io.ebeaninternal.server.deploy.BeanManager
-
Return the associated BeanPersister.
- getBeanPersistList() - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- getBeanPersistListeners() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- getBeanPostConstructoListeners() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- getBeanPostLoaders() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- getBeanProperty(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Get a BeanProperty by its name.
- getBeanQueryAdapters() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- getBeanTable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
-
Return the BeanTable for this association.
- getBeanType() - Method in class io.ebeaninternal.server.deploy.BeanTable
-
Return the class for this beanTable.
- getBeanType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the class type this BeanDescriptor describes.
- getBeanType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanTable
-
Return the class for this beanTable.
- getBeanType() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getBigDecimal() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getBigDecimal(String) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- getBinaryBytes() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getBinaryStream() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getBindCount() - Method in class io.ebeaninternal.server.querydefn.OrmUpdateProperties.Value
- getBinder() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- getBindLog() - Method in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
-
Return the bindLog for this request.
- getBindParams() - Method in interface io.ebeaninternal.api.SpiSqlBinding
-
Return the named or positioned parameters.
- getBindParams() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- getBindParams() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- getBoolean() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getBoolean(String) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- getBootupClasses() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- getBufferFetchSizeHint() - Method in interface io.ebeaninternal.api.SpiSqlBinding
-
Return the hint for Statement.setFetchSize().
- getBufferFetchSizeHint() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- getBufferFetchSizeHint() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- getByte() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getBytes() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getCache() - Method in class io.ebeaninternal.server.deploy.IdentityMode
- getCache() - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- getCacheDataValue(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the value for this property which we hold in the L2 cache entry.
- getCacheDataValue(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- getCacheDataValue(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- getCacheDataValueOrig(EntityBeanIntercept) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the bean cache value for this property using original values.
- getCacheDataValueOrig(EntityBeanIntercept) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Return the bean cache value for this property using original values.
- getCacheEntry(Object) - Method in class io.ebeaninternal.server.cache.DefaultServerCache
-
Get the cache entry - override for query cache to validate dependent tables.
- getCacheEntry(Object) - Method in class io.ebeaninternal.server.cache.DefaultServerQueryCache
- getCacheFactory() - Method in class io.ebeaninternal.server.cache.CacheManagerOptions
- getCacheManager() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- getCacheOptions() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the cache options.
- getCascadeInfo() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
-
Get the persist info.
- getCause() - Method in exception class io.ebeaninternal.server.persist.BatchedSqlException
- getChangeLogFilter() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getChangeLogListener() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- getChangeLogPrepare() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- getChangeLogRegister() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- getChildren() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return the children.
- getChunk(String, boolean) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
- getClearCaches() - Method in class io.ebeaninternal.server.cache.RemoteCacheEvent
- getClusterManager() - Method in class io.ebeaninternal.server.cache.CacheManagerOptions
- getCollectionIdsCache(Class<?>, String) - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
- getCollectionIdsCache(Class<?>, String) - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Return the cache for associated many properties of a bean type.
- getCollectionType() - Method in enum io.ebeaninternal.server.deploy.ManyType
-
Returns List.class or Set.class and null for Map.
- getColumnDefn() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return the explicit column definition.
- getColumnLength() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return the length of the discriminator column.
- getColumnMapping() - Method in class io.ebeaninternal.server.rawsql.DRawSql
-
Return the column mapping for the SQL columns to bean properties.
- getColumnMapping() - Method in interface io.ebeaninternal.server.rawsql.SpiRawSql
- getColumnPrefix() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
- getColumns() - Method in class io.ebeaninternal.server.deploy.IndexDefinition
-
Return the columns that make up this unique constraint.
- getColumns() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping
-
Return an iterator of the Columns.
- getConcurrencyMode() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the concurrency mode used for beans of this type.
- getConfig() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- getCreateTime() - Method in class io.ebeaninternal.server.cache.DefaultServerCache.CacheEntry
-
Return the time the entry was created.
- getCurrentTenantProvider() - Method in class io.ebeaninternal.server.cache.CacheManagerOptions
- getCurrentTransaction() - Method in class io.ebeaninternal.server.transaction.JtaTransactionManager
-
Looks for a current JTA managed transaction and wraps/returns that as an Ebean transaction.
- getData() - Method in class io.ebeaninternal.server.cache.CachedBeanData
-
Return all the property data.
- getData() - Method in class io.ebeaninternal.server.transaction.TransactionProfile
-
Return the profiling data in encoded form.
- getData(String) - Method in class io.ebeaninternal.server.cache.CachedBeanData
-
Return the value for a given property name.
- getDatabasePlatform() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- getDataTimeZone() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- getDate() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getDate(String) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- getDbBind() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the DB Bind parameter.
- getDbCheckConstraintValues() - Method in interface io.ebeaninternal.server.type.ScalarTypeEnum
-
Return the IN values for DB constraint construction.
- getDbColumn() - Method in interface io.ebeaninternal.server.deploy.id.ImportedId
-
For scalar id return the related single db column.
- getDbColumn() - Method in class io.ebeaninternal.server.deploy.id.ImportedIdEmbedded
- getDbColumn() - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- getDbColumn() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
The database column name this is mapped to.
- getDbColumn() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
- getDbColumn() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping.Column
-
Return the DB column name including table alias (if it has one).
- getDbColumnDefaultSqlLiteral() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the DB Column default taking into account literal translation.
- getDbColumnDefn() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the DB column definition if defined.
- getDbColumnDefn() - Method in interface io.ebeaninternal.server.type.ScalarTypeArray
-
Return the underlying DB column type.
- getDbColumnKey() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping.Column
-
Return the DB column alias if specified otherwise DB column.
- getDbComment() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getDbComment() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getDbEncryptedType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the DB type for the encrypted property.
- getDbEncryptFunction() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getDbExpressionHandler() - Method in class io.ebeaninternal.server.persist.Binder
-
Return the DB platform specific expression handler (for JSON and ARRAY types).
- getDbFalseLiteral() - Method in interface io.ebeaninternal.server.type.ScalarTypeBool
-
Return the DB literal value for FALSE.
- getDbFalseLiteral() - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.BooleanBase
-
Return the DB literal value for false.
- getDbFalseLiteral() - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.Native
- getDbLength() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the DB column length for character columns.
- getDbMigrationInfos() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getDbOrderBy() - Method in class io.ebeaninternal.server.querydefn.OrmQueryLimitRequest
- getDbPlatform() - Method in class io.ebeaninternal.server.querydefn.OrmQueryLimitRequest
- getDbScale() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the Db scale for numeric columns.
- getDbSql() - Method in class io.ebeaninternal.server.querydefn.OrmQueryLimitRequest
- getDbTrueLiteral() - Method in interface io.ebeaninternal.server.type.ScalarTypeBool
-
Return the DB literal value for TRUE.
- getDbTrueLiteral() - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.BooleanBase
-
Return the DB literal value for true.
- getDbTrueLiteral() - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.Native
- getDbType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the database jdbc data type this is mapped to.
- getDefaultSelectClause() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the defaultSelectClause using FetchType.LAZY and FetchType.EAGER.
- getDefinition() - Method in class io.ebeaninternal.server.deploy.IndexDefinition
-
Return the raw definition of the index if supplied.
- getDependentTables() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
For view based entity return the dependant tables.
- getDeployCreateProperties() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- getDeployEmbedded() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
-
Return the deploy information specifically for the deployment of Embedded beans.
- getDeployInherit() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- getDeployUtil() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- getDesc() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getDiscriminatorColumn() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return the column name of the discriminator.
- getDiscriminatorType() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return the sql type of the discriminator value.
- getDiscriminatorValue() - Method in class io.ebeaninternal.server.deploy.InheritInfo
- getDiscValue() - Method in class io.ebeaninternal.server.cache.CachedBeanData
-
Return the raw discriminator value.
- getDiscValue() - Method in class io.ebeaninternal.server.cache.CachedBeanId
- getDisplayXtoYofZ(String, String) - Method in class io.ebeaninternal.server.query.LimitOffsetPagedList
- getDocIndexName() - Method in interface io.ebeaninternal.api.SpiQuery
-
For doc store query return the document index name to search against.
- getDocIndexName() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getDocPropertyOptions() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getDocStore() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getDocStoreBatchSize() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the batch size to us for ElasticSearch Bulk API calls as a result of this transaction.
- getDocStoreBatchSize() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- getDocStoreBatchSize() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- getDocStoreBatchSize() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- getDocStoreBatchSize() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- getDocStoreDeleteEvent() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the DocStore index behavior for bean deletes.
- getDocStoreDoc() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
- getDocStoreFactory() - Method in class io.ebeaninternal.server.core.InternalConfiguration
-
Return the doc store factory.
- getDocStoreIndexName() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getDocStoreIndexType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getDocStoreInsertEvent() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the DocStore index behavior for bean inserts.
- getDocStorePathProperties() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getDocStoreQueueId() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getDocStoreUpdateEvent() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the DocStore index behavior for bean updates.
- getDouble() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getDouble(String) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- getDraft() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getDraftDirty() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getDraftTable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getElementDescriptor() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
- getElPlaceHolder() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getElPrefix() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getElProp(SpiExpressionBind) - Method in class io.ebeaninternal.server.expression.InExpression
- getElProp(SpiExpressionBind) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- getEmbeddables() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
-
Return the list of Embeddable classes.
- getEmbedded() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getEntities() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
-
Return the list of entity classes.
- getEntityType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getExecutionOrder() - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistController
-
Always returns 0 (not used for this object).
- getExecutionOrder() - Method in class io.ebeaninternal.server.deploy.ChainedBeanQueryAdapter
-
Return 0 as not used by this Chained adapter.
- getExpressionFactory() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- getExpressionFactory() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getExpressionPath(String) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Return the expression path for the given property path.
- getExtraMetrics() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- getExtraWhere() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
-
Return a literal expression that is added to the query that lazy loads the collection.
- getExtraWhere() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
-
Returns the clause of an extra @Where annotation.
- getFetchConfig() - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
- getFetchOrderBy() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Return the order by clause used to order the fetching of the data for this list, set or map.
- getFetchPaths() - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Return the fetch paths for this detail.
- getFetchPreference() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
- getField() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the bean Field associated with this property.
- getFilterMany() - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Return the filterMany expression list (can be null).
- getFirstRow() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the index of the first row to return in the query.
- getFirstRow() - Method in interface io.ebeaninternal.api.SpiSqlBinding
-
Return the first row to fetch.
- getFirstRow() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- getFirstRow() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getFirstRow() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- getFirstRow() - Method in class io.ebeaninternal.server.querydefn.OrmQueryLimitRequest
- getFloat() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getFloat(String) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- getForeignDbColumn() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoinColumn
-
Return the foreign database column name.
- getForeignDbColumn() - Method in class io.ebeaninternal.server.deploy.TableJoinColumn
-
Return the foreign database column name.
- getForeignKey() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
- getForeignKey() - Method in class io.ebeaninternal.server.deploy.TableJoin
-
Return the foreign key options.
- getForeignSqlFormula() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoinColumn
- getForeignSqlFormula() - Method in class io.ebeaninternal.server.deploy.TableJoinColumn
- getForUpdateLockType() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getForUpdateLockWait() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the ForUpdate mode.
- getForUpdateLockWait() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getFromBeanCache() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- getFromBeanCache() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Maybe hit the bean cache returning true if everything was obtained from the cache (that there were no misses).
- getFromQueryCache() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Try to get the query result from the query cache.
- getFromQueryCache() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Try to get the query result from the query cache.
- getFullName() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the bean class name this descriptor is used for.
- getFutureCount() - Method in class io.ebeaninternal.server.query.LimitOffsetPagedList
- getGenerated() - Method in class io.ebeaninternal.server.deploy.IdentityMode
- getGenerated() - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- getGeneratedInsert() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
-
Return the properties set via generated values on insert.
- getGeneratedKey() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- getGeneratedProperty() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the GeneratedValue.
- getGeneratedPropertyFactory() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- getGeneratedSql() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- getGeneratedSql() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getGeneratedSql() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- getGeneratedUpdate() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
-
Return the properties set via generated values on update.
- getGenericType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the generic type for this property.
- getGetter() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getHitCount() - Method in class io.ebeaninternal.server.cache.DefaultServerCache
-
Return the count of get hits.
- getId() - Method in class io.ebeaninternal.server.cache.CachedBeanId
- getId() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getId() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getId(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Helper method to return the unique property.
- getIdBinder() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return the IdBinder for this type.
- getIdColumn() - Method in class io.ebeaninternal.server.deploy.BeanTable
-
Return the primary key DB column.
- getIdentityMode() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getIdEqualTo(String) - Method in interface io.ebeaninternal.api.SpiExpression
-
Return the bind Id value if this is a "equal to" expression for the id property.
- getIdEqualTo(String) - Method in class io.ebeaninternal.server.expression.InExpression
- getIdEqualTo(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- getIdEqualTo(String) - Method in class io.ebeaninternal.server.expression.IdInExpression
- getIdEqualTo(String) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- getIdGenerator() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the actual IdGenerator for this bean type (can be null).
- getIdGenerators() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- getIdList() - Method in class io.ebeaninternal.server.cache.CachedManyIds
- getIdProperty() - Method in class io.ebeaninternal.server.deploy.BeanTable
-
Return the Id properties.
- getIds() - Method in class io.ebeaninternal.server.transaction.BeanPersistIds
- getIdType() - Method in class io.ebeaninternal.server.deploy.IdentityMode
- getIdType() - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- getIncluded() - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Return the property set.
- getIncrement() - Method in class io.ebeaninternal.server.deploy.IdentityMode
- getIncrement() - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- getIndexDefinitions() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the compound unique constraints (can be null).
- getIndexPos() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping.Column
-
Return the index position of this column.
- getIndexPosition(String) - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping
-
Return the index position by bean property name.
- getIndexTablespace() - Method in class io.ebeaninternal.server.deploy.TablespaceMeta
- getInExpression(boolean, List<Object>) - Method in class io.ebeaninternal.server.persist.Binder
-
Return the SQL in clause taking into account Multi-value support.
- getInheritInfo() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Returns the Inheritance mapping information.
- getInheritInfo() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
- getInheritType() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getInstance(File, String) - Static method in class io.ebeaninternal.server.idgen.UuidV1IdGenerator
-
Returns an instance for given file.
- getInstance(String, String) - Static method in class io.ebeaninternal.server.idgen.UuidV1IdGenerator
-
Returns an instance for given file.
- getInt() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getInteger(String) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- getIntersectionDraftTable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Return a draft table for intersection between 2 @Draftable entities.
- getIntersectionJoin() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
ManyToMany only, join from local table to intersection table.
- getInverseJoin() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
- getKey() - Method in class io.ebeaninternal.server.cache.DefaultServerCache.CacheEntry
-
Return the entry key.
- getKey() - Method in class io.ebeaninternal.server.rawsql.DRawSql
-
Return the key;
- getKey() - Method in interface io.ebeaninternal.server.rawsql.SpiRawSql
- getLabel() - Method in interface io.ebeaninternal.api.SpiSqlBinding
-
Return the label (to collect metrics on when set).
- getLabel() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- getLabel() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- getLabel() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- getLabel() - Method in class io.ebeaninternal.server.transaction.TransactionProfile
-
Return the transaction location label.
- getLang() - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- getLastAccessTime() - Method in class io.ebeaninternal.server.cache.DefaultServerCache.CacheEntry
-
Return the time the entry was last accessed.
- getList() - Method in class io.ebeaninternal.server.query.LimitOffsetPagedList
- getLobTablespace() - Method in class io.ebeaninternal.server.deploy.TablespaceMeta
- getLocal() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getLocalDbColumn() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoinColumn
-
Return the local database column name.
- getLocalDbColumn() - Method in class io.ebeaninternal.server.deploy.TableJoinColumn
-
Return the local database column name.
- getLocalSqlFormula() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoinColumn
- getLocalSqlFormula() - Method in class io.ebeaninternal.server.deploy.TableJoinColumn
- getLogicalType() - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.BooleanBase
- getLogicalType() - Method in interface io.ebeaninternal.server.type.ScalarTypeLogicalType
-
Return the DB agnostic logical type.
- getLogicalType() - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- getLong() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getLong(String) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- getMany() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getManyDelete() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getManySave() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getManyToMany() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getManyType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Return the many type.
- getMap() - Method in class io.ebeaninternal.server.cache.DefaultServerCacheConfig
- getMapKey() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Return the default mapKey when returning a Map.
- getMapKeyType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Return the type of the map key (valid only when this property is a Map).
- getMapKeyType(Type) - Static method in class io.ebeaninternal.server.type.TypeReflectHelper
-
Return the type of the map key.
- getMappedBy() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
-
Return the mappedBy deployment attribute.
- getMapping() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping
-
Return the mapping by DB column.
- getMaxIdleSecs() - Method in class io.ebeaninternal.server.cache.DefaultServerCacheConfig
- getMaxRows() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the maximum number of rows to return in the query.
- getMaxRows() - Method in interface io.ebeaninternal.api.SpiSqlBinding
-
Return the maximum number of rows to fetch.
- getMaxRows() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- getMaxRows() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getMaxRows() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- getMaxRows() - Method in class io.ebeaninternal.server.querydefn.OrmQueryLimitRequest
- getMaxSecsToLive() - Method in class io.ebeaninternal.server.cache.DefaultServerCacheConfig
- getMaxSize() - Method in class io.ebeaninternal.server.cache.DefaultServerCacheConfig
- getMetaAnnotation(Class<A>) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getMetaAnnotationFormula(Platform) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getMetaAnnotations(Class<A>) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getMetaAnnotationWhere(Platform) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getMissCount() - Method in class io.ebeaninternal.server.cache.DefaultServerCache
-
Return the count of get misses.
- getMode() - Method in class io.ebeaninternal.server.deploy.PartitionMeta
- getModifyListenMode() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Return the mode for listening to changes to the List Set or Map.
- getMultiValueBind() - Method in class io.ebeaninternal.server.core.InternalConfiguration
-
Return the platform specific MultiValue bind support.
- getMutable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getMutationDetection() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getName() - Method in class io.ebeaninternal.server.cache.DefaultServerCache
-
Return the name of the cache.
- getName() - Method in class io.ebeaninternal.server.cache.DefaultServerCacheConfig
- getName() - Method in class io.ebeaninternal.server.deploy.IndexDefinition
-
Return the index name (can be null).
- getName() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the bean short name.
- getName() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the name of the property.
- getName() - Method in class io.ebeaninternal.server.deploy.meta.DeployOrderColumn
- getName() - Method in class io.ebeaninternal.server.grammer.NamedParameter
- getName() - Method in class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
-
Returns "uuid".
- getName() - Method in class io.ebeaninternal.server.idgen.UuidV4IdGenerator
-
Returns "uuid".
- getName() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- getName() - Method in class io.ebeaninternal.server.querydefn.NaturalKeyBindParam
- getNamedQuery() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the named ORM queries.
- getNamedRawSql() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the named RawSql queries.
- getNaturalKey() - Method in class io.ebeaninternal.server.core.CacheOptions
-
Return the natural key property name.
- getNaturalKeyCache(Class<?>) - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
- getNaturalKeyCache(Class<?>) - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Return the cache for mapping natural keys to id values.
- getNodeIdBytes() - Method in class io.ebeaninternal.server.idgen.UuidV1IdGenerator
- getNodeIdBytes() - Method in class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
-
returns a random 47 bit value according to https://tools.ietf.org/html/rfc4122.html#section-4.5
- getNodeIdentifier() - Method in class io.ebeaninternal.server.idgen.UuidV1IdGenerator
-
Returns the Node-identifier (=MAC address) as string
- getNonMany() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getNonTransients() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getObject() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getObject(Class<T>) - Method in class io.ebeaninternal.server.type.RsetDataReader
- getOnDelete() - Method in class io.ebeaninternal.server.deploy.PropertyForeignKey
- getOneExportedDelete() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getOneExportedSave() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getOneImported() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getOneImportedDelete() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getOneImportedSave() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getOnes() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getOnUpdate() - Method in class io.ebeaninternal.server.deploy.PropertyForeignKey
- getOrderBy() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the Order By clause or null if there is none defined.
- getOrderBy() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getOrderBy() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.Sql
-
Return the SQL ORDER BY clause.
- getOrderByPrefix() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.Sql
-
Return the 'order by' keywords.
- getOrderColumn() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
- getOrderColumn() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
-
Return the order column property.
- getOriginKey() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the origin key.
- getOriginKey() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getOrmQuery() - Method in class io.ebeaninternal.server.querydefn.OrmQueryLimitRequest
- getOwningType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getPageIndex() - Method in class io.ebeaninternal.server.query.LimitOffsetPagedList
- getPageSize() - Method in class io.ebeaninternal.server.query.LimitOffsetPagedList
- getParams(Class<?>, Class<?>) - Static method in class io.ebeaninternal.server.type.TypeReflectHelper
- getParent() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return the parent node.
- getPartitionMeta() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getPath() - Method in class io.ebeaninternal.server.expression.FilterExprPath
-
Return the path.
- getPath() - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Return the path relative to the root of the graph.
- getPersistController() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the BeanPersistController (could be a chain of them, 1 or null).
- getPersistenceContext() - Method in class io.ebeaninternal.server.json.DJsonBeanReader
- getPersistListener() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the BeanPersistListener (could be a chain of them, 1 or null).
- getPlatform() - Static method in class io.ebeaninternal.api.DbOffline
-
Return the platform to use when creating the next EbeanServer instance.
- getPlatforms() - Method in class io.ebeaninternal.server.deploy.DbMigrationInfo
- getPlatforms() - Method in class io.ebeaninternal.server.deploy.IndexDefinition
-
Return the platforms this index applies to.
- getPlugins() - Method in class io.ebeaninternal.server.core.InternalConfiguration
-
Return the list of plugins we collected during construction.
- getPos() - Method in class io.ebeaninternal.server.querydefn.SimpleTextParser
- getPostAdd() - Method in class io.ebeaninternal.server.deploy.DbMigrationInfo
- getPostAlter() - Method in class io.ebeaninternal.server.deploy.DbMigrationInfo
- getPostConstructListener() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the BeanPostCreate(could be a chain of them, 1 or null).
- getPostLoad() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the BeanPostLoad (could be a chain of them, 1 or null).
- getPreAdd() - Method in class io.ebeaninternal.server.deploy.DbMigrationInfo
- getPreAlter() - Method in class io.ebeaninternal.server.deploy.DbMigrationInfo
- getPreFrom() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.Sql
-
Return the SQL prior to FROM clause.
- getPreHaving() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.Sql
-
Return the SQL prior to HAVING clause.
- getPreparedSql() - Method in class io.ebeaninternal.api.BindParams.OrderedList
- getPreWhere() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.Sql
-
Return the SQL prior to WHERE clause.
- getPrimaryKeyJoin() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getProperties() - Method in class io.ebeaninternal.server.deploy.BeanEmbeddedMeta
-
Return the properties with over ridden mapping information.
- getProperty() - Method in class io.ebeaninternal.server.deploy.PartitionMeta
-
Originally the property name but replaced with the db column.
- getPropertyColumnMap() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanEmbedded
-
Return a map of property names to dbColumns.
- getPropertyIndex() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getPropertyMap() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getPropertyName() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping.Column
-
Return the bean property this column is mapped to.
- getPropertyType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the property type.
- getPropName() - Method in class io.ebeaninternal.server.expression.SimpleExpression
- getQuery() - Method in interface io.ebeaninternal.api.SpiSqlBinding
-
return the query.
- getQuery() - Method in class io.ebeaninternal.server.query.QueryFutureIds
- getQuery() - Method in class io.ebeaninternal.server.query.QueryFutureList
- getQuery() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- getQuery() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- getQueryAdapter() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getQueryCache(Class<?>) - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
-
Return the query cache for a given bean type.
- getQueryCache(Class<?>) - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Return the cache for query results of a particular type of bean.
- getQueryCacheEntryValidate() - Method in class io.ebeaninternal.server.cache.CacheManagerOptions
- getQueryCacheEntryValidate() - Method in class io.ebeaninternal.server.cache.DefaultServerCacheConfig
- getQueryDefault() - Method in class io.ebeaninternal.server.cache.CacheManagerOptions
- getQueryType() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- getRawAggregation() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Get the raw/logical aggregation formula.
- getReadAuditLogger() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- getReadAuditPrepare() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- getRef() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getRegion() - Method in class io.ebeaninternal.server.core.CacheOptions
-
Return the cache region name.
- getRegion(String) - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
- getRegion(String) - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Return the cache region.
- getRemoteCacheEvent() - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- getRemoteTableMod() - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- getResultSet() - Method in class io.ebeaninternal.server.rawsql.DRawSql
-
Return the resultSet if this is a ResultSet based RawSql.
- getResultSet() - Method in interface io.ebeaninternal.server.rawsql.SpiRawSql
- getRoot() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return the root node of the tree.
- getScalarConverters() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
-
Return the list of ScalarConverters found.
- getScalarType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the scalarType.
- getScalarType() - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- getScalarType(Class<?>) - Method in class io.ebeaninternal.server.persist.Binder
- getScalarTypes() - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
-
Return the list of ScalarTypes found.
- getSecondaryTable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the secondary table this property is associated with.
- getSecondaryTableJoin() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getSecondaryTableJoinPrefix() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getSelectLastInsertedId() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the SQL used to return the last inserted Id.
- getSelectLastInsertedIdDraft() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getSelectQueryJoin() - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
- getSequenceName() - Method in class io.ebeaninternal.server.deploy.IdentityMode
- getSequenceName() - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- getServer() - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- getServer(String) - Method in class io.ebeaninternal.server.cluster.ClusterManager
- getServer(String) - Method in interface io.ebeaninternal.server.cluster.ServerLookup
-
Return the EbeanServer instance by name.
- getServerName() - Method in class io.ebeaninternal.server.cache.CacheManagerOptions
- getServerName() - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- getSet() - Method in interface io.ebeaninternal.api.SpiUpdatePlan
-
Return the set of bindable update properties.
- getSetter() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getSharableBean() - Method in class io.ebeaninternal.server.cache.CachedBeanData
-
Return a sharable (immutable read only) bean.
- getShort() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getShortName() - Method in class io.ebeaninternal.server.cache.DefaultServerCache
- getShortName() - Method in class io.ebeaninternal.server.cache.DefaultServerCacheConfig
- getSinglePrimaryKeyColumn() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the Primary Key column assuming it is a single column (not compound).
- getSoftDeleteProperty() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getSortOverride() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getSql() - Method in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
-
Return the SQL executed for this query.
- getSql() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- getSql() - Method in class io.ebeaninternal.server.rawsql.DRawSql
-
Return the Sql either unparsed or in parsed (broken up) form.
- getSql() - Method in interface io.ebeaninternal.server.rawsql.SpiRawSql
- getSqlFormulaJoin() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- getSqlFormulaSelect() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return the formula this property is based on.
- getStart() - Method in class io.ebeaninternal.server.deploy.IdentityMode
- getStart() - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- getStartTime() - Method in class io.ebeaninternal.server.transaction.TransactionProfile
-
Return the transaction start time.
- getStorageEngine() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getString() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getString(String) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- getStringFromStream() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getSummary() - Method in class io.ebeaninternal.server.transaction.TransactionProfile
- getTable() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
-
Return the joined table name.
- getTable() - Method in class io.ebeaninternal.server.deploy.TableJoin
-
Return the joined table name.
- getTableIUDList() - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- getTableJoin() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
-
return the join to use for the bean.
- getTables() - Method in class io.ebeaninternal.server.transaction.RemoteTableMod
- getTablespaceMeta() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getTablespaceName() - Method in class io.ebeaninternal.server.deploy.TablespaceMeta
- getTargetDeploy() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
-
Return the target DeployBeanDescriptor for this associated bean property.
- getTargetType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
-
Return the type of the target.
- getTenant() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getTime() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getTimeComponentTimeZone() - Method in interface io.ebeaninternal.server.core.timezone.DataTimeZone
-
Return the Calendar to use for Timezone information when reading/writing a time component (date only/time only).
- getTimeComponentTimeZone() - Method in class io.ebeaninternal.server.core.timezone.MySqlDataTimeZone
- getTimeout() - Method in interface io.ebeaninternal.api.SpiSqlBinding
-
Return the query timeout.
- getTimeout() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- getTimeout() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- getTimeout() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- getTimestamp() - Method in class io.ebeaninternal.server.transaction.RemoteTableMod
- getTimestamp() - Method in class io.ebeaninternal.server.type.RsetDataReader
- getTimestamp(String) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- getTimeZone() - Method in interface io.ebeaninternal.server.core.timezone.DataTimeZone
-
Return the Calendar to use for Timezone information when reading/writing timestamps.
- getTimeZone() - Method in class io.ebeaninternal.server.core.timezone.MySqlDataTimeZone
- getTimeZone() - Method in class io.ebeaninternal.server.core.timezone.NoDataTimeZone
- getTimeZone() - Method in class io.ebeaninternal.server.core.timezone.OracleDataTimeZone
- getTimeZone() - Method in class io.ebeaninternal.server.core.timezone.SimpleDataTimeZone
- getTotalCount() - Method in class io.ebeaninternal.server.query.LimitOffsetPagedList
- getTotalMicros() - Method in class io.ebeaninternal.server.transaction.TransactionProfile
-
Return the total transaction execution time in micros.
- getTotalPageCount() - Method in class io.ebeaninternal.server.query.LimitOffsetPagedList
- getTransients() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getTrimSize() - Method in class io.ebeaninternal.server.cache.DefaultServerCache
-
Return the size to trim to based on the max size.
- getType() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
return the type.
- getType() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
-
Return the type of join.
- getType() - Method in class io.ebeaninternal.server.persist.MultiValueWrapper
- getType(String) - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
For a discriminator get the inheritance information for this tree.
- getUnchecked() - Method in class io.ebeaninternal.server.query.QueryFutureList
- getUnchecked(long, TimeUnit) - Method in class io.ebeaninternal.server.query.QueryFutureList
- getUnidirectional() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- getUnidirectional() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
-
Return the unidirectional.
- getUnmappedJson() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getUnparsedSql() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.Sql
-
Return the SQL when it is unparsed.
- getUnqualifiedBaseTable() - Method in class io.ebeaninternal.server.deploy.BeanTable
-
Gets the unqualified base table.
- getUserObject(String) - Method in class io.ebeaninternal.api.ScopedTransaction
-
Returns the userObject in the stack, Herew we search the stack and return the first found userObject
- getUserObject(String) - Method in class io.ebeaninternal.api.ScopeTrans
- getUserObject(String) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- getUserObject(String) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- getUserObject(String) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- getUserObject(String) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- getUtilDate(String) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- getUUID(String) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- getValue() - Method in interface io.ebeaninternal.api.SpiNamedParam
- getValue() - Method in class io.ebeaninternal.server.cache.DefaultServerCache.CacheEntry
-
Return the entry value.
- getValue() - Method in class io.ebeaninternal.server.expression.SimpleExpression
- getValue() - Method in class io.ebeaninternal.server.querydefn.NaturalKeyBindParam
- getValue(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the value of the property method.
- getValue(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyIdClass
- getValue(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyOrderColumn
- getValueIntercept(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- getValueIntercept(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyIdClass
- getValueIntercept(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyOrderColumn
- getValues() - Method in class io.ebeaninternal.server.persist.MultiValueWrapper
- getValueType(Type) - Static method in class io.ebeaninternal.server.type.TypeReflectHelper
-
Return the value type of a collection type (list, set, map values).
- getVersion() - Method in class io.ebeaninternal.server.cache.CachedBeanData
-
Return the version value.
- getVersion(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the version value in primitive long form (if exists and set).
- getVersionProperty() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyLists
- getWhenCreated() - Method in class io.ebeaninternal.server.cache.CachedBeanData
-
Return when the cached data was created.
- getWhere() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return the derived where for the discriminator.
- getWithOption(Class<?>, Object) - Method in class io.ebeaninternal.server.transaction.DefaultPersistenceContext
- getWord() - Method in class io.ebeaninternal.server.querydefn.SimpleTextParser
- gt(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- gt(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- gt(String, Object) - Method in class io.ebeaninternal.server.el.ElFilter
- gt(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Greater Than - property greater than the given value.
- gt(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- GT - Enum constant in enum io.ebeaninternal.server.expression.Op
-
Greater than.
- GT_EQ - Enum constant in enum io.ebeaninternal.server.expression.Op
-
Greater than or equal to.
- gtIfPresent(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- gtOrNull(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Greater Than or null - property greater than the given value or null.
- gtOrNull(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- gtSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- gtSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
H
- handleLoadError(String, Exception) - Method in interface io.ebeaninternal.api.SpiQuery
-
Handles load errors.
- handleLoadError(String, Exception) - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Handles a load error on given property.
- handleLoadError(String, Exception) - Method in class io.ebeaninternal.server.query.CQuery
- handleLoadError(String, Exception) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- HARD - Enum constant in enum io.ebeaninternal.server.persist.DeleteMode
-
Hard/permanent delete.
- hasChildren() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return true if this node has children.
- hasCircularImportedId(BeanDescriptor<?>) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- hasDefaultSelectClause() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this bean type has a default select clause that is not simply select all properties.
- hasDirtyProperty(int[]) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if any of the given properties are dirty.
- hasDirtyProperty(Set<String>) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if any of the given property names are dirty.
- hasEmbeddedInvalidation() - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Return true if this bean type as embedded invalidate registered.
- hasEmbeddedInvalidation() - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- hasForeignKey() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- hasForeignKey() - Method in interface io.ebeaninternal.server.query.STreePropertyAssocOne
-
Returns true, if this relation has a foreign key.
- hasForeignKeyConstraint() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return true if foreign key constraint is enabled on this relationship (not disabled).
- hasForeignKeyIndex() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return true if foreign key index is enabled on this relationship (not disabled).
- hash() - Method in interface io.ebeaninternal.api.SpiQueryPlan
-
The hash of the sql.
- hash() - Method in class io.ebeaninternal.server.query.CQueryPlan
- hash(String...) - Static method in class io.ebeaninternal.server.util.Md5
-
Return the MD5 hash of the underlying sql.
- hashCode() - Method in class io.ebeaninternal.api.BindParams.Param
- hashCode() - Method in class io.ebeaninternal.api.BindValuesKey
- hashCode() - Method in class io.ebeaninternal.api.HashQuery
- hashCode() - Method in class io.ebeaninternal.json.ModifyAwareList
- hashCode() - Method in class io.ebeaninternal.json.ModifyAwareMap
- hashCode() - Method in class io.ebeaninternal.json.ModifyAwareSet
- hashCode() - Method in class io.ebeaninternal.server.deploy.TableJoin
- hashCode() - Method in class io.ebeaninternal.server.deploy.TableJoinColumn
- hashCode() - Method in class io.ebeaninternal.server.deploy.TablespaceMeta
- hashCode() - Method in class io.ebeaninternal.server.query.NativeSqlQueryPlanKey
- hashCode() - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
- hashCode() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping.Column
- hashCode() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping
- hashCode() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.Key
- HashQuery - Class in io.ebeaninternal.api
-
A hash key for a query including both the query plan and bind values.
- HashQuery(CQueryPlanKey, BindValuesKey) - Constructor for class io.ebeaninternal.api.HashQuery
-
Create the HashQuery.
- hasId() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- hasId() - Method in interface io.ebeaninternal.server.query.STreeType
-
Return true if the underlying type has an Id property.
- hasId(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return true if the unique id properties are all not null for this bean.
- hasImportedId(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return true if the otherBean has an Id value.
- hasInheritance() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- hasJoinColumns() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
-
Return true if the JoinOnPair have been set.
- hasJoinTable() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return true if this is many to many.
- hasJoinTable() - Method in interface io.ebeaninternal.server.query.STreePropertyAssocMany
-
Return true if the property has a join table.
- hasMaxRowsOrFirstRow() - Method in interface io.ebeaninternal.api.SpiQuery
-
Returns true if either firstRow or maxRows has been set.
- hasMaxRowsOrFirstRow() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- hasNext() - Method in class io.ebeaninternal.json.ModifyAwareIterator
- hasNext() - Method in class io.ebeaninternal.json.ModifyAwareListIterator
- hasNext() - Method in class io.ebeaninternal.server.query.LimitOffsetPagedList
- hasOptions() - Method in class io.ebeaninternal.server.deploy.IdentityMode
- hasOrderColumn() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- hasOrderColumn() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
- hasPrev() - Method in class io.ebeaninternal.server.query.LimitOffsetPagedList
- hasPrevious() - Method in class io.ebeaninternal.json.ModifyAwareListIterator
- hasSelectClause() - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
- hasSelectClause() - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
- hasSingleIdProperty() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return false for IdClass case with multiple @Id properties.
- having() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- having() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- having() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- having(Expression) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- havingExpressions() - Method in interface io.ebeaninternal.api.SpiQuery
-
Can return null if no expressions where added to the having clause.
- havingExpressions() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- HelpScopeTrans - Class in io.ebeaninternal.api
-
Helper object to make AOP generated code simpler.
- HelpScopeTrans() - Constructor for class io.ebeaninternal.api.HelpScopeTrans
- hint() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the SQL hint to include in the query.
- hint() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- hitCount - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- hitRatio() - Method in class io.ebeaninternal.server.cache.DefaultServerCache
- hits() - Method in class io.ebeaninternal.api.BeanCacheResult
-
Return the hits.
I
- icontains(String, String) - Method in class io.ebeaninternal.server.el.ElFilter
- icontains(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Case-insensitive Contains - property like %value%.
- icontains(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- id - Variable in class io.ebeaninternal.server.deploy.BeanProperty
-
Flag to mark this is the id property.
- id() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Returns a String used to identify the transaction.
- id() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- id() - Method in interface io.ebeaninternal.api.SpiTxnLogger
- id() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Return the transaction id.
- id() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Return the transaction id.
- id() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Return the transaction id.
- id(Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- ID_LIST - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
Find the Id's.
- idBinder() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the IdBinder which is helpful for handling the various types of Id.
- idBinder() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
- idBinder() - Method in interface io.ebeaninternal.server.query.STreePropertyAssoc
-
Return the IdBinder of the underlying type.
- idBinder() - Method in interface io.ebeaninternal.server.query.STreeType
-
Return the IdBinder for this type.
- IdBinder - Interface in io.ebeaninternal.server.deploy.id
-
Binds id values to prepared statements.
- IdBinderEmbedded - Class in io.ebeaninternal.server.deploy.id
-
Bind an Id that is an Embedded bean.
- IdBinderEmbedded(boolean, BeanPropertyAssocOne<?>) - Constructor for class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- IdBinderFactory - Class in io.ebeaninternal.server.deploy.id
-
Creates the appropriate IdConvertSet depending on the type of Id property(s).
- IdBinderFactory(boolean, MultiValueBind) - Constructor for class io.ebeaninternal.server.deploy.id.IdBinderFactory
- idBinderIdSql(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the sql for binding an id.
- idBinderInLHSSql() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the sql for binding id's using an IN clause.
- IdBinderSimple - Class in io.ebeaninternal.server.deploy.id
-
Bind an Id where the Id is made of a single property (not embedded).
- IdBinderSimple(BeanProperty, MultiValueBind) - Constructor for class io.ebeaninternal.server.deploy.id.IdBinderSimple
- identityMode() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- IdentityMode - Class in io.ebeaninternal.server.deploy
- IdentityMode(IdType, IdentityGenerated, int, int, int, String) - Constructor for class io.ebeaninternal.server.deploy.IdentityMode
-
Create from migration model CreateTable.
- IdentityMode(DeployIdentityMode) - Constructor for class io.ebeaninternal.server.deploy.IdentityMode
-
Create from deployment.
- idEq(Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Id Equal to - ID property is equal to the value.
- idEq(Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- idEq(Object) - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- idEqualTo(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- idForJson(Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the Id value for the bean with embeddedId beans converted into maps.
- idIn(Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Id IN a list of id values.
- idIn(Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- idIn(Collection<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Id IN a collection of id values.
- idIn(Collection<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- idIn(Collection<?>) - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- IdInCommon - Interface in io.ebeaninternal.server.expression
-
ID IN expression common for cache handling.
- IdInExpression - Class in io.ebeaninternal.server.expression
-
In a collection of ID values.
- IdInExpression(Collection<?>) - Constructor for class io.ebeaninternal.server.expression.IdInExpression
- idInValueExpr(boolean, int) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Return the binding expression (like "?"
- idInValueExpr(boolean, int) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- idInValueExpr(boolean, int) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- idInValueExprDelete(int) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Same as getIdInValueExpr but for delete by id.
- idInValueExprDelete(int) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- idInValueExprDelete(int) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- idleCount - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- idName() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the Id property name or null if no Id property exists.
- idNullOr(String) - Method in interface io.ebeaninternal.api.SpiQueryManyJoin
-
Wrap the filter many expression with a condition allowing lEFT JOIN null matching row.
- idNullOr(String) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- idNullOr(String) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- idNullOr(String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- idNullOr(String) - Method in class io.ebeaninternal.server.el.ElPropertyChain
- idNullOr(String, String) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Wrap the filter many expression with a condition allowing lEFT JOIN null matching row.
- idNullOr(String, String) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- idNullOr(String, String) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- idProperty() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- idProperty() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the BeanProperty that is the Id.
- idReader() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- idReader() - Method in interface io.ebeaninternal.server.query.STreePropertyAssocOne
-
Return the scalar type of the associated id property.
- idSelect() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- idSelect() - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
- idSelect() - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- idSelect() - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- idType() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the identity generation type.
- idValues() - Method in interface io.ebeaninternal.api.CacheIdLookup
-
Return the Id values to lookup against the L2 cache.
- idValues() - Method in class io.ebeaninternal.api.CacheIdLookupMany
-
Return the Id values for the in expression.
- idValues() - Method in class io.ebeaninternal.api.CacheIdLookupSingle
- idValues() - Method in interface io.ebeaninternal.server.expression.IdInCommon
-
Return the ids this expression is looking to fetch.
- idValues() - Method in class io.ebeaninternal.server.expression.IdInExpression
- idValues() - Method in class io.ebeaninternal.server.expression.InExpression
- iendsWith(String, String) - Method in class io.ebeaninternal.server.el.ElFilter
- iendsWith(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Case-insensitive Ends With - property like %value.
- iendsWith(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- ieq(String, String) - Method in class io.ebeaninternal.server.el.ElFilter
- ieq(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Case Insensitive Equal To - property equal to the given value (typically using a lower() function to make it case-insensitive).
- ieq(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- ieqObject(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Create for named parameter use (and without support for equalsWithNullAsNoop).
- iexampleLike(Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Case-insensitive
DefaultExpressionFactory.exampleLike(Object) - iexampleLike(Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- IGNORE_COLUMN - Static variable in interface io.ebeaninternal.server.rawsql.SpiRawSql
-
Special property name assigned to a DB column that should be ignored.
- ilike(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Case-insensitive Like - property like value where the value contains the SQL wild card characters % (percentage) and _ (underscore).
- ilike(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- importedId() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- ImportedId - Interface in io.ebeaninternal.server.deploy.id
-
Represents a imported property.
- importedIdClause() - Method in interface io.ebeaninternal.server.deploy.id.ImportedId
-
Return the set importedId clause.
- importedIdClause() - Method in class io.ebeaninternal.server.deploy.id.ImportedIdEmbedded
- importedIdClause() - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- ImportedIdEmbedded - Class in io.ebeaninternal.server.deploy.id
-
Imported Embedded id.
- ImportedIdEmbedded(BeanPropertyAssoc<?>, BeanPropertyAssocOne<?>, ImportedIdSimple[]) - Constructor for class io.ebeaninternal.server.deploy.id.ImportedIdEmbedded
- ImportedIdSimple - Class in io.ebeaninternal.server.deploy.id
-
Single scalar imported id.
- ImportedIdSimple(BeanPropertyAssoc<?>, String, String, BeanProperty, int) - Constructor for class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- ImportedIdSimple(BeanPropertyAssoc<?>, String, String, BeanProperty, int, boolean, boolean) - Constructor for class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- importedOrphanForRemoval() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- in() - Method in class io.ebeaninternal.api.BinaryReadContext
- in(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
In - using a subQuery.
- in(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- in(String, Object[]) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
In - property has a value in the array of values.
- in(String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- in(String, Collection<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
In - property has a value in the collection of values.
- in(String, Collection<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- in(String, Set<?>) - Method in class io.ebeaninternal.server.el.ElFilter
- includeBeanJoin(String, String) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Add the explicit bean join.
- includeInAll() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- includeInAll(Boolean) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- includeMany(String) - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
Return true if the many property should be included.
- includeMany(String) - Method in class io.ebeaninternal.server.json.WriteJson
- includeManyJoin() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return true if there is a manyJoin that should be included with this query.
- includes() - Method in class io.ebeaninternal.server.deploy.DeployParser
-
Return the join includes.
- includes() - Method in class io.ebeaninternal.server.deploy.DeployPropertyParser
- includes() - Method in class io.ebeaninternal.server.deploy.DeployPropertyParserMap
-
Returns null for raw sql queries.
- includes() - Method in class io.ebeaninternal.server.deploy.DeployUpdateParser
-
Return null as not used for updates.
- includesAggregation(OrmQueryDetail) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if the query detail includes an aggregation property.
- includesPath(String) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Return true if the fetch path is included.
- includesPath(String, String) - Method in class io.ebeanservice.docstore.api.mapping.DocMappingBuilder
-
Return true if the path is included in the document.
- includesProperty(String, String) - Method in class io.ebeanservice.docstore.api.mapping.DocMappingBuilder
-
Return true if the property is included in the document.
- incrementAsOfTableCount() - Method in interface io.ebeaninternal.api.SpiQuery
-
Increment the counter of tables used in 'As Of' query.
- incrementAsOfTableCount() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- incrementAsOfTableCount(int) - Method in interface io.ebeaninternal.api.SpiQuery
-
Increment the counter of tables used in 'As Of' query.
- incrementAsOfTableCount(int) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- incrementLoadOneL2() - Method in class io.ebeaninternal.api.ExtraMetrics
-
Increment counter for lazy loading one bean from L2 cache.
- incrementLoadOneNoLoader() - Method in class io.ebeaninternal.api.ExtraMetrics
-
Increment counter for lazy loading one bean due to no loader.
- incrementLoadOneRef() - Method in class io.ebeaninternal.api.ExtraMetrics
-
Increment counter for lazy loading on reference bean.
- incrementPos(int) - Method in class io.ebeaninternal.server.type.RsetDataReader
- index(Object, T, DocUpdateContext) - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Process an index event which is effectively an insert or update (or put).
- index(Object, T, DocUpdateContext) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- IndexDefinition - Class in io.ebeaninternal.server.deploy
-
Holds multiple column unique constraints defined for an entity.
- IndexDefinition(String[], String, boolean, Platform[], boolean, String) - Constructor for class io.ebeaninternal.server.deploy.IndexDefinition
-
Create from Index annotation.
- IndexDefinition(String, String[]) - Constructor for class io.ebeaninternal.server.deploy.IndexDefinition
-
Create a unique constraint given the column names.
- IndexDefinition(String, String[], boolean) - Constructor for class io.ebeaninternal.server.deploy.IndexDefinition
-
Create from JPA Index.
- indexDefinitions() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the compound unique constraints.
- indexName - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
ElasticSearch index name.
- indexName() - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Return the index name for this bean type.
- indexName() - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- indexOf(Object) - Method in class io.ebeaninternal.json.ModifyAwareList
- indexType - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
ElasticSearch index type.
- indexType() - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Return the index type for this bean type.
- indexType() - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- ine(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Case Insensitive Equal To - property equal to the given value (typically using a lower() function to make it case-insensitive).
- ine(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- ineObject(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Create for named parameter use (and without support for equalsWithNullAsNoop).
- InExpression - Class in io.ebeaninternal.server.expression
- inheritanceChildren() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- inheritanceLoad(SqlBeanLoad, STreeProperty, DbReadContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- inheritanceLoad(SqlBeanLoad, STreeProperty, DbReadContext) - Method in interface io.ebeaninternal.server.query.STreeType
-
Load the property taking into account inheritance.
- inheritanceParent() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- InheritChildVisitor(VisitProperties, BeanPropertyVisitor) - Constructor for class io.ebeaninternal.server.deploy.visitor.VisitProperties.InheritChildVisitor
- inheritInfo() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Returns the Inheritance mapping information.
- inheritInfo() - Method in interface io.ebeaninternal.server.query.STreeType
-
Return the inheritance information for this type.
- InheritInfo - Class in io.ebeaninternal.server.deploy
-
Represents a node in the Inheritance tree.
- InheritInfo(InheritInfo, InheritInfo, DeployInheritInfo) - Constructor for class io.ebeaninternal.server.deploy.InheritInfo
- InheritInfoVisitor - Interface in io.ebeaninternal.server.deploy
-
Used to visit all the InheritInfo in a single inheritance hierarchy.
- initBindParams() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the bind parameters ensuring it is initialised.
- initBindParams() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- initDdlGenerator(SpiEbeanServer) - Method in class io.ebeaninternal.server.core.InternalConfiguration
-
Return the DDL generator.
- initForSoftDelete() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Init generated properties for soft delete (as it's an update).
- initialise() - Method in class io.ebeaninternal.server.core.DefaultServer
-
Run any initialisation required before registering with the ClusterManager.
- initialise() - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Initialise the binder.
- initialise() - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- initialise() - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- initialise(BeanDescriptorInitContext) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Initialise the property before returning to client code.
- initialise(BeanDescriptorInitContext) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Initialise post construction.
- initialise(BeanDescriptorInitContext) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- initialise(BeanDescriptorInitContext) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- initialiseOther(BeanDescriptorInitContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Initialise the exported and imported parts for associated properties.
- initMetaAnnotations(Set<Class<?>>) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- initQueryPlanManager(TransactionManager) - Method in class io.ebeaninternal.server.core.InternalConfiguration
- initTransIfRequired() - Method in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
-
Create a transaction if none currently exists.
- initTransIfRequired() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
This will create a local (readOnly) transaction if no current transaction exists.
- initTransIfRequired() - Method in class io.ebeaninternal.server.core.PersistRequest
- initTransIfRequired() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
This will create a local (readOnly) transaction if no current transaction exists.
- initTransIfRequiredWithBatchCascade() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Init the transaction and also check for batch on cascade escalation.
- INNER - Enum constant in enum io.ebeaninternal.server.query.SqlJoinType
-
It is an inner join.
- inOrEmpty(String, Collection<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
In where null or empty values means that no predicate is added to the query.
- inOrEmpty(String, Collection<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- inPairs(Pairs) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
In - property has a value in the collection of values.
- inPairs(Pairs) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- inRange(String, Object, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Between - property between the two given values.
- inRange(String, Object, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- inRangeWith(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- inRangeWith(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- inRangeWithProperties(String, String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- inRangeWithProperties(String, String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- inScope() - Method in class io.ebeaninternal.server.transaction.DefaultTransactionScopeManager
- inScope() - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Return the current transaction from thread local scope.
- inScope() - Method in class io.ebeaninternal.server.transaction.TransactionScopeManager
-
Return the current Transaction from internal Ebean scope.
- insert - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
Behavior on insert.
- insert(EntityBean, InsertOptions, Transaction) - Method in interface io.ebeaninternal.server.core.Persister
-
Perform an Insert using the given bean.
- insert(EntityBean, InsertOptions, Transaction) - Method in class io.ebeaninternal.server.persist.DefaultPersister
-
Insert this bean.
- insert(Database, boolean) - Method in class io.ebeaninternal.server.deploy.IntersectionTable
-
Return a SqlUpdate for inserting into the intersection table.
- insert(PersistRequestBean<?>) - Method in interface io.ebeaninternal.server.persist.BeanPersister
-
execute the insert bean request.
- insert(Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- insert(Object, InsertOptions) - Method in class io.ebeaninternal.server.core.DefaultServer
- insert(Object, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- insert(Object, InsertOptions, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- insert(Object, PersistRequestBean<T>, DocStoreUpdateContext) - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Process an insert persist request.
- insert(Object, PersistRequestBean<T>, DocStoreUpdateContext) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- INSERT - Enum constant in enum io.ebeaninternal.api.SpiUpdate.OrmUpdateType
- INSERT - Enum constant in enum io.ebeaninternal.server.core.PersistRequest.Type
- INSERT - Static variable in class io.ebeaninternal.server.persist.Flags
-
Indicates the bean is being inserted.
- insertAll(Collection<?>, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- insertAll(Collection<?>, InsertOptions, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- insertAll(Collection<?>) - Method in class io.ebeaninternal.server.core.DefaultServer
- insertAll(Collection<?>, InsertOptions) - Method in class io.ebeaninternal.server.core.DefaultServer
- inserted(Object) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistListener
- insertElementCollection() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- insertOptions() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- INSTANCE - Static variable in class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
- INSTANCE - Static variable in class io.ebeaninternal.server.idgen.UuidV4IdGenerator
- INSTANCE - Static variable in class io.ebeaninternal.server.type.ScalarTypeString
- inSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- inSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- intercept() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the intercept if there is one.
- intern(String) - Static method in class io.ebeaninternal.server.core.InternString
-
Return the shared instance of this string.
- internal - Static variable in class io.ebeaninternal.api.CoreLog
- InternalConfiguration - Class in io.ebeaninternal.server.core
-
Used to extend the DatabaseConfig with additional objects used to configure and construct an Database.
- internalConnection() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the underlying Connection for internal use.
- internalConnection() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- internalConnection() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- internalConnection() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Return the underlying connection for internal use.
- internalConnection() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Return the underlying connection for internal use.
- internalList() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- InternString - Class in io.ebeaninternal.server.core
-
Used to reduce memory consumption of strings used in deployment processing.
- InternString() - Constructor for class io.ebeaninternal.server.core.InternString
- intersectionBind(SqlUpdate, EntityBean, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Bind the two side of a many to many to the given SqlUpdate.
- IntersectionBuilder - Class in io.ebeaninternal.server.deploy
-
Helper to build IntersectionTable.
- IntersectionRow - Class in io.ebeaninternal.server.deploy
- intersectionTable() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return the intersection table helper.
- IntersectionTable - Class in io.ebeaninternal.server.deploy
- intersectionTableJoin() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
ManyToMany only, join from local table to intersection table.
- intersectionTableJoin() - Method in interface io.ebeaninternal.server.query.STreePropertyAssocMany
-
Return the intersection table join.
- inTuples(InTuples) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- inTuples(InTuples) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- invalidateQueryCache(String) - Static method in class io.ebeaninternal.server.core.CacheOptions
- inValue() - Method in class io.ebeaninternal.api.BindParams.Param
-
Return the In value.
- inValue() - Method in interface io.ebeaninternal.api.NaturalKeyEntry
-
Return the inValue (used to remove from IN clause of original query).
- io.ebean.core - module io.ebean.core
- io.ebeaninternal.api - package io.ebeaninternal.api
- io.ebeaninternal.api.json - package io.ebeaninternal.api.json
- io.ebeaninternal.json - package io.ebeaninternal.json
- io.ebeaninternal.server.autotune - package io.ebeaninternal.server.autotune
- io.ebeaninternal.server.cache - package io.ebeaninternal.server.cache
- io.ebeaninternal.server.cluster - package io.ebeaninternal.server.cluster
-
Clustering service for an application.
- io.ebeaninternal.server.core - package io.ebeaninternal.server.core
-
Core implementation objects
- io.ebeaninternal.server.core.bootup - package io.ebeaninternal.server.core.bootup
- io.ebeaninternal.server.core.timezone - package io.ebeaninternal.server.core.timezone
- io.ebeaninternal.server.deploy - package io.ebeaninternal.server.deploy
-
Bean description
- io.ebeaninternal.server.deploy.id - package io.ebeaninternal.server.deploy.id
-
Helpers for Id property conversion
- io.ebeaninternal.server.deploy.meta - package io.ebeaninternal.server.deploy.meta
-
Temporary objects used to collect deployment information
- io.ebeaninternal.server.deploy.visitor - package io.ebeaninternal.server.deploy.visitor
- io.ebeaninternal.server.el - package io.ebeaninternal.server.el
- io.ebeaninternal.server.expression - package io.ebeaninternal.server.expression
-
Expressions for building WHERE clauses.
- io.ebeaninternal.server.expression.platform - package io.ebeaninternal.server.expression.platform
- io.ebeaninternal.server.grammer - package io.ebeaninternal.server.grammer
- io.ebeaninternal.server.idgen - package io.ebeaninternal.server.idgen
-
Id Generation (Sequences, UUIDGen etc)
- io.ebeaninternal.server.json - package io.ebeaninternal.server.json
- io.ebeaninternal.server.persist - package io.ebeaninternal.server.persist
-
Persistence Implementation
- io.ebeaninternal.server.query - package io.ebeaninternal.server.query
- io.ebeaninternal.server.querydefn - package io.ebeaninternal.server.querydefn
- io.ebeaninternal.server.rawsql - package io.ebeaninternal.server.rawsql
- io.ebeaninternal.server.transaction - package io.ebeaninternal.server.transaction
-
Transaction implementation
- io.ebeaninternal.server.type - package io.ebeaninternal.server.type
-
Built in and custom Scalar types support.
- io.ebeaninternal.server.util - package io.ebeaninternal.server.util
-
Server side Utility objects
- io.ebeanservice.docstore.api - package io.ebeanservice.docstore.api
-
The service API for document store integration.
- io.ebeanservice.docstore.api.mapping - package io.ebeanservice.docstore.api.mapping
-
Mapping for document store integration.
- io.ebeanservice.docstore.api.support - package io.ebeanservice.docstore.api.support
-
Support objects for implementing integration.
- isActive() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isActive() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Return true if the transaction is active.
- isActive() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Return true if the transaction is active.
- isActive() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Return true if the transaction is active.
- isAddToUpdate(BeanProperty) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if the property should be included in the update.
- isAggregation() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- isAggregation() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- isAggregation() - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- isAggregation() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isAggregation() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- isAggregation() - Method in interface io.ebeaninternal.server.el.ElPropertyDeploy
-
Return true if this is an aggregation property.
- isAggregation() - Method in class io.ebeaninternal.server.query.SqlTreeProperties
-
Return true if this contains an aggregation property.
- isAggregation() - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Return true if the property is an aggregation.
- isAggregationManyToOne() - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- isAggregationManyToOne() - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Return true if the property is an aggregation on a ManyToOne.
- isAndHavingExpr() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.Sql
-
Return true if there is already a HAVING clause and any extra having expressions start with AND.
- isAndWhereExpr() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.Sql
-
Return true if there is already a WHERE clause and any extra where expressions start with AND.
- isArrayType() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- isAsDraft() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if this is a 'As Draft' query.
- isAsDraft() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isAsOfBaseTable() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if the base table is using history.
- isAsOfBaseTable() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isAsOfQuery() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if this is a 'As Of' query.
- isAsOfQuery() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isAsOfStandardsBased() - Method in class io.ebeaninternal.server.persist.Binder
-
Return true if the 'as of' history support is SQL2011 standards based.
- isAssignableFrom(Class<?>) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- isAssocId() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
-
Returns false as not an AssocOne.
- isAssocId() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- isAssocId() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- isAssocId() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- isAssocId() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- isAssocId() - Method in interface io.ebeaninternal.server.el.ElPropertyValue
-
Return true if this is an ManyToOne or OneToOne associated bean property.
- isAssocId() - Method in interface io.ebeaninternal.server.query.STreePropertyAssocOne
-
Return true if the property is an Id.
- isAssocMany() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- isAssocMany() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- isAssocMany() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- isAssocMany() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- isAssocMany() - Method in interface io.ebeaninternal.server.el.ElPropertyValue
-
Return true if the property is a OneToMany or ManyToMany associated bean property.
- isAssocProperty() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- isAssocProperty() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- isAssocProperty() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- isAssocProperty() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- isAssocProperty() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- isAssocProperty() - Method in interface io.ebeaninternal.server.el.ElPropertyValue
-
Return true if any path of this path contains a Associated One or Many.
- isAuditReads() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return true if read auditing is on for this query request.
- isAuto() - Method in class io.ebeaninternal.server.deploy.IdentityMode
- isAuto() - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- isAutoPersistUpdates() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return true if dirty beans are automatically persisted.
- isAutoPersistUpdates() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isAutoPersistUpdates() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- isAutoPersistUpdates() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- isAutoPersistUpdates() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- isAutoTableMod() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- isAutoTunable() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if AutoTune should be attempted on this query.
- isAutoTunable() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if queries for beans of this type are auto tunable.
- isAutoTunable() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isAutoTune() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return explicit AutoTune setting or null.
- isAutoTune() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isAutoTuned() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isAutoTuneEqual(OrmQueryDetail) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Return true if equal in terms of autoTune (select and fetch without property ordering).
- isAutoTuneProfiling() - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Return true if we are profiling this query.
- isAutoTuneProfiling() - Method in class io.ebeaninternal.server.query.CQuery
-
Should we create profileNodes for beans created in this query.
- isBaseTable() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this type is a base table entity type.
- isBaseTableType() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- isBatched() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true is this request was added to the JDBC batch.
- isBatchEscalateOnCascade(PersistRequest.Type) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return false if JDBC batch can't be implicitly escalated to.
- isBatchMode() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isBatchMode() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- isBatchMode() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- isBatchMode() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- isBatchOnCascade() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isBatchOnCascade() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- isBatchOnCascade() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- isBatchOnCascade() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- isBatchThisRequest() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return true if this request should be batched.
- isBatchThisRequest() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isBatchThisRequest() - Method in class io.ebeaninternal.server.core.PersistRequest
-
Return true if this persist request should use JDBC batch.
- isBatchThisRequest() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- isBatchThisRequest() - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
- isBatchThisRequest() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Return true if this request should be batched.
- isBatchThisRequest() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Return true if this request should be batched.
- isBatchThisRequest() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Return true if this request should be batched.
- isBeanCacheGet() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if the query should GET against bean cache.
- isBeanCacheGet() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isBeanCachePut() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if the query should PUT against the bean cache.
- isBeanCachePut() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- isBeanCachePut() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isBeanCachePutMany() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- isBeanCaching() - Method in interface io.ebeaninternal.api.SpiCacheControl
-
Return true if bean caching.
- isBeanCaching() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if there is currently bean caching for this type of bean.
- isCache() - Method in interface io.ebeaninternal.api.LoadBeanBuffer
- isCache() - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Return true if this path should hit the L2 cache.
- isCacheDataInclude() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property should be included in the cache bean data.
- isCacheDataInclude() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Exclude many properties from bean cache data.
- isCacheNotify(PersistRequest.Type, boolean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if the persist request needs to notify the cache.
- isCacheSharableBeans() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this bean can cache sharable instances.
- isCaching() - Method in interface io.ebeaninternal.api.SpiCacheControl
-
Return true if bean caching or query caching.
- isCancelled() - Method in class io.ebeaninternal.server.query.QueryFutureIds
- isCancelled() - Method in class io.ebeaninternal.server.query.QueryFutureList
- isCancelled() - Method in class io.ebeaninternal.server.query.QueryFutureRowCount
- isCascade() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- isChangedProperty(int) - Method in class io.ebeaninternal.server.core.PersistRequestBean
- isChangeLog() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- isClearAll() - Method in class io.ebeaninternal.server.cache.RemoteCacheEvent
- isClustering() - Method in class io.ebeaninternal.server.cluster.ClusterManager
-
Return true if clustering is on.
- isCode() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- isCompatible(EnumType) - Method in interface io.ebeaninternal.server.type.ScalarTypeEnum
-
Return true if the scalar type is compatible with the specified enum type.
- isComplexId() - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Return false if the id is a simple scalar and false if it is embedded or concatenated.
- isComplexId() - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- isComplexId() - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- isCompound() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
-
Return true if this has multiple properties (expected for embedded id).
- isConcrete() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return true if this is considered a concrete type in the inheritance hierarchy.
- isConcurrent() - Method in class io.ebeaninternal.server.deploy.IndexDefinition
-
Return true if this index has the concurrent flag.
- isContainsMany() - Method in class io.ebeaninternal.server.el.ElPropertyChainBuilder
- isContainsMany() - Method in class io.ebeaninternal.server.query.ExtraJoin
- isCountDistinct() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isDatabaseIdentity() - Method in class io.ebeaninternal.server.deploy.IdentityMode
- isDbEncrypted() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
-
Returns false for keys.
- isDbEncrypted() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property is stored encrypted.
- isDbEncrypted() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if this property is encrypted in the DB.
- isDbEncrypted() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- isDbEncrypted() - Method in interface io.ebeaninternal.server.el.ElPropertyValue
-
Return true if the property is encrypted in the DB.
- isDbInsertable() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property should be included in an Insert.
- isDbInsertable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isDbRead() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if this property is included in database queries.
- isDbSequence() - Method in class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
-
Returns false.
- isDbSequence() - Method in class io.ebeaninternal.server.idgen.UuidV4IdGenerator
-
Returns false.
- isDbUpdatable() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property should be included in an Update.
- isDbUpdateable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isDDLColumn() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property should have a DB Column created in DDL.
- isDDLNotNull() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if DDL Not NULL constraint should be defined for this column based on it being a version column or having a generated property.
- isDebug() - Method in interface io.ebeaninternal.api.SpiLogger
-
Is debug logging enabled.
- isDelete() - Method in class io.ebeaninternal.api.TransactionEventTable.TableIUD
- isDelete() - Method in class io.ebeaninternal.server.deploy.BeanCascadeInfo
-
Return true if delete should cascade.
- isDeleteByBulk() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- isDeleteByStatement() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- isDeleteByStatement() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Return true if delete by statement is allowed for this type given cascade rules etc.
- isDeleteByStatement() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if delete can use a single SQL statement.
- isDetailEmpty() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if the query detail has neither select or joins specified.
- isDetailEmpty() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Return true if the query detail has neither select or joins specified.
- isDirty() - Method in class io.ebeaninternal.server.core.DefaultBeanState
- isDirty() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Used to skip updates if we know the bean is not dirty.
- isDirty() - Method in interface io.ebeaninternal.server.type.ModifyAwareType
- isDirty(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- isDirty(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- isDirtyProperty(BeanProperty) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if the property is dirty.
- isDisableL2Cache() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return true if the L2 cache has been disabled.
- isDisableL2Cache() - Method in class io.ebeaninternal.server.core.DefaultServer
- isDisableLazyLoad() - Method in class io.ebeaninternal.server.core.DefaultBeanState
- isDisableLazyLoading() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if lazy loading has been disabled on the query.
- isDisableLazyLoading() - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Return true if this request disables lazy loading.
- isDisableLazyLoading() - Method in class io.ebeaninternal.server.query.CQuery
- isDisableLazyLoading() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isDisableReadAudit() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if read auditing is disabled on this query.
- isDisableReadAudit() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isDiscriminator() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property maps to the inheritance discriminator column.
- isDiscriminator() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if this property maps to the inheritance discriminator column.s
- isDistinct() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if this query has been specified by a user to use DISTINCT.
- isDistinct() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
return true if user specified to use SQL DISTINCT (effectively excludes id property).
- isDistinct() - Method in class io.ebeaninternal.server.querydefn.OrmQueryLimitRequest
- isDistinct() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.Sql
- isDocStoreEmbeddedInvalidation() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this bean type has embedded doc store invalidation.
- isDocStoreMapped() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this type maps to a root type of a doc store document (not embedded or ignored).
- isDocStoreMapped() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return true if this type is mapped for a doc store.
- isDocStoreOnly() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this is a "Doc Store only" entity bean.
- isDocStoreOnly() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- isDone() - Method in class io.ebeaninternal.server.query.QueryFutureIds
- isDone() - Method in class io.ebeaninternal.server.query.QueryFutureList
- isDone() - Method in class io.ebeaninternal.server.query.QueryFutureRowCount
- isDraft() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property is a boolean flag on a draftable bean indicating if the instance is a draft or live bean.
- isDraft() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isDraftable() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if the bean type is a Draftable.
- isDraftable() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this entity type is draftable.
- isDraftable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- isDraftableElement() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this entity type is a draftable element (child).
- isDraftableElement() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- isDraftDirty() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property is a boolean flag only on the draft table indicating that when the draft is different from the published row.
- isDraftDirty() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isDraftInstance(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if the bean is considered a 'draft' instance (not 'live').
- isDraftOnly() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property only exists on the draft table.
- isDraftOnly() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isDraftQuery() - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Return true if the underlying query is a 'asDraft' query.
- isDraftQuery() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Return true if the query is a 'asDraft' query.
- isDraftQuery() - Method in class io.ebeaninternal.server.query.CQuery
- isDraftReset() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isElementCollection() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- isElementCollection() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
- isEmbedded() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this is an embedded bean.
- isEmbedded() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this is an Embedded property.
- isEmbedded() - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- isEmbedded() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- isEmbedded() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if this is an Embedded property.
- isEmbedded() - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Return true if the property is an embedded type.
- isEmbeddedPath(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- isEmbeddedPath(String) - Method in interface io.ebeaninternal.server.query.STreeType
-
Return true if the given path is an embedded bean.
- isEmpty() - Method in class io.ebeaninternal.api.BindParams
-
Return true if there are no bind parameters.
- isEmpty() - Method in interface io.ebeaninternal.api.SpiExpressionList
-
Return true if this list is empty.
- isEmpty() - Method in class io.ebeaninternal.api.TransactionEventTable
- isEmpty() - Method in class io.ebeaninternal.json.ModifyAwareList
- isEmpty() - Method in class io.ebeaninternal.json.ModifyAwareMap
- isEmpty() - Method in class io.ebeaninternal.json.ModifyAwareSet
- isEmpty() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- isEmpty() - Method in class io.ebeaninternal.server.persist.BatchControl
-
Return true if the queue is empty.
- isEmpty() - Method in class io.ebeaninternal.server.persist.BatchedPstmt
- isEmpty() - Method in class io.ebeaninternal.server.persist.BatchedPstmtHolder
-
Return true if the batch has no statements to execute.
- isEmpty() - Method in class io.ebeaninternal.server.query.CQueryPlanStats
-
Return true if there are no statistics collected since the last reset.
- isEmpty() - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- isEmpty() - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Return true if the query detail has neither select properties specified or any joins defined.
- isEmpty() - Method in class io.ebeaninternal.server.querydefn.SimpleTextParser
- isEmpty() - Method in class io.ebeaninternal.server.transaction.BeanPersistIdMap
- isEmpty() - Method in class io.ebeaninternal.server.transaction.BulkEventListenerMap
- isEmpty() - Method in class io.ebeaninternal.server.transaction.DeleteByIdMap
- isEmpty() - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- isEmpty() - Method in class io.ebeaninternal.server.util.ArrayStack
-
Tests if this stack is empty.
- isEmpty() - Method in class io.ebeanservice.docstore.api.DocStoreUpdates
-
Return true if there are no events to process.
- isEmpty(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- isEmpty(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- isEmptySetClause() - Method in interface io.ebeaninternal.api.SpiUpdatePlan
-
Return true if the set clause has no columns.
- isEmptyStats() - Method in class io.ebeaninternal.server.query.CQueryPlan
-
Return true if there are no statistics collected since the last reset.
- isEnableBeanCache() - Method in class io.ebeaninternal.server.core.CacheOptions
-
Return true if bean caching is enabled.
- isEnableBindLog() - Method in class io.ebeaninternal.server.persist.Binder
-
Return true if bind log is enabled.
- isEnabled() - Method in class io.ebeaninternal.server.deploy.DCacheRegion
- isEnableQueryCache() - Method in class io.ebeaninternal.server.core.CacheOptions
-
Return true if query caching is enabled.
- isEncryptionKey() - Method in class io.ebeaninternal.api.BindParams.Param
-
If true do not include this value in a transaction log.
- isEnumType(Type) - Static method in class io.ebeaninternal.server.type.TypeReflectHelper
-
Return true if the type is an enum.
- isExcludedFromHistory() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property is excluded from history.
- isExcludedFromHistory() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isExcludedFromHistory() - Method in interface io.ebeaninternal.server.query.STreePropertyAssocMany
-
Return true if the property is excluded from history.
- isExplicit() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return true if this transaction was created explicitly via
Ebean.beginTransaction(). - isExplicit() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isExplicit() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Return true if this was an explicitly created transaction.
- isExplicit() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Return true if this was an explicitly created transaction.
- isExplicit() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Return true if this was an explicitly created transaction.
- isExternal() - Method in class io.ebeaninternal.server.deploy.IdentityMode
- isExternal() - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- isFetchEager() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if by default this property is set to fetch eager.
- isFetchEager() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if this should be eager fetched by default.
- isFindAll() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if this is a "find all" query.
- isFindAll() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isFindById() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if this is a "find by id" query.
- isFindById() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return true if this is a find by id (rather than List Set or Map).
- isFindById() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isFindIterate() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return true if this is a findEach, findIterate type query where we expect many results.
- isFinished() - Method in class io.ebeaninternal.server.querydefn.SimpleTextParser
- isFlushOnQuery() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isFlushOnQuery() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- isFlushOnQuery() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- isFlushOnQuery() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- isFlushQueue() - Method in class io.ebeaninternal.server.core.PersistRequest
- isFlushQueue() - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
- isFlushQueue() - Method in interface io.ebeaninternal.server.persist.BatchPostExecute
-
Return true if this is a queued sql update for element collection or intersection table.
- isForcedUpdate() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- isForceHitDatabase() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if we must hit the DB (Cache reload or select for update).
- isForceHitDatabase() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isFormula() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property is based on a formula.
- isFormula() - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- isFormula() - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Return true if the property is a formula.
- isFormulaWithJoin(String) - Method in class io.ebeaninternal.api.ManyWhereJoins
-
Return true if the query select includes a formula with join.
- isForUpdate() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isGenerated() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this is a generated or Id property.
- isGeneratedProperty(int) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this is a generated property.
- isGenerateMigration() - Static method in class io.ebeaninternal.api.DbOffline
-
Return true if the migration is running.
- isGetAllFromBeanCache() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- isGetAllFromBeanCache() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Return true if hitting bean cache and returning all beans from cache.
- isGetGeneratedKeys() - Method in interface io.ebeaninternal.api.SpiSqlUpdate
-
Return true if we are using getGeneratedKeys.
- isGetGeneratedKeys() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- isGetGeneratedKeys() - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
- isHard() - Method in enum io.ebeaninternal.server.persist.DeleteMode
- isHardDeleteCascade() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if this was a hard/permanent delete request (and should cascade as such).
- isHardDeleteDraft() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if this request is a hard delete of a draftable bean.
- isHistory() - Method in enum io.ebeaninternal.api.SpiQuery.TemporalMode
-
Return true if this is a history query.
- isHistorySupport() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this entity bean has history support.
- isHistorySupport() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return true if this is an @History entity bean.
- isHistorySupport() - Method in interface io.ebeaninternal.server.query.STreeType
-
Return true if the type uses history.
- isId() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this is included in the unique id.
- isId() - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- isId() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if this is included in the unique id.
- isId() - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Return true if the property is the Id.
- isIdClass() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isIdentity() - Method in class io.ebeaninternal.server.deploy.IdentityMode
- isIdentity() - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- isIdGeneratedValue() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if the Id value is marked as a
@GeneratedValue. - isIdGeneratedValue() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return true for automatic Id generation strategy.
- isIdInExpandedForm() - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Return true if this is a compound key and must use expanded and or form.
- isIdInExpandedForm() - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- isIdInExpandedForm() - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- isIdLoaded(EntityBeanIntercept) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- isImportedPrimaryKey() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
If true this bean maps to the primary key.
- isImportedPrimaryKey() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if this is part of the primary key.
- isIncludeCascadeDelete() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- isIncludeCascadeSave() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- isIncludedBeanJoin(String) - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Return true if this property is included as a bean join.
- isIncludeEmpty() - Method in class io.ebeaninternal.server.json.WriteJson
-
Return true if empty collections should be included in the JSON output.
- isIncludeNull() - Method in class io.ebeaninternal.server.json.WriteJson
-
Return true if null values should be included in JSON output.
- isIncludeSoftDelete() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Return true if the query includes soft deleted rows.
- isIncludeSoftDeletes() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if this query includes soft deleted rows.
- isIncludeSoftDeletes() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isInheritanceRoot() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this object is the root level object in its entity inheritance.
- isInlineCountDistinct() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- isInlineSqlUpdateLimit() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return true if no MaxRows or use LIMIT in SQL update.
- isInParam() - Method in class io.ebeaninternal.api.BindParams.Param
-
Return true if this is an In parameter that needs to be bound before execution.
- isInsert() - Method in class io.ebeaninternal.api.TransactionEventTable.TableIUD
- isInsert() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if this is an insert request.
- isInsert(int) - Static method in class io.ebeaninternal.server.persist.Flags
-
Return true if the bean is being inserted.
- isInsertable() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return true if this association is insertable.
- isInsertable() - Method in class io.ebeaninternal.server.deploy.meta.DeployOrderColumn
- isInsertable() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoinColumn
-
Return true if this column should be insertable.
- isInsertable() - Method in class io.ebeaninternal.server.deploy.TableJoinColumn
-
Return true if this column should be insertable.
- isInsertedParent() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if this request is an insert.
- isInsertMode(EntityBeanIntercept, boolean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this bean should be inserted rather than updated.
- isInvalidateQueryCache() - Method in class io.ebeaninternal.server.core.CacheOptions
-
Return true if this is InvalidateQueryCache.
- isJacksonCorePresent() - Method in class io.ebeaninternal.server.core.InternalConfiguration
- isJacksonCorePresent() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- isJacksonCorePresent() - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- isJacksonCorePresent() - Method in interface io.ebeaninternal.server.deploy.BeanDescriptorMap
-
Return true if Jackson core is present on the classpath.
- isJoinsEmpty() - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Return true if there are no joins.
- isJsonDeserialize() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isJsonReadCollection() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- isJsonSerialize() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- isJsonSerialize() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isLazy() - Method in class io.ebeaninternal.api.LoadRequest
-
Return true if this is a lazy load and false if it is a secondary query.
- isLazyLoad() - Method in class io.ebeaninternal.server.query.SqlBeanLoad
-
Return true if this is a lazy loading.
- isLiveInstance(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if the bean is draftable and considered a 'live' instance.
- isLoadContextBean() - Method in enum io.ebeaninternal.api.SpiQuery.Mode
- isLoadContextBean() - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Return true if the beans that already exist in the persistence context should have data from the database loaded into them.
- isLoadContextBean() - Method in class io.ebeaninternal.server.query.CQuery
- isLoaded(String) - Method in class io.ebeaninternal.server.cache.CachedBeanData
-
Return true if the property is held.
- isLoadedProperty(BeanProperty) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if this property is loaded (full bean or included in partial bean).
- isLoadProperty(boolean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property is loadable from a resultSet.
- isLob() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this is mapped to a Clob Blob LongVarchar or LongVarbinary.
- isLob() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if this is mapped to a Clob Blob LongVarchar or LongVarbinary.
- isLobForPlatform() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Returns true if this
isLob()or the type will effectively map to a lob. - isLobForPlatform() - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- isLobForPlatform() - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Returns true, if this is a lob property from db-perspective.
- isLobType(int) - Static method in class io.ebeaninternal.server.deploy.BeanProperty
- isLocal() - Method in class io.ebeaninternal.api.TransactionEvent
-
Return true if this was a local transaction.
- isLocal() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true is this type is not from a super type.
- isLocal() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if this is local to this type - aka not from a super type.
- isLocalEncrypted() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
-
Returns false for keys.
- isLocalEncrypted() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Returns true if DB encrypted.
- isLocalEncrypted() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if the property is encrypted in java rather than in the DB.
- isLocalEncrypted() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- isLocalEncrypted() - Method in interface io.ebeaninternal.server.el.ElPropertyValue
-
Return true if the property is encrypted via Java.
- isLocalL2Caching() - Method in class io.ebeaninternal.server.cache.CacheManagerOptions
- isLocalL2Caching() - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
- isLocalL2Caching() - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Return true if the L2 caching is local.
- isLogSql() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return true if generated SQL and Bind values should be logged to the transaction log.
- isLogSql() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isLogSql() - Method in interface io.ebeaninternal.api.SpiTxnLogger
-
Is debug logging enabled.
- isLogSql() - Method in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
- isLogSql() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- isLogSql() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- isLogSql() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- isLogSummary() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return true if summary level events should be logged to the transaction log.
- isLogSummary() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isLogSummary() - Method in interface io.ebeaninternal.api.SpiTxnLogger
-
Is summary logging enabled.
- isLogSummary() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- isLogSummary() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- isLogSummary() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- isManualId() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if the Id property is manually included in the query (DTO queries).
- isManualId() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isMany() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- isMany() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- isManyPropCaching() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- isManyToMany() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return true if this is many to many.
- isManyToMany() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Return true if this is many to many.
- isManyToMany() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertySimpleCollection
-
Returns false as never a ManyToMany.
- isManyToManyWithHistory() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- isManyToManyWithHistory() - Method in interface io.ebeaninternal.server.query.STreePropertyAssocMany
-
Return true if this is a ManyToMany with history.
- isMap() - Method in enum io.ebeaninternal.server.deploy.ManyType
- isMarkedDirty() - Method in class io.ebeaninternal.json.ModifyAwareFlag
- isMarkedDirty() - Method in class io.ebeaninternal.json.ModifyAwareList
- isMarkedDirty() - Method in class io.ebeaninternal.json.ModifyAwareMap
- isMarkedDirty() - Method in class io.ebeaninternal.json.ModifyAwareSet
- isMatch(String) - Method in class io.ebeaninternal.server.querydefn.SimpleTextParser
-
Match the current word.
- isMatch(String, String) - Method in class io.ebeaninternal.server.querydefn.SimpleTextParser
-
Match the current and the next word.
- isMatch(T) - Method in interface io.ebeaninternal.server.el.ElMatcher
-
Return true if the bean matches the expression.
- isMerge(int) - Static method in class io.ebeaninternal.server.persist.Flags
-
Return true if part of a Merge.
- isModified(Object) - Static method in class io.ebeaninternal.server.deploy.BeanCollectionUtil
-
Return true if this is a bean collection and not considered dirty.
- isMultiTenant() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this type is tenant aware.
- isMultiValueIdSupported() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- isMultiValueIdSupported() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this type has a simple Id and the platform supports mutli-value binding.
- isMultiValueSupported() - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- isMultiValueSupported() - Method in interface io.ebeaninternal.server.deploy.BeanDescriptorMap
-
Return true if multiple values can be bound as Array or Table Value and hence share the same query plan.
- isMultiValueSupported(Class<?>) - Method in interface io.ebeaninternal.server.core.OrmQueryEngine
-
Return true if multi-value bind is supported for this type (and current platform).
- isMultiValueSupported(Class<?>) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- isMultiValueSupported(Class<?>) - Method in class io.ebeaninternal.server.persist.Binder
-
Return true if MultiValue binding is supported for the given type.
- isMultiValueSupported(Class<?>) - Method in class io.ebeaninternal.server.query.DefaultOrmQueryEngine
- isMutableScalarType() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if the underlying type is mutable.
- isNativeSql() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if this is a native sql query.
- isNativeSql() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- isNativeSql() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isNaturalKey() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this is the natural key property.
- isNaturalKey() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isNaturalKeyCaching() - Method in interface io.ebeaninternal.api.SpiCacheControl
-
Return true if natural key caching.
- isNaturalKeyCaching() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if there is a natural key defined for this bean type.
- isNestedUseSavepoint() - Method in class io.ebeaninternal.api.ScopedTransaction
- isNestedUseSavepoint() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return true when nested transactions should create Savepoints.
- isNestedUseSavepoint() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isNestedUseSavepoint() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- isNestedUseSavepoint() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- isNestedUseSavepoint() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- isNew() - Method in class io.ebeaninternal.server.core.DefaultBeanState
- isNewOrDirty() - Method in class io.ebeaninternal.server.core.DefaultBeanState
- isNoConstraint() - Method in class io.ebeaninternal.server.deploy.PropertyForeignKey
- isNoIndex() - Method in class io.ebeaninternal.server.deploy.PropertyForeignKey
- isNotEmpty(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- isNotEmpty(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- isNotifyCache() - Method in interface io.ebeaninternal.api.SpiUpdate
-
Return true if the cache should be notified to invalidate objects.
- isNotifyCache() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- isNotifyCache() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
-
Return true if the cache should be notified so that invalidates appropriate objects.
- isNotNull(String) - Method in class io.ebeaninternal.server.el.ElFilter
- isNotNull(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Is Not Null - property is not null.
- isNotNull(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- isNull(String) - Method in class io.ebeaninternal.server.el.ElFilter
- isNull(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Is Null - property is null.
- isNull(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- isNullable() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property is mandatory.
- isNullable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if this property is mandatory.
- isNullable() - Method in class io.ebeaninternal.server.deploy.meta.DeployOrderColumn
- isNullOrZero(Object) - Static method in class io.ebeaninternal.server.persist.DmlUtil
-
Return true if the value is null or a Numeric 0 (for primitive int's and long's) or Option empty.
- isO2mJoinTable() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return true if this is a one to many with a join table.
- isO2mJoinTable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
- isOneToOne() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Return true if this a OneToOne property.
- isOneToOne() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
-
Return true if this a OneToOne property.
- isOneToOneExported() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Return true if this is the exported side of a OneToOne.
- isOneToOneExported() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
-
Return true if this is the exported side of a OneToOne.
- isOpEquals() - Method in class io.ebeaninternal.server.expression.SimpleExpression
- isOptionsSet() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
-
Return true if the index options is set to a non-default value.
- isOrphanRemoval() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- isOrphanRemoval() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- isOrphanRemoval() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
- isOutParam() - Method in class io.ebeaninternal.api.BindParams.Param
-
Return true if this is an out parameter that needs to be registered before execution.
- isOverrideBy(EnumType) - Method in interface io.ebeaninternal.server.type.ScalarTypeEnum
-
Return true if we allow this scalar enum type to be overridden.
- isPadInExpression() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- isPadInExpression() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if Id IN expression should have bind parameters padded.
- isParent(Object) - Method in class io.ebeaninternal.server.core.PersistRequestBean
- isParentFindIterate() - Method in class io.ebeaninternal.api.LoadRequest
-
Return true if the parent query is a findIterate() type query.
- isParsed() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping
-
Returns true if the Columns where supplied by parsing the sql select clause.
- isParsed() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.Sql
-
Return true if the SQL is left completely unmodified.
- isPersistCascade() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Whether persistCascade is on for save and delete.
- isPersistCascade() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isPersistCascade() - Method in class io.ebeaninternal.server.core.PersistRequest
-
Return true if save and delete should cascade.
- isPersistCascade() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- isPersistCascade() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- isPersistCascade() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- isPlatformDefault() - Method in class io.ebeaninternal.server.deploy.IdentityMode
- isPlatformDefault() - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- isPrimaryKeyCompoundOrNonNumeric() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return true if the primary key is a compound key or if it's database type is non-numeric (and hence not suitable for db identity or sequence.
- isPrimaryKeyExport() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
- isPrimaryKeyJoin() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
- isProfileRequest(ObjectGraphNode, SpiQuery<?>) - Method in interface io.ebeaninternal.server.autotune.ProfilingListener
-
Return true if this request should be profiled (based on the profiling ratio and collection count for this origin).
- isPublish() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if this request is a 'publish' action.
- isPublish(int) - Static method in class io.ebeaninternal.server.persist.Flags
-
Return true if part of a Publish.
- isPublishMergeOrNormal(int) - Static method in class io.ebeaninternal.server.persist.Flags
-
Return true if part of a Merge or Publish or Normal (bean state matches persist).
- isQueryCachePut() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- isQueryCaching() - Method in interface io.ebeaninternal.api.SpiCacheControl
-
Return true if query caching.
- isQueryCaching() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if there is query caching for this type of bean.
- isQueryFetch() - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Return true if this path is a 'query join'.
- isQueueSaveMany() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if the intersection table updates or element collection updates should be queued.
- isRawSql() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if this is a RawSql query.
- isRawSql() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- isRawSql() - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Return true if the query is using supplied SQL rather than generated SQL.
- isRawSql() - Method in class io.ebeaninternal.server.query.CQuery
-
Return true if this is a raw sql query as opposed to Ebean generated sql.
- isRawSql() - Method in class io.ebeaninternal.server.query.CQueryPlan
- isRawSql() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isRawSqlBased() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Returns true if this bean is based on RawSql.
- isRawSqlBased() - Method in interface io.ebeaninternal.server.query.STreeType
-
Return true if the type is RawSql based.
- isReadAuditing() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if read auditing is on this entity bean.
- isReadAuditing() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return true if read auditing is on for this entity bean.
- isReadOnly() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if the beans returned by this query should be read only.
- isReadOnly() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isReadOnly() - Method in class io.ebeaninternal.server.core.CacheOptions
-
Return true if bean cache hits default to read only.
- isReadOnly() - Method in class io.ebeaninternal.server.core.DefaultBeanState
- isReadOnly() - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Return the state of the object graph.
- isReadOnly() - Method in class io.ebeaninternal.server.query.CQuery
- isReadOnly() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isReadOnly() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- isReadOnly() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- isReadOnly() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- isRecurse(int) - Static method in class io.ebeaninternal.server.persist.Flags
-
Return true if persist cascading.
- isReference() - Method in class io.ebeaninternal.server.core.DefaultBeanState
- isReference() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- isReference(EntityBeanIntercept) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- isReference(Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- isRefresh() - Method in class io.ebeaninternal.server.deploy.BeanCascadeInfo
-
Return true if refresh should cascade.
- isRegisteredBean() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if this bean has been already been persisted (inserted or updated) in this transaction.
- isRegisteredBean(Object) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return true if this is a bean that has already been persisted in the current recursive save request.
- isRegisteredBean(Object) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isRegisteredBean(Object) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Return true if this is a bean that has already been saved.
- isRegisteredBean(Object) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Return true if this is a bean that has already been saved.
- isRegisteredBean(Object) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Return true if this is a bean that has already been saved.
- isRegisteredDeleteBean(Integer) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return true if this is a bean that has already been saved/deleted.
- isRegisteredDeleteBean(Integer) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isRegisteredDeleteBean(Integer) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Return true if this is a bean that has already been saved/deleted.
- isRegisteredDeleteBean(Integer) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Return true if this is a bean that has already been saved/deleted.
- isRegisteredDeleteBean(Integer) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Return true if this is a bean that has already been saved/deleted.
- isRegisteredForDeleteBean() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- isRegisterFor(Class<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistController
-
Always returns false (not used for this object).
- isRegisterFor(Class<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistListener
- isRegisterFor(Class<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPostConstructListener
- isRegisterFor(Class<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPostLoad
- isRegisterFor(Class<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanQueryAdapter
-
Return false as only individual adapters are registered.
- isRelaxedMode() - Method in interface io.ebeaninternal.api.SpiDtoQuery
-
Return true if the query is in relaxed mapping mode.
- isRelaxedMode() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- isRequireOuterJoins() - Method in class io.ebeaninternal.api.ManyWhereJoins
-
Return the current 'mode' indicating if outer joins are currently required or not.
- isRollbackOnly() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isRollbackOnly() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Return true if the transaction is marked as rollback only.
- isRollbackOnly() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Return true if the transaction is marked as rollback only.
- isRollbackOnly() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Return true if the transaction is marked as rollback only.
- isRoot() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return true if this is the root node.
- isSameBindHash() - Method in class io.ebeaninternal.api.BindParams
-
Return true if the bind hash and count has not changed.
- isSameByBind(SpiExpression) - Method in interface io.ebeaninternal.api.SpiExpression
-
Return true if the expression is the same with respect to bind values.
- isSameByBind(SpiExpression) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- isSameByBind(SpiExpression) - Method in class io.ebeaninternal.server.expression.IdInExpression
- isSameByBind(SpiExpression) - Method in class io.ebeaninternal.server.expression.InExpression
- isSameByBind(SpiExpression) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- isSave() - Method in class io.ebeaninternal.server.deploy.BeanCascadeInfo
-
Return true if save should cascade.
- isSaveAssocManyIntersection(String, String) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return true if the manyToMany intersection should be persisted for this particular relationship direction.
- isSaveAssocManyIntersection(String, String) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isSaveAssocManyIntersection(String, String) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Return true if the m2m intersection save is allowed from a given bean direction.
- isSaveAssocManyIntersection(String, String) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Return true if the m2m intersection save is allowed from a given bean direction.
- isSaveAssocManyIntersection(String, String) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Return true if the m2m intersection save is allowed from a given bean direction.
- isSaveRecurseSkippable() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return true if save can be skipped for unmodified bean(s) of this property.
- isSaveRecurseSkippable(Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
- isScalar() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true is this is a simple scalar property.
- isScalar() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return false.
- isScalar() - Method in interface io.ebeaninternal.server.deploy.id.ImportedId
-
Return true if this id is a simple single scalar value.
- isScalar() - Method in class io.ebeaninternal.server.deploy.id.ImportedIdEmbedded
- isScalar() - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- isSecondaryTable() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property is based on a secondary table (not the base table).
- isSecondaryTable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if this property is based on a secondary table.
- isSequence() - Method in class io.ebeaninternal.server.deploy.IdentityMode
- isSequence() - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- isSet() - Static method in class io.ebeaninternal.api.DbOffline
-
Return true if the offline platform has been set.
- isSet(int, int) - Static method in class io.ebeaninternal.server.persist.Flags
-
Return true if the given flag is set.
- isSingleAttribute() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if this is singleAttribute query.
- isSingleAttribute() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Return true if this is a single attribute query.
- isSingleProperty() - Method in class io.ebeaninternal.server.deploy.BeanNaturalKey
-
Return true if this is a single property natural key.
- isSkipCache() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isSkipCache() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- isSkipCache() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- isSkipCache() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- isSkipCacheExplicit() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return true if explicitly set to skip cache (ignores skipOnWrite).
- isSkipCacheExplicit() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isSkipCacheExplicit() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- isSkipCacheExplicit() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- isSkipCacheExplicit() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- isSkipReference() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return if persist can be skipped on the reference only bean.
- isSkipSaveBeanCollection(EntityBean, boolean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return true if this is considered 'empty' from a save perspective.
- isSoftDelete() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- isSoftDelete() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property is the soft delete property.
- isSoftDelete() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isSoftDelete() - Method in interface io.ebeaninternal.server.query.STreeType
-
Return true if the type uses soft delete.
- isSortable() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- isStatelessUpdate() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return true if this is a stateless update request (in which case it doesn't really have 'old values').
- isSupportedType(Type) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return true if the type is known as an Entity or Xml type or a List Set or Map of known bean types.
- isSupportedType(Type) - Method in class io.ebeaninternal.server.core.DefaultServer
- isSupportedType(Type) - Method in class io.ebeaninternal.server.json.DJsonContext
- isTableManaged(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Returns true, if the table is managed (i.e. an existing m2m relation).
- isTableManaged(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- isTableManaged(String) - Method in interface io.ebeaninternal.server.deploy.BeanDescriptorMap
-
Returns true, if the given table (or view) is managed by ebean (= an entity exists)
- isTargetDocStoreMapped() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- isTargetSoftDelete() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return true if the target side has soft delete.
- isTargetSoftDelete() - Method in interface io.ebeaninternal.server.query.STreePropertyAssoc
-
Return true if the associated type has soft delete.
- istartsWith(String, String) - Method in class io.ebeaninternal.server.el.ElFilter
- istartsWith(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Case-insensitive Starts With - property like value%.
- istartsWith(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- isTenantId() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this is the tenantId property (for multi-tenant partitioning).
- isTenantId() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isToManyDirty(EntityBean) - Method in interface io.ebeaninternal.api.SpiBeanType
-
Return true if the bean contains a many property that has modifications.
- isToManyDirty(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- isTransient() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if the property is transient.
- isTransient() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if the property is transient.
- isUndirectionalShadow() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if this is a placeholder property for a unidirectional relationship.
- isUnidirectional() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Return true if this is a unidirectional relationship.
- isUnidirectional() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertySimpleCollection
-
Returns true as always Unidirectional.
- isUnique() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if the DB column should be unique.
- isUnique() - Method in class io.ebeaninternal.server.deploy.IndexDefinition
-
Return true if this is a unique constraint.
- isUnique() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if the DB column is unique.
- isUniqueConstraint() - Method in class io.ebeaninternal.server.deploy.IndexDefinition
-
Return true if this can be used as a unique constraint.
- isUnmappedJson() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this property hold unmapped JSON.
- isUnmappedJson() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- isUpdatable() - Method in class io.ebeaninternal.server.deploy.meta.DeployOrderColumn
- isUpdate() - Method in enum io.ebeaninternal.api.SpiQuery.Type
-
Return true if this is an Update or Delete query (not read only).
- isUpdate() - Method in class io.ebeaninternal.api.TransactionEventTable.TableIUD
- isUpdateable() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return true if this association is updateable.
- isUpdateable() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoinColumn
-
Return true if this column should be updateable.
- isUpdateAllLoadedProperties() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return true if this transaction has updateAllLoadedProperties set.
- isUpdateAllLoadedProperties() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- isUpdateAllLoadedProperties() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- isUpdateAllLoadedProperties() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- isUpdateAllLoadedProperties() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- isUpdateAllPropertiesInBatch() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return true if updates in JDBC batch should include all columns if unspecified on the transaction.
- isUpdateAllPropertiesInBatch() - Method in class io.ebeaninternal.server.core.DefaultServer
- isUpdateForce(int) - Static method in class io.ebeaninternal.server.persist.Flags
- isUpdateOrDelete() - Method in class io.ebeaninternal.api.TransactionEventTable.TableIUD
- isUsageProfiling() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return false when this is a lazy load or refresh query for a bean.
- isUsageProfiling() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isUseCache() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Only cache Many Ids if the target bean is also cached.
- isUseDocStore() - Method in interface io.ebeaninternal.api.LoadManyBuffer
- isUseDocStore() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if this query should be executed against the doc store.
- isUseDocStore() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- isUseDocStore() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Return true if this query is expected to use the doc store.
- isUseDocStore() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isUseIdGenerator() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this bean type should use IdGeneration.
- isUseMaster() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if this query should not use the read only data source.
- isUseMaster() - Method in interface io.ebeaninternal.api.SpiSqlBinding
-
Return true if this query should not use the read only data source.
- isUseMaster() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- isUseMaster() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isUseMaster() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- isUsingFuture() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if this is a future query.
- isUsingFuture() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isValid(QueryCacheEntry) - Method in class io.ebeaninternal.server.transaction.TableModState
- isValidExpression(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- isVersion() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return true if this is a version column used for concurrency checking.
- isVersionColumn() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Return true if this is a version column used for concurrency checking.
- isVersionsBetween() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if this is a find versions between query.
- isVersionsBetween() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- isWithId() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if the query should include the Id property.
- isWithId() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- ITERATE - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
Find iterate type query - findEach(), findIterate() etc.
- iterator() - Method in class io.ebeaninternal.json.ModifyAwareList
- iterator() - Method in class io.ebeaninternal.json.ModifyAwareSet
- iterator() - Method in class io.ebeaninternal.server.util.ArrayStack
J
- JAVA_LANG_RECORD - Static variable in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- jdbcNative() - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- jdbcNative() - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- jdbcNative() - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- jdbcType() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- jdbcType() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- jdbcType() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- jdbcType() - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- jdbcType() - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- jdbcType() - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- joinAdded() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Return true if the last join was added and false means the join was suppressed as it was already added to the query.
- joinPlatforms() - Method in class io.ebeaninternal.server.deploy.DbMigrationInfo
- json() - Method in class io.ebeaninternal.server.core.DefaultServer
- json(DbExpressionRequest, String, String, Op, Object) - Method in interface io.ebeaninternal.server.expression.platform.DbExpressionHandler
-
Write the db platform specific json expression.
- jsonBetween(String, String, Object, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- jsonBetween(String, String, Object, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Between - for the given path in a JSON document.
- jsonEqualTo(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- jsonEqualTo(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Equal to expression for the value at the given path in the JSON document.
- jsonExists(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- jsonExists(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Path exists - for the given path in a JSON document.
- jsonExtended() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return the server extended Json context.
- jsonExtended() - Method in class io.ebeaninternal.server.core.DefaultServer
- jsonGreaterOrEqual(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- jsonGreaterOrEqual(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Greater than or equal to - for the given path in a JSON document.
- jsonGreaterThan(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- jsonGreaterThan(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Greater than - for the given path in a JSON document.
- jsonLessOrEqualTo(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- jsonLessOrEqualTo(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Less than or equal to - for the given path in a JSON document.
- jsonLessThan(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- jsonLessThan(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Less than - for the given path in a JSON document.
- jsonNotEqualTo(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- jsonNotEqualTo(String, String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Not Equal to - for the given path in a JSON document.
- jsonNotExists(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- jsonNotExists(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Path does not exist - for the given path in a JSON document.
- jsonRead(JsonParser) - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.BooleanBase
- jsonRead(JsonParser) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesBase
- jsonRead(JsonParser) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- jsonRead(JsonParser) - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- jsonRead(JsonParser) - Method in class io.ebeaninternal.server.type.ScalarTypeString
- jsonRead(JsonParser) - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- jsonRead(JsonParser) - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- jsonRead(SpiJsonReader) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- jsonRead(SpiJsonReader) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- jsonRead(SpiJsonReader, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- jsonRead(SpiJsonReader, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- jsonRead(SpiJsonReader, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- jsonRead(SpiJsonReader, String, T) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- jsonReadCollection(SpiJsonReader, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- jsonReadCollection(SpiJsonReader, EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Read the collection (JSON Array) containing entity beans.
- jsonReadCollection(SpiJsonReader, EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertySimpleCollection
- jsonWrite(JsonGenerator, byte[]) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesBase
- jsonWrite(JsonGenerator, byte[]) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- jsonWrite(JsonGenerator, B) - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- jsonWrite(JsonGenerator, Boolean) - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.BooleanBase
- jsonWrite(JsonGenerator, String) - Method in class io.ebeaninternal.server.type.ScalarTypeString
- jsonWrite(JsonGenerator, UUID) - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- jsonWrite(JsonGenerator, T) - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- jsonWrite(SpiJsonWriter, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- jsonWrite(SpiJsonWriter, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
JSON write the bean property.
- jsonWrite(SpiJsonWriter, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- jsonWrite(SpiJsonWriter, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- jsonWrite(SpiJsonWriter, EntityBean, String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- jsonWrite(SpiJsonWriter, String, Object, boolean) - Method in interface io.ebeaninternal.server.deploy.BeanCollectionHelp
-
Write the collection out as json.
- jsonWrite(SpiJsonWriter, String, Object, boolean) - Method in class io.ebeaninternal.server.deploy.BeanListHelp
- jsonWrite(SpiJsonWriter, String, Object, boolean) - Method in class io.ebeaninternal.server.deploy.BeanMapHelp
- jsonWrite(SpiJsonWriter, String, Object, boolean) - Method in class io.ebeaninternal.server.deploy.BeanSetHelp
- jsonWriteCollection(Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Write the collection to JSON.
- jsonWriteDirty(SpiJsonWriter, EntityBean, boolean[]) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- jsonWriteElement(SpiJsonWriter, Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- jsonWriteForInsert(SpiJsonWriter, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
JSON write the property for 'insert only depth'.
- jsonWriteForInsert(SpiJsonWriter, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
JSON write property (non-recursive to other beans).
- jsonWriteMapEntry(SpiJsonWriter, Map.Entry<?, ?>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- jsonWriteValue(SpiJsonWriter, Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
JSON write the property value.
- jsonWriteValue(SpiJsonWriter, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Skip JSON write value for ToMany property.
- jsonWriteValue(SpiJsonWriter, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
JSON write property value (non-recursive to other beans).
- JtaTransaction - Class in io.ebeaninternal.server.transaction
-
Jta based transaction.
- JtaTransaction(boolean, UserTransaction, DataSource, TransactionManager) - Constructor for class io.ebeaninternal.server.transaction.JtaTransaction
-
Create the JtaTransaction.
- JtaTransactionManager - Class in io.ebeaninternal.server.transaction
-
Hook into external JTA transaction manager.
- JtaTransactionManager() - Constructor for class io.ebeaninternal.server.transaction.JtaTransactionManager
-
Instantiates a new JTA transaction manager.
- junction(Junction.Type) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- junction(Junction.Type) - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- junction(Junction.Type, Query<T>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Return a list of expressions that are wrapped by NOT.
- junction(Junction.Type, Query<T>, ExpressionList<T>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Create and return a Full text junction (Must, Must Not or Should).
K
- key() - Method in interface io.ebeaninternal.api.NaturalKeyEntry
-
Return the natural cache key (String concatenation of values).
- key() - Method in interface io.ebeaninternal.api.SpiUpdatePlan
-
Return the hash key for this plan.
- keys() - Method in class io.ebeaninternal.api.NaturalKeySet
- keys() - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- keySet() - Method in class io.ebeaninternal.json.ModifyAwareMap
- keySet() - Method in class io.ebeaninternal.server.query.DefaultSqlRow
L
- label - Variable in class io.ebeaninternal.server.core.PersistRequest
- label() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the label set on the query.
- label() - Method in enum io.ebeaninternal.api.SpiQuery.Type
- label() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the user defined label for the transaction.
- label() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- label() - Method in interface io.ebeaninternal.api.SpiUpdate
-
Return the label (for metrics collection).
- label() - Method in class io.ebeaninternal.server.query.CQueryPlan
- label() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- label() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- label() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- label() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- label() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- lastIndexOf(Object) - Method in class io.ebeaninternal.json.ModifyAwareList
- lastQueryTime() - Method in class io.ebeaninternal.server.query.CQueryPlan
-
Return the time this query plan was last used.
- lazy - Variable in class io.ebeaninternal.api.LoadRequest
- lazyFetchOrderBy() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return the order by for use when lazy loading the associated collection.
- lazyJoins() - Method in interface io.ebeaninternal.api.SpiQuerySecondary
-
Return the list of path/properties that are lazy loaded.
- LAZYLOAD_BEAN - Enum constant in enum io.ebeaninternal.api.SpiQuery.Mode
- LAZYLOAD_MANY - Enum constant in enum io.ebeaninternal.api.SpiQuery.Mode
- lazyLoadBatchSize() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return the default batch size for lazy loading.
- lazyLoadBatchSize() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the default lazy load batch size.
- lazyLoadBatchSize() - Method in class io.ebeaninternal.server.core.DefaultServer
- lazyLoadBatchSize() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return the batch size for lazy loading on this bean query request.
- lazyLoadBatchSize() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- lazyLoadMany() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the lazy loading 'many' property.
- lazyLoadMany() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- lazyLoadMany(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Add the loaded current bean to its associated parent.
- lazyLoadMany(EntityBeanIntercept) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if the lazy loading property is a Many in which case just define a Reference for the collection and not invoke a query.
- lazyLoadMany(EntityBeanIntercept, LoadBeanContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- lazyLoadProperty() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the property that invoked lazy load.
- lazyLoadProperty() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- lazyLoadRegister(String, EntityBeanIntercept, EntityBean, LoadContext) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Register all the assoc many properties on this bean that are not populated with the load context.
- le(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- le(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- le(String, Object) - Method in class io.ebeaninternal.server.el.ElFilter
- le(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Less Than or Equal to - property less than or equal to the given value.
- le(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- leIfPresent(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- length() - Method in class io.ebeaninternal.server.deploy.BeanNaturalKey
- length() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Return the current content length.
- length() - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- length() - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- length() - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- length() - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- length(int, Object) - Method in interface io.ebeaninternal.server.deploy.BindMaxLength
-
Return the length of the object.
- length(int, Object) - Method in class io.ebeaninternal.server.deploy.BindMaxLength.Standard
- length(int, Object) - Method in class io.ebeaninternal.server.deploy.BindMaxLength.UTF8
- leOrNull(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- leOrNull(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- leSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- leSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- like(String, Object, boolean, LikeType) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- like(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Like - property like value where the value contains the SQL wild card characters % (percentage) and _ (underscore).
- like(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- LimitOffsetPagedList<T> - Class in io.ebeaninternal.server.query
-
PagedList implementation based on limit offset types of queries.
- LimitOffsetPagedList(SpiEbeanServer, SpiQuery<T>) - Constructor for class io.ebeaninternal.server.query.LimitOffsetPagedList
-
Construct with firstRow/maxRows.
- list - Variable in class io.ebeaninternal.server.expression.DefaultExpressionList
- list() - Method in class io.ebeaninternal.api.BindParams.OrderedList
-
Returns the ordered list of bind parameters.
- LIST - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
Find returning a List.
- LIST - Enum constant in enum io.ebeaninternal.server.deploy.ManyType
- listenerNotify() - Method in class io.ebeaninternal.api.TransactionEvent
-
Return the list of PersistRequestBean's for this transaction.
- listIterator() - Method in class io.ebeaninternal.json.ModifyAwareList
- listIterator(int) - Method in class io.ebeaninternal.json.ModifyAwareList
- literal(SqlJoinType) - Method in enum io.ebeaninternal.server.query.SqlJoinType
-
Return the actual SQL join literal taking into account the current join type and the 'default join type as per deployment cardinality and optionality'.
- load(BeanDescriptor<?>, EntityBean, CachedBeanData, PersistenceContext) - Static method in class io.ebeaninternal.server.cache.CachedBeanDataToBean
- load(BeanProperty) - Method in class io.ebeaninternal.server.query.SqlBeanLoad
- load(BeanProperty, Object) - Method in class io.ebeaninternal.server.query.SqlBeanLoad
-
Load the given value into the property.
- load(SqlBeanLoad) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- load(SqlBeanLoad) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- load(SqlBeanLoad) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- load(SqlBeanLoad) - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- load(SqlBeanLoad) - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Load into the bean (from the DataReader/ResultSet).
- loadBean(EntityBeanIntercept) - Method in class io.ebeaninternal.server.core.DefaultServer
- loadBean(LoadBeanRequest) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Load a batch of Associated One Beans.
- loadBean(LoadBeanRequest) - Method in class io.ebeaninternal.server.core.DefaultServer
- LoadBeanBuffer - Interface in io.ebeaninternal.api
-
A buffer of beans for batch lazy loading and secondary query loading.
- LoadBeanContext - Interface in io.ebeaninternal.api
-
Controls the loading of ManyToOne and OneToOne relationships.
- loadBeanL2(EntityBeanIntercept) - Method in class io.ebeaninternal.server.core.DefaultServer
- loadBeanRef(EntityBeanIntercept) - Method in class io.ebeaninternal.server.core.DefaultServer
- LoadBeanRequest - Class in io.ebeaninternal.api
-
Request for loading ManyToOne and OneToOne relationships.
- LoadBeanRequest(LoadBeanBuffer, EntityBeanIntercept, boolean) - Constructor for class io.ebeaninternal.api.LoadBeanRequest
-
Construct for lazy load request.
- LoadBeanRequest(LoadBeanBuffer, OrmQueryRequest<?>) - Constructor for class io.ebeaninternal.api.LoadBeanRequest
-
Construct for secondary query.
- loadContext() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return the graph context for this query.
- LoadContext - Interface in io.ebeaninternal.api
-
Controls the loading of reference objects for a query instance.
- loadCount() - Method in class io.ebeaninternal.server.query.LimitOffsetPagedList
- loadDescription() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return a more detailed description of the lazy or query load.
- loadDescription() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- loadedProperties() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- loadedProps() - Method in class io.ebeaninternal.server.core.DefaultBeanState
- loadErrors() - Method in class io.ebeaninternal.server.core.DefaultBeanState
- loadIgnore(DbReadContext) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- loadIgnore(DbReadContext) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- loadIgnore(DbReadContext) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- loadIgnore(DbReadContext) - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- loadIgnore(DbReadContext) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Ignore the appropriate number of scalar properties for this id.
- loadIgnore(DbReadContext) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- loadIgnore(DbReadContext) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- loadIgnore(DbReadContext) - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Ignore the property (moving the column index position without reading).
- loadingStarted() - Method in interface io.ebeaninternal.api.LoadBeanBuffer
- loadingStopped() - Method in interface io.ebeaninternal.api.LoadBeanBuffer
- loadMany(BeanCollection<?>, boolean) - Method in class io.ebeaninternal.server.core.DefaultServer
- loadMany(LoadManyRequest) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Lazy load a batch of Many's.
- loadMany(LoadManyRequest) - Method in class io.ebeaninternal.server.core.DefaultServer
- LoadManyBuffer - Interface in io.ebeaninternal.api
-
A buffer of bean collections for batch lazy loading and secondary query loading.
- LoadManyContext - Interface in io.ebeaninternal.api
-
Controls the loading of OneToMany and ManyToMany relationships.
- LoadManyRequest - Class in io.ebeaninternal.api
-
Request for loading Associated Many Beans.
- LoadManyRequest(LoadManyBuffer, boolean, boolean, BeanCollection<?>) - Constructor for class io.ebeaninternal.api.LoadManyRequest
-
Construct for lazy loading.
- LoadManyRequest(LoadManyBuffer, OrmQueryRequest<?>) - Constructor for class io.ebeaninternal.api.LoadManyRequest
-
Construct for secondary query.
- loadMode() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the load mode (+lazy or +query).
- loadMode() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- LoadRequest - Class in io.ebeaninternal.api
-
Request for loading Associated One Beans.
- loadSecondaryQuery(OrmQueryRequest<?>, boolean) - Method in interface io.ebeaninternal.api.LoadSecondaryQuery
-
Execute the secondary query with a given batch size.
- LoadSecondaryQuery - Interface in io.ebeaninternal.api
-
Defines the method for executing secondary queries.
- localEncrypt(Object) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- localEncrypt(Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- localEncrypt(Object) - Method in class io.ebeaninternal.server.el.ElPropertyChain
- localEncrypt(Object) - Method in interface io.ebeaninternal.server.el.ElPropertyValue
-
Encrypt the input value return the encrypted value.
- localEncrypt(Object) - Method in interface io.ebeaninternal.server.type.LocalEncryptedType
-
Encrypt and return the un-encrypted value.
- localEncrypt(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- LocalEncryptedType - Interface in io.ebeaninternal.server.type
-
Scalar type that wraps a local/client side encrypted value.
- localL2Caching() - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- localProperties() - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return the local properties for this node in the hierarchy.
- location() - Method in class io.ebeaninternal.server.query.CQueryPlan
- lock - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- lock(Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- log - Static variable in class io.ebeaninternal.api.CoreLog
- log - Static variable in class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
- log() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return the log manager.
- log() - Method in class io.ebeaninternal.server.core.DefaultServer
- log() - Method in class io.ebeaninternal.server.transaction.TransactionManager
- logger - Static variable in class io.ebeaninternal.server.cache.DefaultServerCache
- logger() - Method in interface io.ebeaninternal.api.SpiLogManager
-
Logger used for general transactions.
- logger() - Method in class io.ebeaninternal.server.transaction.TransactionManager
- loggerReadOnly() - Method in class io.ebeaninternal.server.transaction.TransactionManager
- LOGICAL_NAME - Static variable in class io.ebeaninternal.server.deploy.meta.DeployOrderColumn
-
Logical property name used for order by and available for expression language.
- logSql() - Method in class io.ebeaninternal.server.core.BeanRequest
-
Return true if SQL should be logged for this transaction.
- logSql() - Method in class io.ebeaninternal.server.core.PersistRequest
- logSql(String, Object...) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Log a message to the SQL logger.
- logSql(String, Object...) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- logSql(String, Object...) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Log the SQL if the logLevel is appropriate.
- logSql(String, Object...) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- logSql(String, Object...) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- logSql(String, Object...) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- logSqlBatchBind() - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
-
Log the sql bind used with jdbc batch.
- logSummary() - Method in class io.ebeaninternal.server.core.BeanRequest
-
Return true if SUMMARY information should be logged for this transaction.
- logSummary() - Method in class io.ebeaninternal.server.core.PersistRequest
- logSummary() - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
- logSummary(String, Object...) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Log a summary message to the SUMMARY logger.
- logSummary(String, Object...) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- logSummary(String, Object...) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- logSummary(String, Object...) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- logSummary(String, Object...) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- logTxn(String, Object...) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Log a transaction message to the transaction logger.
- logTxn(String, Object...) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- logTxn(String, Object...) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- logTxn(String, Object...) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- logTxn(String, Object...) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- lruCount - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- lt(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- lt(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- lt(String, Object) - Method in class io.ebeaninternal.server.el.ElFilter
- lt(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Less Than - property less than the given value.
- lt(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- LT - Enum constant in enum io.ebeaninternal.server.expression.Op
-
Less than.
- LT_EQ - Enum constant in enum io.ebeaninternal.server.expression.Op
-
Less than or equal to.
- ltIfPresent(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- ltOrNull(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Less Than or null - property less than the given value or null.
- ltOrNull(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- ltSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- ltSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
M
- m2mIncludeJoin() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the extra join for a M2M lazy load.
- m2mIncludeJoin() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- manyJoin() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- manyType() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return the many type.
- ManyType - Enum in io.ebeaninternal.server.deploy
-
Represents the type of a OneToMany or ManyToMany property.
- manyWhereJoins() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the joins required to support predicates on the many properties.
- manyWhereJoins() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Return the extra joins required to support the where clause for 'Many' properties.
- ManyWhereJoins - Class in io.ebeaninternal.api
-
Holds the joins needs to support the many where predicates.
- ManyWhereJoins() - Constructor for class io.ebeaninternal.api.ManyWhereJoins
- map - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
-
The underlying map (ConcurrentHashMap or similar)
- MAP - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
Find returning a Map.
- MAP - Enum constant in enum io.ebeaninternal.server.deploy.ManyType
- mapEach(RowConsumer) - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
- mapKey() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the property used to specify keys for a map.
- mapKey() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return the default mapKey when returning a Map.
- mapKey() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- mapOne(RowMapper<T>) - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
- mapped - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
The type of index.
- mapped() - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Return true if this type is mapped for doc storage.
- mapped() - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- mappedBy() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return the mappedBy property.
- mapper() - Method in interface io.ebeaninternal.api.json.SpiJsonReader
- mapper() - Method in class io.ebeaninternal.server.json.ReadJson
-
Return the objectMapper used for this request.
- mapTo(RowMapper<T>) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- mapToColumn(String) - Method in class io.ebeaninternal.server.rawsql.DRawSql
- mapToColumn(String) - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping
- mapToColumn(String) - Method in interface io.ebeaninternal.server.rawsql.SpiRawSql
- mapToScalar(Class<T>) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- markAsDeleted(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- markAsDeleted(EntityBean) - Method in interface io.ebeaninternal.server.query.STreeType
-
Mark the bean as deleted by setting the softDelete property to true.
- markAsDirty(Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- markedAsDeleted - Static variable in class io.ebeaninternal.api.CoreLog
- markNotQueryOnly() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Mark the transaction explicitly as not being query only.
- markNotQueryOnly() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- markNotQueryOnly() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Mark the transaction as not being query only.
- markNotQueryOnly() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Mark the underlying transaction as not being query only.
- markNotQueryOnly() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- markNotQueryOnly() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- markNotQueryOnly() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- match(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- match(String, String, Match) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- matchEq(String, Object) - Method in class io.ebeaninternal.api.NaturalKeyQueryData
-
Match for an EQ expression.
- matchIn(String, List<Object>) - Method in class io.ebeaninternal.api.NaturalKeyQueryData
-
Match for IN expression.
- matchInPairs(String, String, List<Pairs.Entry>) - Method in class io.ebeaninternal.api.NaturalKeyQueryData
-
Match for In Pairs expression.
- matchMultiProperties(Set<String>) - Method in class io.ebeaninternal.server.deploy.BeanNaturalKey
-
Return true if all the properties match our natural key.
- matchPlatform(Platform, String) - Static method in class io.ebeaninternal.api.PlatformMatch
-
Return true if the script platforms is a match/supported for the given platform.
- matchProperty(String) - Method in class io.ebeaninternal.server.deploy.BeanNaturalKey
-
Return true if the property name is part of the natural key.
- matchSingleProperty(String) - Method in class io.ebeaninternal.server.deploy.BeanNaturalKey
-
Return true if the given propertyName is our natural key property.
- maxIdleSecs - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- maxRows(int) - Method in class io.ebeaninternal.server.el.ElFilter
- maxSecsToLive - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- maxSize - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- Md5 - Class in io.ebeaninternal.server.util
- Md5() - Constructor for class io.ebeaninternal.server.util.Md5
- merge(EntityBean, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- merge(EntityBean, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- merge(EntityBean, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Copy collection value if existing is empty.
- merge(BeanDescriptor<?>, EntityBean, MergeOptions, SpiTransaction) - Method in interface io.ebeaninternal.server.core.Persister
-
Merge the bean.
- merge(BeanDescriptor<?>, EntityBean, MergeOptions, SpiTransaction) - Method in class io.ebeaninternal.server.persist.DefaultPersister
- merge(Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- merge(Object, MergeOptions) - Method in class io.ebeaninternal.server.core.DefaultServer
- merge(Object, MergeOptions, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- MERGE - Static variable in class io.ebeaninternal.server.persist.Flags
-
Indicates Merge mode.
- mergeCacheHits(BeanCollection<T>) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Merge in prior L2 bean cache hits with the query result.
- metaInfo() - Method in class io.ebeaninternal.server.core.DefaultServer
- metricPersistBatch(PersistRequest.Type, long, int) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- metricPersistNoBatch(PersistRequest.Type, long) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- MILLIS_TO_UUID - Static variable in class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
- missCount - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- mode() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the query mode.
- mode() - Method in interface io.ebeaninternal.api.SpiUpdatePlan
-
Return the concurrency mode for this plan.
- mode() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- mode(PersistRequest.Type, DocStoreMode) - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Determine and return how this persist type will be processed given the transaction mode.
- mode(PersistRequest.Type, DocStoreMode) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- ModifyAwareFlag - Class in io.ebeaninternal.json
-
Detects when content has been modified and as such needs to be persisted (included in an update).
- ModifyAwareFlag() - Constructor for class io.ebeaninternal.json.ModifyAwareFlag
- ModifyAwareIterator<E> - Class in io.ebeaninternal.json
-
Wraps an iterator for the purposes of detecting modifications.
- ModifyAwareIterator(ModifyAwareType, Iterator<E>) - Constructor for class io.ebeaninternal.json.ModifyAwareIterator
-
Create with an Owner and the underlying Iterator this wraps.
- ModifyAwareList<E> - Class in io.ebeaninternal.json
-
Modify aware wrapper of a list.
- ModifyAwareList(ModifyAwareType, List<E>) - Constructor for class io.ebeaninternal.json.ModifyAwareList
- ModifyAwareList(List<E>) - Constructor for class io.ebeaninternal.json.ModifyAwareList
- ModifyAwareListIterator<E> - Class in io.ebeaninternal.json
-
Modify aware wrapper of a ListIterator.
- ModifyAwareListIterator(ModifyAwareType, ListIterator<E>) - Constructor for class io.ebeaninternal.json.ModifyAwareListIterator
- ModifyAwareMap<K,
V> - Class in io.ebeaninternal.json -
Map that is wraps an underlying map for the purpose of detecting changes.
- ModifyAwareMap(ModifyAwareType, Map<K, V>) - Constructor for class io.ebeaninternal.json.ModifyAwareMap
- ModifyAwareMap(Map<K, V>) - Constructor for class io.ebeaninternal.json.ModifyAwareMap
- ModifyAwareSet<E> - Class in io.ebeaninternal.json
-
Wraps a Set for the purposes of detecting modifications.
- ModifyAwareSet(ModifyAwareType, Set<E>) - Constructor for class io.ebeaninternal.json.ModifyAwareSet
-
Create with an Owner that is notified of modifications.
- ModifyAwareSet(Set<E>) - Constructor for class io.ebeaninternal.json.ModifyAwareSet
-
Create as top level with it's own ModifyAwareOwner instance wrapping the given Set.
- ModifyAwareType - Interface in io.ebeaninternal.server.type
- modifyListenMode() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return the mode for listening to modifications to collections for this association.
- multiMatch(String, MultiMatch) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- multiMatch(String, String...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- MultiValueWrapper - Class in io.ebeaninternal.server.persist
-
Wraps the multi values that are used for "property in (...)" queries
- MultiValueWrapper(Collection<?>) - Constructor for class io.ebeaninternal.server.persist.MultiValueWrapper
- MultiValueWrapper(Collection<?>, Class<?>) - Constructor for class io.ebeaninternal.server.persist.MultiValueWrapper
- must() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- mustNot() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- mutable() - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- mutable() - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- mutationCounter - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- MySqlDataTimeZone - Class in io.ebeaninternal.server.core.timezone
-
Implementation of DataTimeZone when single Calendar instance is used with local timezone.
- MySqlDataTimeZone() - Constructor for class io.ebeaninternal.server.core.timezone.MySqlDataTimeZone
N
- name - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- name() - Method in interface io.ebeaninternal.api.SpiQueryPlan
-
The plan name.
- name() - Method in class io.ebeaninternal.server.core.DefaultServer
-
Return the server name.
- name() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the short name of the entity bean.
- name() - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- name() - Method in interface io.ebeaninternal.server.deploy.BeanDescriptorMap
-
Return the name of the server/database.
- name() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- name() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the name of the property.
- name() - Method in class io.ebeaninternal.server.deploy.DCacheRegion
- name() - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- name() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- name() - Method in interface io.ebeaninternal.server.el.ElPropertyDeploy
-
Return the name of the property.
- name() - Method in class io.ebeaninternal.server.query.CQueryPlan
- name() - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Return the property name.
- name() - Method in interface io.ebeaninternal.server.query.STreeType
-
Return the bean short name.
- name() - Method in class io.ebeaninternal.server.transaction.TransactionManager
- name() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyMapping
-
Return the property name.
- name() - Method in class io.ebeanservice.docstore.api.mapping.DocumentMapping
-
Return the name.
- NamedParameter - Class in io.ebeaninternal.server.grammer
- NamedParameter(String) - Constructor for class io.ebeaninternal.server.grammer.NamedParameter
- namedQuery(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the named ORM query.
- namedRawSql(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the named RawSql query.
- namingConvention() - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- namingConvention() - Method in interface io.ebeaninternal.server.deploy.BeanDescriptorMap
-
Return the naming convention.
- Native() - Constructor for class io.ebeaninternal.server.type.ScalarTypeBoolean.Native
-
Native Boolean database type.
- nativeSql() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the unmodified native sql query (with named params etc).
- nativeSql() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- NativeSqlQueryPlanKey - Class in io.ebeaninternal.server.query
-
QueryPlanKey for native sql queries.
- NativeSqlQueryPlanKey(String) - Constructor for class io.ebeaninternal.server.query.NativeSqlQueryPlanKey
- naturalKey() - Method in interface io.ebeaninternal.api.SpiQuery
-
Collect natural key data for this query or null if the query does not match the requirements of natural key lookup.
- naturalKey() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the natural key.
- naturalKey() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- naturalKey(NaturalKeyQueryData<?>) - Method in interface io.ebeaninternal.api.SpiExpression
-
Check for match to a natural key query returning false if it doesn't match.
- naturalKey(NaturalKeyQueryData<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- naturalKey(NaturalKeyQueryData<?>) - Method in class io.ebeaninternal.server.expression.InExpression
- naturalKey(NaturalKeyQueryData<?>) - Method in class io.ebeaninternal.server.expression.IdInExpression
- naturalKey(NaturalKeyQueryData<?>) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- naturalKeyBindParam() - Method in class io.ebeaninternal.api.BindParams
-
Return a Natural Key bind param if supported.
- naturalKeyBindParam() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return a Natural Key bind parameter if supported by this query.
- naturalKeyBindParam() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- NaturalKeyBindParam - Class in io.ebeaninternal.server.querydefn
- NaturalKeyBindParam(String, Object) - Constructor for class io.ebeaninternal.server.querydefn.NaturalKeyBindParam
- naturalKeyCache(Class<?>) - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- NaturalKeyEntry - Interface in io.ebeaninternal.api
-
An entry for natural key lookup.
- NaturalKeyEq - Class in io.ebeaninternal.api
-
A property value pair in a natural key lookup.
- NaturalKeyEq(String, Object) - Constructor for class io.ebeaninternal.api.NaturalKeyEq
- naturalKeyLookup(PersistenceContext, Set<Object>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Use natural key lookup to hit the bean cache.
- NaturalKeyQueryData<T> - Class in io.ebeaninternal.api
-
Collects the data for processing the natural key cache processing.
- NaturalKeyQueryData(BeanNaturalKey) - Constructor for class io.ebeaninternal.api.NaturalKeyQueryData
- NaturalKeySet - Class in io.ebeaninternal.api
- ne(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- ne(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- ne(String, Object) - Method in class io.ebeaninternal.server.el.ElFilter
- ne(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Not Equal To - property not equal to the given value.
- ne(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- nestedEvents() - Method in class io.ebeanservice.docstore.api.DocStoreUpdates
-
Return the list of nested update events.
- nestedPath(BeanDescriptor<?>) - Method in interface io.ebeaninternal.api.SpiExpression
-
Return the nested path for this expression.
- nestedPath(BeanDescriptor<?>) - Method in class io.ebeaninternal.server.expression.InExpression
- nestedPath(BeanDescriptor<?>) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- nestedPath(BeanDescriptor<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- nestedPath(BeanDescriptor<?>) - Method in class io.ebeaninternal.server.expression.IdInExpression
- neSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- neSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- newQuery(SpiEbeanServer) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Create a new query for the target type.
- next() - Method in class io.ebeaninternal.json.ModifyAwareIterator
- next() - Method in class io.ebeaninternal.json.ModifyAwareListIterator
- next() - Method in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
-
Return true if we can navigate to the next row.
- next() - Method in class io.ebeaninternal.server.core.DtoQueryRequest
- next() - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
- next() - Method in class io.ebeaninternal.server.type.RsetDataReader
- nextId(Transaction) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- nextId(Transaction) - Method in class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
-
Return UUID from UUID.randomUUID();
- nextId(Transaction) - Method in class io.ebeaninternal.server.idgen.UuidV4IdGenerator
-
Return UUID from UUID.randomUUID();
- nextId(Class<?>) - Method in class io.ebeaninternal.server.core.DefaultServer
- nextIndex() - Method in class io.ebeaninternal.json.ModifyAwareListIterator
- nextParameter() - Method in interface io.ebeaninternal.api.SpiExpressionRequest
-
Increments the parameter index and returns that value.
- nextParameter() - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
-
Increments the parameter index and returns that value.
- nextToken() - Method in interface io.ebeaninternal.api.json.SpiJsonReader
- nextToken() - Method in class io.ebeaninternal.server.json.ReadJson
-
Return the next JsonToken from the underlying parser.
- nextWord() - Method in class io.ebeaninternal.server.querydefn.SimpleTextParser
- NO_CACHING - Static variable in class io.ebeaninternal.server.core.CacheOptions
-
Instance when no caching is used.
- NoAutoTuneService - Class in io.ebeaninternal.server.autotune
-
Noop service when AutoTuneService is not available.
- NoAutoTuneService() - Constructor for class io.ebeaninternal.server.autotune.NoAutoTuneService
- NoDataTimeZone - Class in io.ebeaninternal.server.core.timezone
-
Implementation of DataTimeZone when no time zone is specified.
- NoDataTimeZone() - Constructor for class io.ebeaninternal.server.core.timezone.NoDataTimeZone
- NONE - Enum constant in enum io.ebeaninternal.api.ConcurrencyMode
-
No concurrency checking.
- NONE - Static variable in class io.ebeaninternal.server.deploy.IdentityMode
- NOOP - Static variable in interface io.ebeaninternal.api.QueryPlanManager
- NOOP - Static variable in interface io.ebeaninternal.api.SpiQueryBindCapture
-
NOOP implementation.
- NoopProfileHandler - Class in io.ebeaninternal.server.transaction
-
A do nothing SpiProfileHandler.
- NoopProfileHandler() - Constructor for class io.ebeaninternal.server.transaction.NoopProfileHandler
- NORMAL - Enum constant in enum io.ebeaninternal.api.SpiQuery.Mode
- NORMAL - Static variable in class io.ebeaninternal.server.persist.Flags
-
Indicates Normal insert or update (not forced).
- norms() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- norms(Boolean) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- not() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- not(Expression) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Negate the expression (prefix it with NOT).
- not(Expression) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- NOT_EQ - Enum constant in enum io.ebeaninternal.server.expression.Op
-
Not equal to.
- NOT_EXISTS - Enum constant in enum io.ebeaninternal.server.expression.Op
-
Not Exists (JSON).
- notExists(Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Not exists subquery
- notExists(Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- notExists(String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
In - using a subQuery.
- notExists(String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- notify(ServerCacheNotification) - Method in class io.ebeaninternal.server.transaction.TableModState
-
Update the table modification timestamps based on remote table modification events.
- notify(RemoteTableMod) - Method in class io.ebeaninternal.server.transaction.TableModState
-
Update from Remote transaction event.
- notifyBindCapture(CQueryBindCapture, long) - Method in class io.ebeaninternal.server.query.CQueryPlanManager
- notifyCache(CacheChangeSet) - Method in class io.ebeaninternal.server.transaction.BeanPersistIds
-
Notify the cache of this event that came from another server in the cluster.
- notifyCache(CacheChangeSet) - Method in class io.ebeaninternal.server.transaction.DeleteByIdMap
- notifyCommit() - Method in interface io.ebeaninternal.api.SpiTxnLogger
-
Transaction Committed.
- notifyLocalPersistListener() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- notifyOfCommit(SpiTransaction) - Method in interface io.ebeaninternal.api.SpiTransactionManager
-
Notify of a transaction commit.
- notifyOfCommit(SpiTransaction) - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Process a local committed transaction.
- notifyOfQueryOnly(SpiTransaction) - Method in interface io.ebeaninternal.api.SpiTransactionManager
-
Notify of a query only transaction commit.
- notifyOfQueryOnly(SpiTransaction) - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Query only transaction in read committed isolation.
- notifyOfRollback(SpiTransaction, Throwable) - Method in interface io.ebeaninternal.api.SpiTransactionManager
-
Notify of a transaction rollback.
- notifyOfRollback(SpiTransaction, Throwable) - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Process a local rolled back transaction.
- notifyQueryOnly() - Method in interface io.ebeaninternal.api.SpiTxnLogger
-
Query only transaction completed.
- notifyRollback(Throwable) - Method in interface io.ebeaninternal.api.SpiTxnLogger
-
Transaction Rolled back.
- notIn(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
In - using a subQuery.
- notIn(String, Query<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- notIn(String, Object[]) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
In - property has a value in the array of values.
- notIn(String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- notIn(String, Collection<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Not In - property has a value in the collection of values.
- notIn(String, Collection<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- notInSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- notInSubQuery(String, String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- now() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Use a common 'now' value across both when created and when updated etc.
- nowMillis() - Method in class io.ebeaninternal.server.core.ClockService
-
Return the Clock current timestamp in millis.
- nullValue() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- nullValue(String) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
O
- objectGraphNode() - Method in interface io.ebeaninternal.api.LoadManyBuffer
- objectGraphNode(String) - Method in interface io.ebeaninternal.api.LoadContext
-
Return the node for a given path which is used by AutoTune profiling.
- obtain() - Method in interface io.ebeanservice.docstore.api.DocStoreTransaction
-
Obtain a context to persist to (like a buffer).
- obtainCacheChangeSet() - Method in class io.ebeaninternal.api.TransactionEvent
-
Return the CacheChangeSet that we add cache notification messages to.
- obtainLocation() - Method in interface io.ebeaninternal.api.SpiDtoQuery
-
Obtain the location if necessary.
- obtainLocation() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- of(SpiQuery<?>) - Static method in enum io.ebeaninternal.api.SpiQuery.TemporalMode
-
Return the mode of the query of if null return CURRENT mode.
- of(Class<T>) - Method in class io.ebeaninternal.server.query.DFetchGroupService
- of(Class<T>, String) - Method in class io.ebeaninternal.server.query.DFetchGroupService
- offset() - Method in class io.ebeaninternal.server.transaction.DefaultProfileStream
-
Return the time offset from the beginning of the transaction.
- offset() - Method in interface io.ebeaninternal.server.transaction.ProfileStream
-
Return the offset in micros from the start of the transaction.
- ofStandard() - Static method in interface io.ebeaninternal.server.deploy.BindMaxLength
-
Return a standard implementation.
- ofUtf8() - Static method in interface io.ebeaninternal.server.deploy.BindMaxLength
-
Return a UTF8 based implementation.
- online(boolean) - Method in class io.ebeaninternal.server.transaction.DefaultProfileHandler
- Op - Enum in io.ebeaninternal.server.expression
-
Simple operators - equals, greater than, less than etc.
- options() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyMapping
-
Return the property options.
- options() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- options(DocProperty.Option) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- or() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- or(Expression, Expression) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Or - join two expressions with a logical or.
- or(Expression, Expression) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- OracleDataTimeZone - Class in io.ebeaninternal.server.core.timezone
-
Implementation of DataTimeZone that clones the Calendar instance.
- OracleDataTimeZone(String) - Constructor for class io.ebeaninternal.server.core.timezone.OracleDataTimeZone
- orderBy() - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Return the default order by that may need to be used if the query includes a many property.
- orderBy() - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- orderBy() - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- orderBy() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- orderBy() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- orderBy() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- orderBy(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- orderBy(String) - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- orderBy(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- orderBy(String, boolean) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
- orderBy(String, boolean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- orderBy(String, boolean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- orderById(boolean) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- orderById(boolean) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- orderByIsEmpty() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if there is no Order By clause.
- orderByIsEmpty() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- orderColumn() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the order column property.
- OrderedList(List<BindParams.Param>) - Constructor for class io.ebeaninternal.api.BindParams.OrderedList
- origValue(BeanProperty) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the original / old value for the given property.
- ORM - Enum constant in enum io.ebeaninternal.server.deploy.BeanDescriptor.EntityType
- ormQuery() - Method in interface io.ebeaninternal.api.SpiDtoQuery
-
Return an underlying ORM query (if this query is built from an ORM query).
- ormQuery() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- OrmQueryDetail - Class in io.ebeaninternal.server.querydefn
-
Represents the internal structure of an Object Relational query.
- OrmQueryDetail() - Constructor for class io.ebeaninternal.server.querydefn.OrmQueryDetail
- OrmQueryDetailParser - Class in io.ebeaninternal.server.querydefn
-
Parses a Object relational query statement into a OrmQueryDetail and OrmQueryAttributes.
- OrmQueryDetailParser(String) - Constructor for class io.ebeaninternal.server.querydefn.OrmQueryDetailParser
- OrmQueryEngine - Interface in io.ebeaninternal.server.core
-
The Object Relational query execution API.
- OrmQueryLimitRequest - Class in io.ebeaninternal.server.querydefn
- OrmQueryLimitRequest(String, String, SpiQuery<?>, DatabasePlatform, boolean) - Constructor for class io.ebeaninternal.server.querydefn.OrmQueryLimitRequest
- OrmQueryLimitRequest(String, String, SpiQuery<?>, DatabasePlatform, boolean, String, String, String) - Constructor for class io.ebeaninternal.server.querydefn.OrmQueryLimitRequest
- OrmQueryProperties - Class in io.ebeaninternal.server.querydefn
-
Represents the Properties of an Object Relational query.
- OrmQueryProperties() - Constructor for class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Construct for root so path (and parentPath) are null.
- OrmQueryProperties(String) - Constructor for class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Construct with a given path.
- OrmQueryProperties(String, String) - Constructor for class io.ebeaninternal.server.querydefn.OrmQueryProperties
- OrmQueryProperties(String, String, FetchConfig) - Constructor for class io.ebeaninternal.server.querydefn.OrmQueryProperties
- OrmQueryProperties(String, Set<String>) - Constructor for class io.ebeaninternal.server.querydefn.OrmQueryProperties
- OrmQueryRequest<T> - Class in io.ebeaninternal.server.core
-
Wraps the objects involved in executing a Query.
- OrmQueryRequest(SpiEbeanServer, OrmQueryEngine, SpiQuery<T>, SpiTransaction) - Constructor for class io.ebeaninternal.server.core.OrmQueryRequest
- ormUpdate() - Method in class io.ebeaninternal.server.core.PersistRequestOrmUpdate
-
Return the UpdateSql.
- OrmUpdateProperties - Class in io.ebeaninternal.server.querydefn
-
Set properties for a UpdateQuery.
- OrmUpdateProperties() - Constructor for class io.ebeaninternal.server.querydefn.OrmUpdateProperties
- OrmUpdateProperties.Value - Class in io.ebeaninternal.server.querydefn
-
Bind value used in the set clause for update query.
- ormUpdateType() - Method in interface io.ebeaninternal.api.SpiUpdate
-
Return the type of this - insert, update or delete.
- ormUpdateType() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- os() - Method in class io.ebeaninternal.api.BinaryWriteContext
-
Return the output stream to write to.
- OUTER - Enum constant in enum io.ebeaninternal.server.query.SqlJoinType
-
It is an outer join.
- outValue() - Method in class io.ebeaninternal.api.BindParams.Param
-
Return the OUT value that was retrieved.
- override(BeanPropertyOverride) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- override(BeanPropertyOverride) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- override(BeanPropertyOverride) - Method in class io.ebeaninternal.server.deploy.BeanPropertyJsonBasic
- override(BeanPropertyOverride) - Method in class io.ebeaninternal.server.deploy.BeanPropertyJsonMapper
P
- padIds(List<Object>) - Static method in class io.ebeaninternal.server.core.BindPadding
-
Pad out the Ids into common bucket sizes.
- Param() - Constructor for class io.ebeaninternal.api.BindParams.Param
-
Construct a Parameter.
- parameter(int) - Method in class io.ebeaninternal.api.BindParams
-
Return the Parameter for a given position.
- parameter(String) - Method in class io.ebeaninternal.api.BindParams
-
Return the named parameter.
- parentBean() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the parent bean for cascading save with unidirectional relationship.
- parentBean(Object) - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
Return true if the value is a parent bean.
- parentBean(Object) - Method in class io.ebeaninternal.server.json.WriteJson
- parentId(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- parentNode() - Method in interface io.ebeaninternal.api.SpiQuery
-
Used to hook back a lazy loading query to the original query (query point).
- parentNode() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- parentRequest - Variable in class io.ebeaninternal.api.LoadRequest
- parse() - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetailParser
- parse(JsonParser) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json and return as a List or Map.
- parse(BindParams, String) - Static method in class io.ebeaninternal.server.util.BindParamsParser
- parse(BindParams, String, BeanDescriptor<?>) - Static method in class io.ebeaninternal.server.util.BindParamsParser
- parse(Reader) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json and return as a List or Map.
- parse(String) - Method in interface io.ebeaninternal.api.SpiExpressionRequest
-
Append to the expression sql with logical property parsing to db columns with logical path prefix.
- parse(String) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json and return as a List or Map.
- parse(String) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the value from String format into Object value.
- parse(String) - Method in class io.ebeaninternal.server.deploy.DeployParser
- parse(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Parse the aggregation formula into expressions with table alias placeholders.
- parse(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- parse(String) - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.BooleanBase
- parse(String) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesBase
- parse(String) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- parse(String) - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- parse(String) - Method in class io.ebeaninternal.server.type.ScalarTypeString
- parse(String) - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- parse(String) - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- parse(String) - Static method in class io.ebeaninternal.server.util.DSelectColumnsParser
- parse(String, SpiQuery<T>) - Static method in class io.ebeaninternal.server.grammer.EqlParser
-
Parse the raw EQL query and apply it to the supplied query.
- parseAggregation() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Get the parsed aggregation formula with table alias placeholders.
- parseBindParams(String) - Method in class io.ebeaninternal.server.query.CQueryPredicates
- parsed(String) - Method in class io.ebeaninternal.server.rawsql.DRawSqlService
- parseDeploy(String) - Method in interface io.ebeaninternal.api.SpiExpressionRequest
-
Parse the logical property name to the deployment name.
- parseDeploy(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- parseList(JsonParser) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json and return as a List taking a JsonParser.
- parseList(JsonParser, JsonToken) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json returning as a List taking into account the current token.
- parseList(Reader) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json and return as a List taking a Reader.
- parseList(String) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json and return as a List.
- parseList(String, boolean) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json and return as a modify aware List.
- parseObject(JsonParser) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json and return as a Map taking a JsonParser.
- parseObject(JsonParser, JsonToken) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json and return as a Map taking a JsonParser and a starting token.
- parseObject(Reader) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json and return as a Map taking a reader.
- parseObject(Reader, boolean) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json and return as a Map taking a reader.
- parseObject(String) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json and return as a Map.
- parseObject(String, boolean) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json and return as a Map additionally specifying if the returned map should be modify aware meaning that it can detect when it has been modified.
- parser() - Method in interface io.ebeaninternal.api.json.SpiJsonReader
- parser() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- parser() - Method in class io.ebeaninternal.server.json.ReadJson
-
Return the JsonParser.
- parseSet(JsonParser, JsonToken) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json returning as a Set taking into account the current token.
- parseSet(String, boolean) - Method in class io.ebeaninternal.json.DJsonService
-
Parse the json returning a Set that might be modify aware.
- parseWhere(String, ExpressionList<T>, ExpressionFactory, Object[]) - Static method in class io.ebeaninternal.server.grammer.EqlParser
- partialKey() - Method in interface io.ebeaninternal.api.CQueryPlanKey
-
Used by read audit such that we can log read audit entries without the full sql (which would make the read audit logs verbose).
- partialKey() - Method in class io.ebeaninternal.server.query.NativeSqlQueryPlanKey
-
Return as a partial key.
- partitionMeta() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the partition details of the bean.
- PartitionMeta - Class in io.ebeaninternal.server.deploy
- PartitionMeta(PartitionMode, String) - Constructor for class io.ebeaninternal.server.deploy.PartitionMeta
- path - Variable in class io.ebeanservice.docstore.api.support.DocStoreEmbeddedInvalidation
- path() - Method in interface io.ebeaninternal.api.SpiQueryManyJoin
-
The full path of the many property to include in the query via join.
- path() - Method in interface io.ebeaninternal.server.el.ElPropertyDeploy
- pathGet(Object) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- pathGet(Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- pathGet(Object) - Method in class io.ebeaninternal.server.el.ElPropertyChain
- pathGetNested(Object) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- pathGetNested(Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- pathGetNested(Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- pathGetNested(Object) - Method in class io.ebeaninternal.server.el.ElPropertyChain
- pathGetNested(Object) - Method in interface io.ebeaninternal.server.el.ElPropertyValue
-
Return the value ensuring objects prior to the top scalar property are automatically populated.
- pathMap(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- pathMap(String) - Method in interface io.ebeaninternal.server.query.STreeType
-
Return the "path map" to toMany or toOne properties using the given prefix.
- pathProps - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- paths() - Method in class io.ebeanservice.docstore.api.mapping.DocumentMapping
-
Return the document structure as PathProperties.
- pathSet(Object, Object) - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- pathSet(Object, Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- pathSet(Object, Object) - Method in class io.ebeaninternal.server.el.ElPropertyChain
- pathStack - Variable in class io.ebeanservice.docstore.api.mapping.DocPropertyAdapter
- PathStack - Class in io.ebeaninternal.server.json
- PathStack() - Constructor for class io.ebeaninternal.server.json.PathStack
- peek() - Method in class io.ebeaninternal.server.util.ArrayStack
-
Returns the object at the top of this stack without removing it.
- peekFullPath(String) - Method in class io.ebeaninternal.server.json.PathStack
- peekTableAlias() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Peek the current table alias.
- peekWithNull() - Method in class io.ebeaninternal.server.util.ArrayStack
-
Returns the object at the top of this stack without removing it.
- performCommit() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- performRollback() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- periodicTrim(BackgroundExecutor) - Method in class io.ebeaninternal.server.cache.DefaultServerCache
- persistBeans - Variable in class io.ebeaninternal.server.transaction.TransactionProfile.Summary
- persistController() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the Controller.
- persistCount - Variable in class io.ebeaninternal.server.transaction.TransactionProfile.Summary
- PersistDeferredRelationship - Class in io.ebeaninternal.server.core
-
Deferred update of a relationship where an Id value is not initially available so instead we execute this later as a SqlUpdate statement.
- PersistDeferredRelationship(SpiEbeanServer, BeanDescriptor<?>, EntityBean, ImportedId, EntityBean) - Constructor for class io.ebeaninternal.server.core.PersistDeferredRelationship
- persistenceContext() - Method in interface io.ebeaninternal.api.json.SpiJsonReader
- persistenceContext() - Method in interface io.ebeaninternal.api.LoadBeanBuffer
- persistenceContext() - Method in interface io.ebeaninternal.api.LoadContext
-
Return the persistence context used by this query and future lazy loading.
- persistenceContext() - Method in interface io.ebeaninternal.api.LoadManyBuffer
- persistenceContext() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the TransactionContext.
- persistenceContext() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the persistence context associated with this transaction.
- persistenceContext() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- persistenceContext() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return the PersistenceContext used for this request.
- persistenceContext() - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Return the persistence context.
- persistenceContext() - Method in class io.ebeaninternal.server.json.ReadJson
-
Return the persistence context being used if any.
- persistenceContext() - Method in class io.ebeaninternal.server.query.CQuery
-
Return the persistence context.
- persistenceContext() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Return the TransactionContext.
- persistenceContext() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Return the persistence context associated with this transaction.
- persistenceContext() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Return the persistence context associated with this transaction.
- persistenceContext() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Return the persistence context associated with this transaction.
- persistenceContextPut(Object, T) - Method in interface io.ebeaninternal.api.json.SpiJsonReader
- persistenceContextPut(Object, T) - Method in class io.ebeaninternal.server.json.DJsonBeanReader
- persistenceContextPut(Object, T) - Method in class io.ebeaninternal.server.json.ReadJson
-
Add the bean to the persistence context.
- persistenceContextPutIfAbsent(Object, EntityBean, BeanDescriptor<?>) - Method in interface io.ebeaninternal.api.json.SpiJsonReader
- persistenceContextPutIfAbsent(Object, EntityBean, BeanDescriptor<?>) - Method in class io.ebeaninternal.server.json.ReadJson
-
Put the bean into the persistence context.
- persistenceContextScope() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the PersistenceContextScope that this query should use.
- persistenceContextScope() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- persistenceContextScope(SpiQuery<?>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return the PersistenceContextScope to use defined at query or server level.
- persistenceContextScope(SpiQuery<?>) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Return the PersistenceContextScope to use defined at query or server level.
- PersistenceContextUtil - Class in io.ebeaninternal.server.deploy
-
Utility to find the root bean type.
- PersistenceContextUtil() - Constructor for class io.ebeaninternal.server.deploy.PersistenceContextUtil
- Persister - Interface in io.ebeaninternal.server.core
-
API for persisting a bean.
- persistEvents() - Method in class io.ebeanservice.docstore.api.DocStoreUpdates
-
Return the persist insert and update requests to be sent to the document store.
- PersistExecute - Interface in io.ebeaninternal.server.persist
-
The actual execution of persist requests.
- persistListener() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the beanListener.
- persistMicros - Variable in class io.ebeaninternal.server.transaction.TransactionProfile.Summary
- persistOneCount - Variable in class io.ebeaninternal.server.transaction.TransactionProfile.Summary
- PersistRequest - Class in io.ebeaninternal.server.core
-
Wraps all the objects used to persist a bean.
- PersistRequest.Type - Enum in io.ebeaninternal.server.core
- PersistRequestBean<T> - Class in io.ebeaninternal.server.core
-
PersistRequest for insert update or delete of a bean.
- PersistRequestBean(SpiEbeanServer, T, Object, BeanManager<T>, SpiTransaction, PersistExecute, PersistRequest.Type, int) - Constructor for class io.ebeaninternal.server.core.PersistRequestBean
- PersistRequestCallableSql - Class in io.ebeaninternal.server.core
-
Persist request specifically for CallableSql.
- PersistRequestCallableSql(SpiEbeanServer, CallableSql, SpiTransaction, PersistExecute) - Constructor for class io.ebeaninternal.server.core.PersistRequestCallableSql
-
Create.
- PersistRequestOrmUpdate - Class in io.ebeaninternal.server.core
-
Persist request specifically for CallableSql.
- PersistRequestOrmUpdate(SpiEbeanServer, BeanManager<?>, SpiUpdate<?>, SpiTransaction, PersistExecute) - Constructor for class io.ebeaninternal.server.core.PersistRequestOrmUpdate
- PersistRequestUpdateSql - Class in io.ebeaninternal.server.core
-
Persist request specifically for CallableSql.
- PersistRequestUpdateSql(SpiEbeanServer, SpiSqlUpdate, SpiTransaction, PersistExecute) - Constructor for class io.ebeaninternal.server.core.PersistRequestUpdateSql
- PersistRequestUpdateSql(SpiEbeanServer, SpiSqlUpdate, SpiTransaction, PersistExecute, boolean) - Constructor for class io.ebeaninternal.server.core.PersistRequestUpdateSql
- PersistRequestUpdateSql.SqlType - Enum in io.ebeaninternal.server.core
- persistType() - Method in enum io.ebeaninternal.server.persist.DeleteMode
- planCollect() - Method in class io.ebeaninternal.api.ExtraMetrics
-
Timed metric for query plan collection.
- planKey() - Method in interface io.ebeaninternal.api.SpiDtoQuery
-
Return the key for query plan.
- planKey() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- planLabel() - Method in interface io.ebeaninternal.api.SpiDtoQuery
-
Return the label with fallback to profile location label.
- planLabel() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the label manually set on the query or from the profile location.
- planLabel() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- planLabel() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- platform() - Method in class io.ebeaninternal.server.core.DefaultServer
- PlatformArrayTypeFactory - Interface in io.ebeaninternal.server.type
-
Factory for platform specific handling/ScalarTypes for DB ARRAY.
- platformHandler() - Method in interface io.ebeaninternal.api.SpiExpressionRequest
-
Return the DB specific handler for JSON and ARRAY expressions.
- platformHandler() - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- PlatformMatch - Class in io.ebeaninternal.api
- PlatformMatch() - Constructor for class io.ebeaninternal.api.PlatformMatch
- plugin(T) - Method in class io.ebeaninternal.server.core.InternalConfiguration
-
Check if this is a SpiServerPlugin and if so 'collect' it to give the complete list later on the DefaultServer for late call to configure().
- pluginApi() - Method in class io.ebeaninternal.server.core.DefaultServer
- pop() - Method in class io.ebeaninternal.server.util.ArrayStack
-
Removes the object at the top of this stack and returns that object as the value of this function.
- pop() - Method in class io.ebeanservice.docstore.api.mapping.DocMappingBuilder
-
Pop the nested object or list off the properties stack.
- popJoin() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Pop a join node off the stack.
- popJson() - Method in class io.ebeaninternal.server.type.RsetDataReader
- popParentBeanMany() - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
Pop the parent of a ToMany.
- popParentBeanMany() - Method in class io.ebeaninternal.server.json.WriteJson
- popPath() - Method in interface io.ebeaninternal.api.json.SpiJsonReader
- popPath() - Method in class io.ebeaninternal.server.json.ReadJson
-
Pop the path stack.
- popTableAlias() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Pop the current table alias from the stack.
- pos - Variable in class io.ebeaninternal.server.type.RsetDataReader
- pos() - Method in class io.ebeaninternal.server.type.RsetDataReader
- pos() - Method in class io.ebeaninternal.server.type.RsetDataReaderIndexed
- positionedParameters() - Method in class io.ebeaninternal.api.BindParams
-
Return the values of ordered parameters.
- postAnnotations() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- postCommit() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Fire post commit events and listeners.
- postCommit() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- postCommit() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- postCommit() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- postCommit() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- postCommit() - Method in class io.ebeaninternal.server.transaction.TChangeLogHolder
-
On post commit send the changes we have collected.
- postConstruct(Object) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPostConstructListener
-
Fire postLoad on all registered BeanPostCreate implementations.
- postCreate(Object) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPostConstructListener
- postDelete(BeanPersistRequest<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistController
- postExecute() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Post processing.
- postExecute() - Method in class io.ebeaninternal.server.core.PersistRequestCallableSql
-
Perform post execute processing for the CallableSql.
- postExecute() - Method in class io.ebeaninternal.server.core.PersistRequestOrmUpdate
-
Perform post execute processing.
- postExecute() - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
-
Perform post execute processing.
- postExecute() - Method in interface io.ebeaninternal.server.persist.BatchPostExecute
-
Execute the post execute processing.
- postInsert(BeanPersistRequest<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistController
- postLoad() - Method in class io.ebeaninternal.api.LoadManyRequest
-
After the query execution check for empty collections and load L2 cache if desired.
- postLoad(Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Execute the postLoad if a BeanPostLoad exists for this bean.
- postLoad(Object) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPostLoad
-
Fire postLoad on all registered BeanPostLoad implementations.
- postLoad(Object) - Method in interface io.ebeaninternal.server.query.STreeType
-
Invoke any post load listeners.
- postLoad(List<?>) - Method in class io.ebeaninternal.api.LoadBeanRequest
-
Load the beans into the L2 cache if that is requested and check for load failures due to deletes.
- postRollback() - Method in class io.ebeaninternal.server.transaction.TChangeLogHolder
-
On post rollback send the changes we have collected and leave it up to the listener to decide what to do.
- postRollback(Throwable) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Fire post rollback events and listeners.
- postRollback(Throwable) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- postRollback(Throwable) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- postRollback(Throwable) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- postRollback(Throwable) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- postSoftDelete(BeanPersistRequest<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistController
- postUpdate(BeanPersistRequest<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistController
- preAllocateIds(int) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- preAllocateIds(int) - Method in class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
-
Ignored for UUID as not required as a performance optimisation.
- preAllocateIds(int) - Method in class io.ebeaninternal.server.idgen.UuidV4IdGenerator
-
Ignored for UUID as not required as a performance optimisation.
- preCommit() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Fire pre commit processing/listeners.
- preCommit() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- preCommit() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- preCommit() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- preCommit() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- preCommit() - Method in class io.ebeaninternal.server.transaction.TChangeLogHolder
-
Send the changes held prior to transaction commit.
- preDelete(BeanDeleteIdRequest) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistController
- preDelete(BeanPersistRequest<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistController
- predicates() - Method in class io.ebeaninternal.server.query.CQuery
- preElementCollectionUpdate() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Ensure the preUpdate event fires (for case where only element collection has changed).
- PREFIX - Static variable in interface io.ebeaninternal.server.core.EncryptAlias
- PREFIX - Static variable in class io.ebeaninternal.server.grammer.NamedParameter
- prefixProperty(String) - Method in interface io.ebeaninternal.api.SpiExpression
-
Apply property prefix when filterMany expressions included into main query.
- prefixProperty(String) - Method in class io.ebeaninternal.server.expression.InExpression
- prefixProperty(String) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- prefixProperty(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- prefixProperty(String) - Method in class io.ebeaninternal.server.expression.IdInExpression
- preGetterTrigger(int) - Method in class io.ebeaninternal.server.core.PersistRequestBean
- preInsert(BeanPersistRequest<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistController
- prepare(boolean) - Method in class io.ebeaninternal.server.query.CQueryPredicates
- prepare(SpiOrmQueryRequest<T>) - Method in interface io.ebeaninternal.api.SpiQuery
-
Prepare the query which prepares sub-query expressions and calculates and returns the query plan key.
- prepare(SpiOrmQueryRequest<T>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Prepare the query which prepares any expressions (sub-query expressions etc) and calculates the query plan key.
- prepareDocNested() - Method in interface io.ebeaninternal.api.SpiQuery
-
Prepare the query for docstore execution with nested paths.
- prepareDocNested() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- prepareDocNested(BeanDescriptor<T>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Prepare expressions for document store nested path handling.
- preparedSql() - Method in class io.ebeaninternal.api.BindParams
-
Return the sql with ?
- prepareExpression(BeanQueryRequest<?>) - Method in interface io.ebeaninternal.api.SpiExpression
-
Prepare the expression.
- prepareExpression(BeanQueryRequest<?>) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- prepareExpression(BeanQueryRequest<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- prepareExpression(BeanQueryRequest<?>) - Method in class io.ebeaninternal.server.expression.IdInExpression
- prepareExpression(BeanQueryRequest<?>) - Method in class io.ebeaninternal.server.expression.InExpression
- prepareExpressions(BeanQueryRequest<?>) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Prepare filterMany expressions that are being included into the main query.
- prepareExpressions(BeanQueryRequest<?>) - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Prepare filterMany expressions for query plan key.
- prepareMany(BeanDescriptor<T>) - Method in class io.ebeanservice.docstore.api.support.DocStructure
-
For 'many' nested properties we need an additional root based graph to fetch and update.
- prepareQuery() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Prepare the query and calculate the query plan key.
- prepareQuery() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Prepare the query for execution.
- prepareQuery(SpiQuery<T>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Prepare the query for multi-tenancy check for document store only use.
- preQuery(BeanQueryRequest<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanQueryAdapter
- preSoftDelete(BeanPersistRequest<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistController
- preUpdate(BeanPersistRequest<?>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistController
- previous() - Method in class io.ebeaninternal.json.ModifyAwareListIterator
- previousIndex() - Method in class io.ebeaninternal.json.ModifyAwareListIterator
- primaryKeyJoin() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- process(BulkTableEvent) - Method in class io.ebeaninternal.server.transaction.BulkEventListenerMap
- process(DocStoreUpdates, int) - Method in interface io.ebeanservice.docstore.api.DocStoreUpdateProcessor
-
Process all the updates for a transaction.
- processViewInvalidation(Set<String>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Invalidate entity beans based on views via their dependent tables.
- profile() - Method in interface io.ebeaninternal.api.SpiProfileTransactionEvent
-
Add the event information to the profiling transaction.
- profile() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Add to profile as single bean insert, update or delete (not batched).
- profile() - Method in class io.ebeaninternal.server.persist.BatchedPstmt
- profile() - Method in class io.ebeaninternal.server.query.CQuery
- profile(long, int) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Add to profile as batched bean insert, update or delete.
- profile(long, int) - Method in class io.ebeaninternal.server.core.PersistRequestCallableSql
- profile(long, int) - Method in class io.ebeaninternal.server.core.PersistRequestOrmUpdate
- profile(long, int) - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
- profile(long, int) - Method in interface io.ebeaninternal.server.persist.BatchPostExecute
-
Add as event to the profiling.
- profileBean(EntityBeanIntercept, String) - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Add AutoTune profiling for a loaded entity bean.
- profileBean(EntityBeanIntercept, String) - Method in class io.ebeaninternal.server.query.CQuery
- profileEvent(SpiProfileTransactionEvent) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Check if the event should be added to a profiling transaction.
- profileEvent(SpiProfileTransactionEvent) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- profileEvent(SpiProfileTransactionEvent) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- profileEvent(SpiProfileTransactionEvent) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- profileEvent(SpiProfileTransactionEvent) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- profileEventId() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the profile event id based on query mode and type.
- profileEventId() - Method in enum io.ebeaninternal.api.SpiQuery.Type
- profileEventId() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- profileId() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the id used to identify a particular query for the given bean type.
- profileId() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- profileLocation() - Method in interface io.ebeaninternal.api.SpiDtoQuery
-
Return the profile location.
- profileLocation() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the profile location for this query.
- profileLocation() - Method in interface io.ebeaninternal.api.SpiQueryPlan
-
The related profile location.
- profileLocation() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the profile location for this transaction.
- profileLocation() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- profileLocation() - Method in class io.ebeaninternal.server.query.CQueryPlan
- profileLocation() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- profileLocation() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- profileLocation() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- profileLocation() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- profileLocation() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- profileOffset() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the offset time from the start of the transaction.
- profileOffset() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- profileOffset() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- profileOffset() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- profileOffset() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- profileStream() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the stream that profiling events are written to.
- profileStream() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- profileStream() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- profileStream() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- profileStream() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- ProfileStream - Interface in io.ebeaninternal.server.transaction
-
Collects the events of a transaction being profiled.
- profilingListener() - Method in interface io.ebeaninternal.api.SpiQuery
-
If return null then no profiling for this query.
- profilingListener() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- ProfilingListener - Interface in io.ebeaninternal.server.autotune
-
Profiling listener gets call backs for node usage and the associated query executions.
- propagateState(Object) - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Propagate the state to the bean.
- propagateState(Object) - Method in class io.ebeaninternal.server.query.CQuery
- properties() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Return meta data for the deployment of the embedded bean specific to this property.
- properties() - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- properties() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- properties() - Method in class io.ebeanservice.docstore.api.mapping.DocumentMapping
-
Return the document structure with mapping details.
- propertiesAll() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return a collection of all BeanProperty.
- propertiesAll() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return a collection of all BeanProperty deployment information.
- propertiesAssocMany() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return BeanPropertyAssocMany for this descriptor.
- propertiesAssocOne() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return an Iterator of BeanPropertyAssocOne that are not embedded.
- propertiesBase() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
base properties without the unique id properties.
- propertiesBaseScalar() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Scalar properties without the unique id or secondary table properties.
- propertiesEmbedded() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the beans that are embedded.
- propertiesGenInsert() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the properties set as generated values on insert.
- propertiesGenUpdate() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the properties set as generated values on update.
- propertiesLocal() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the properties local to this type for inheritance.
- propertiesMany() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
All Assoc Many's for this descriptor.
- propertiesManyDelete() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Assoc Many's with delete cascade.
- propertiesManySave() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Assoc Many's with save cascade.
- propertiesManyToMany() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Assoc ManyToMany's.
- propertiesNonMany() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
All Non Assoc Many's for this descriptor.
- propertiesNonTransient() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the non transient non id properties.
- propertiesOne() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
All the BeanPropertyAssocOne that are not embedded.
- propertiesOneExportedDelete() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Exported assoc ones with delete cascade.
- propertiesOneExportedSave() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Exported assoc ones with cascade save.
- propertiesOneImported() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Returns ManyToOnes and OneToOnes on the imported owning side.
- propertiesOneImportedDelete() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Imported Assoc Ones with cascade delete true.
- propertiesOneImportedSave() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Imported Assoc Ones with cascade save true.
- propertiesTransient() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the transient properties.
- property() - Method in class io.ebeaninternal.api.PropertyJoin
-
Return the property that should be joined.
- property() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- property() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- property() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- property() - Method in class io.ebeaninternal.server.expression.InExpression
- property() - Method in class io.ebeaninternal.server.query.ExtraJoin
- property(String) - Method in interface io.ebeaninternal.api.SpiExpressionRequest
-
Append to the expression sql with logical property parsing to db columns with logical path prefix.
- property(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- property(String) - Method in class io.ebeaninternal.server.deploy.DeployParser
-
Fast path parse() which first checks that the source is a bean property.
- property(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- property(String) - Method in interface io.ebeaninternal.server.expression.platform.DbExpressionRequest
-
Append to the expression sql with logical property parsing to db columns with logical path prefix.
- propertyByIndex(int) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- propertyContainsMany(String, BeanDescriptor<?>, ManyWhereJoins) - Method in class io.ebeaninternal.server.expression.InExpression
-
Check the logical property path for containing a 'many' property.
- propertyContainsMany(String, BeanDescriptor<?>, ManyWhereJoins) - Method in class io.ebeaninternal.server.expression.SimpleExpression
-
Check the logical property path for containing a 'many' property.
- PropertyForeignKey - Class in io.ebeaninternal.server.deploy
- PropertyForeignKey() - Constructor for class io.ebeaninternal.server.deploy.PropertyForeignKey
-
Construct for "No Constraint".
- PropertyForeignKey(DbForeignKey) - Constructor for class io.ebeaninternal.server.deploy.PropertyForeignKey
-
Construct for the mapping annotation.
- propertyIndex() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the position of this property in the enhanced bean.
- PropertyJoin - Class in io.ebeaninternal.api
-
Represents a join required for a given property and whether than needs to be an outer join.
- PropertyJoin(String, SqlJoinType) - Constructor for class io.ebeaninternal.api.PropertyJoin
- propertyJoins() - Method in class io.ebeaninternal.api.ManyWhereJoins
-
Return the set of many where joins.
- propertyNames() - Method in class io.ebeaninternal.api.ManyWhereJoins
-
Return the set of property names for the many where joins.
- propertyNames() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- propertyNestedPath(String, BeanDescriptor<?>) - Method in class io.ebeaninternal.server.expression.InExpression
- propertyNestedPath(String, BeanDescriptor<?>) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- propertyPositions(Set<String>) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
Return the property names as property index positions.
- propertyUnmappedJson() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the property that holds unmapped JSON content.
- propName - Variable in class io.ebeaninternal.server.expression.InExpression
- propName - Variable in class io.ebeaninternal.server.expression.SimpleExpression
- props() - Method in class io.ebeaninternal.server.query.SqlTreeProperties
- propsBaseScalar() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- propsBaseScalar() - Method in interface io.ebeaninternal.server.query.STreeType
-
Return the scalar properties.
- propsEmbedded() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- propsEmbedded() - Method in interface io.ebeaninternal.server.query.STreeType
-
Return the embedded bean properties.
- propsMany() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- propsMany() - Method in interface io.ebeaninternal.server.query.STreeType
-
Return the associated many properties.
- propsOne() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- propsOne() - Method in interface io.ebeaninternal.server.query.STreeType
-
Return the associated one properties.
- pstmt - Variable in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
- pstmtHolder() - Method in class io.ebeaninternal.server.persist.BatchControl
-
Return the actual batch of PreparedStatements.
- publish(EntityBean, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Copy/set the property value from the draft bean to the live bean.
- publish(Query<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- publish(Query<T>, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- publish(Query<T>, Transaction) - Method in interface io.ebeaninternal.server.core.Persister
-
Publish the draft beans matching the given query.
- publish(Query<T>, Transaction) - Method in class io.ebeaninternal.server.persist.DefaultPersister
-
Publish from draft to live given the query.
- publish(Class<T>, Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- publish(Class<T>, Object, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- publish(T, T) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- PUBLISH - Static variable in class io.ebeaninternal.server.persist.Flags
-
Indicates Publish mode.
- PUBLISH_RECURSE - Static variable in class io.ebeaninternal.server.persist.Flags
- push(E) - Method in class io.ebeaninternal.server.util.ArrayStack
-
Pushes an item onto the top of this stack.
- push(ScopeTrans) - Method in class io.ebeaninternal.api.ScopedTransaction
-
Push the scope transaction.
- push(DocPropertyMapping) - Method in class io.ebeanservice.docstore.api.mapping.DocMappingBuilder
-
Push the nested object or list onto the properties stack.
- pushJoin(String) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Push a join node onto the stack.
- pushJson(String) - Method in class io.ebeaninternal.server.type.RsetDataReader
- pushParentBeanMany(EntityBean) - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
Push the parent bean of a ToMany.
- pushParentBeanMany(EntityBean) - Method in class io.ebeaninternal.server.json.WriteJson
- pushPath(String) - Method in interface io.ebeaninternal.api.json.SpiJsonReader
- pushPath(String) - Method in class io.ebeaninternal.server.json.ReadJson
-
Push the path onto the stack (traversing a 1-M or M-1 etc)
- pushPathKey(String) - Method in class io.ebeaninternal.server.json.PathStack
- pushTableAlias(String) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Push the current table alias onto the stack.
- put(Class<?>, Object, Object) - Method in class io.ebeaninternal.server.transaction.DefaultPersistenceContext
- put(Object, Object) - Method in class io.ebeaninternal.server.cache.DefaultServerCache
-
Put a value into the cache.
- put(String, Object) - Method in class io.ebeaninternal.server.deploy.IntersectionRow
- put(String, Object) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- put(K, V) - Method in class io.ebeaninternal.json.ModifyAwareMap
- putAll(Map<? extends String, ?>) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- putAll(Map<? extends K, ? extends V>) - Method in class io.ebeaninternal.json.ModifyAwareMap
- putAll(Map<Object, Object>) - Method in class io.ebeaninternal.server.cache.DefaultServerCache
- putAll(Map<String, Column>) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanEmbedded
-
Set a Map of property names to dbColumns.
- putCount - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- putIfAbsent(Class<?>, Object, Object) - Method in class io.ebeaninternal.server.transaction.DefaultPersistenceContext
- putQueryPlan(CQueryPlan) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Put the QueryPlan into the cache.
- putQueryPlan(Object, DtoQueryPlan) - Method in interface io.ebeaninternal.api.SpiDtoQuery
-
Put the query plan into the cache.
- putQueryPlan(Object, DtoQueryPlan) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- putToQueryCache(Object) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- putUserObject(String, Object) - Method in class io.ebeaninternal.api.ScopedTransaction
-
New user objects are always written to the current ScopeTrans.
- putUserObject(String, Object) - Method in class io.ebeaninternal.api.ScopeTrans
- putUserObject(String, Object) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- putUserObject(String, Object) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- putUserObject(String, Object) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- putUserObject(String, Object) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
Q
- query - Variable in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
- query - Variable in class io.ebeaninternal.server.expression.DefaultExpressionList
- query() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- query() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Return the query.
- query() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- query() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- query() - Method in interface io.ebeanservice.docstore.api.DocQueryRequest
-
Return the query for this request.
- queryAdapter() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the BeanQueryAdapter or null if none is defined.
- queryBeans - Variable in class io.ebeaninternal.server.transaction.TransactionProfile.Summary
- queryBindCount() - Method in class io.ebeaninternal.api.BindParams.Param
- queryBindHash(BindValuesKey) - Method in class io.ebeaninternal.api.BindParams
- queryBindKey(BindValuesKey) - Method in interface io.ebeaninternal.api.SpiExpression
-
Build the key for bind values of the query.
- queryBindKey(BindValuesKey) - Method in interface io.ebeaninternal.api.SpiQuery
-
Build the key for the bind values used in the query (for l2 query cache).
- queryBindKey(BindValuesKey) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- queryBindKey(BindValuesKey) - Method in class io.ebeaninternal.server.expression.IdInExpression
- queryBindKey(BindValuesKey) - Method in class io.ebeaninternal.server.expression.InExpression
- queryBindKey(BindValuesKey) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- queryBindKey(BindValuesKey) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- queryCache(Class<?>) - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- queryCacheGet(Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Get a query result from the query cache.
- queryCacheMode() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the cache mode if this query should use/check the query cache.
- queryCacheMode() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- queryCachePut(Object, QueryCacheEntry) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Put a query result into the query cache.
- queryCount - Variable in class io.ebeaninternal.server.transaction.TransactionProfile.Summary
- queryFor(Class<T>) - Method in class io.ebeaninternal.server.query.DFetchGroupService
- QueryFutureIds<T> - Class in io.ebeaninternal.server.query
-
Default implementation of FutureIds.
- QueryFutureIds(CallableQueryIds<T>) - Constructor for class io.ebeaninternal.server.query.QueryFutureIds
- QueryFutureList<T> - Class in io.ebeaninternal.server.query
-
Default implementation for FutureList.
- QueryFutureList(CallableQueryList<T>) - Constructor for class io.ebeaninternal.server.query.QueryFutureList
- QueryFutureRowCount<T> - Class in io.ebeaninternal.server.query
-
Future implementation for the row count query.
- QueryFutureRowCount(CallableQueryCount<T>) - Constructor for class io.ebeaninternal.server.query.QueryFutureRowCount
- queryHash() - Method in interface io.ebeaninternal.api.SpiQuery
-
Identifies queries that are exactly the same including bind variables.
- queryHash() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Return a hash that includes the query plan and bind values.
- queryJoins() - Method in interface io.ebeaninternal.api.SpiQuerySecondary
-
Return a list of path/properties that are query join loaded.
- queryMax - Variable in class io.ebeaninternal.server.transaction.TransactionProfile.Summary
- queryMicros - Variable in class io.ebeaninternal.server.transaction.TransactionProfile.Summary
- queryMode() - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Return the query mode.
- queryMode() - Method in class io.ebeaninternal.server.query.CQuery
- queryPlan() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return a queryPlan for the current query if one exists.
- queryPlan(CQueryPlanKey) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- queryPlan(CQueryPlanKey, CQueryPlan) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- queryPlan(Object) - Method in interface io.ebeaninternal.api.SpiDtoQuery
-
Get the query plan for the cache.
- queryPlan(Object) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- queryPlanConnection() - Method in interface io.ebeaninternal.api.SpiTransactionManager
-
Return a connection used for query plan collection.
- queryPlanConnection() - Method in class io.ebeaninternal.server.transaction.TransactionManager
- queryPlanHash(StringBuilder) - Method in interface io.ebeaninternal.api.SpiExpression
-
Calculate a hash value used to identify a query for AutoTune tuning.
- queryPlanHash(StringBuilder) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Calculate a hash based on the expressions but excluding the actual bind values.
- queryPlanHash(StringBuilder) - Method in class io.ebeaninternal.server.expression.IdInExpression
-
Incorporates the number of ID values to bind.
- queryPlanHash(StringBuilder) - Method in class io.ebeaninternal.server.expression.InExpression
-
Based on the number of values in the in clause.
- queryPlanHash(StringBuilder) - Method in class io.ebeaninternal.server.expression.SimpleExpression
-
Based on the type and propertyName.
- queryPlanHash(StringBuilder) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Calculate the hash for the query plan.
- queryPlanHash(StringBuilder) - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Calculate the query plan hash.
- queryPlanInit(long) - Method in interface io.ebeaninternal.api.SpiQueryBindCapture
-
Update the threshold micros triggering the bind capture.
- queryPlanInit(long) - Method in interface io.ebeaninternal.api.SpiQueryPlan
-
Initiate bind capture with the give threshold.
- queryPlanInit(long) - Method in class io.ebeaninternal.server.query.CQueryPlan
- queryPlanInit(QueryPlanInit) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- queryPlanKey() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the query plan key.
- queryPlanKey() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return the queryPlanHash.
- queryPlanKey() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- QueryPlanLogger - Class in io.ebeaninternal.server.query
- QueryPlanLogger() - Constructor for class io.ebeaninternal.server.query.QueryPlanLogger
- QueryPlanLoggerExplain - Class in io.ebeaninternal.server.query
-
A QueryPlanLogger that prefixes "EXPLAIN " to the query.
- QueryPlanLoggerExplain(String) - Constructor for class io.ebeaninternal.server.query.QueryPlanLoggerExplain
- QueryPlanLoggerOracle - Class in io.ebeaninternal.server.query
-
A QueryPlanLogger for oracle.
- QueryPlanLoggerOracle() - Constructor for class io.ebeaninternal.server.query.QueryPlanLoggerOracle
- QueryPlanLoggerSqlServer - Class in io.ebeaninternal.server.query
-
A QueryPlanLogger for SqlServer.
- QueryPlanLoggerSqlServer() - Constructor for class io.ebeaninternal.server.query.QueryPlanLoggerSqlServer
- QueryPlanManager - Interface in io.ebeaninternal.api
-
Manage query plan capture.
- queryRequest() - Method in interface io.ebeaninternal.api.SpiExpressionRequest
-
Return the associated QueryRequest.
- queryRequest() - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- queue() - Method in interface io.ebeanservice.docstore.api.DocStoreTransaction
-
Add changes that should be queued to the DocStoreUpdates.
- queueDelete(String, Object) - Method in class io.ebeanservice.docstore.api.DocStoreUpdates
-
Queue a 'delete' request.
- queueEntries() - Method in class io.ebeanservice.docstore.api.DocStoreUpdates
-
Return the entries for sending to the queue.
- queueId - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
Identifier used in the queue system to identify the index.
- queueId - Variable in class io.ebeanservice.docstore.api.support.DocStoreEmbeddedInvalidation
- queueId() - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Return the unique queueId for this bean type.
- queueId() - Method in class io.ebeanservice.docstore.api.mapping.DocumentMapping
-
Return the queueId.
- queueId() - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- queueIndex(String, Object) - Method in class io.ebeanservice.docstore.api.DocStoreUpdates
-
Queue an 'index' request.
- queueNested(String, String, Object) - Method in class io.ebeanservice.docstore.api.DocStoreUpdates
-
Queue an update to a nested/embedded object.
R
- raw(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Add raw expression with no parameters.
- raw(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- raw(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Add raw expression with a single parameter.
- raw(String, Object) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- raw(String, Object[]) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Add raw expression with an array of parameters.
- raw(String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- rawCollection(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return the underlying collection of beans.
- rawOrEmpty(String, Collection<?>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- rawProperty(String) - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Return an un-analysed property to use instead of the given property.
- rawProperty(String) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- rawSql() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the RawSql that was set to use for this query.
- rawSql() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- read() - Method in interface io.ebeaninternal.server.core.RowReader
-
Build and return a result for a row.
- read(byte[]) - Method in class io.ebeaninternal.server.cluster.BinaryTransactionEventReader
-
Read Transaction from bytes.
- read(DataReader) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- read(DataReader) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- read(DataReader) - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- read(DataReader) - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.Native
- read(DataReader) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- read(DataReader) - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- read(DataReader) - Method in class io.ebeaninternal.server.type.ScalarTypeString
- read(DataReader) - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- read(DataReader) - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- read(BinaryReadContext) - Method in class io.ebeaninternal.server.cluster.BinaryTransactionEventReader
-
Read Transaction using BinaryReadContext.
- read(DbReadContext) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- read(DbReadContext) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- read(DbReadContext) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- read(DbReadContext) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Read the id value from the result set and return it.
- read(DbReadContext) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- read(DbReadContext) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- read(T) - Method in class io.ebeaninternal.server.json.DJsonBeanReader
- readAuditBean(String, String, Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Write a bean read to the read audit log.
- readAuditFutureList(SpiQuery<T>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Prepare the read audit of a findFutureList() query.
- readAuditFutureMany(ReadEvent) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Write a futureList many read to the read audit log.
- readAuditLogger() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return the ReadAuditLogger to use for logging all read audit events.
- readAuditLogger() - Method in class io.ebeaninternal.server.core.DefaultServer
- readAuditLogger() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the ReadAuditLogger for logging read audit events.
- readAuditMany(String, String, List<Object>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Write a many bean read to the read audit log.
- readAuditPrepare() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return the ReadAuditPrepare used to populate the read audit events with user context information (user id, user ip address etc).
- readAuditPrepare() - Method in class io.ebeaninternal.server.core.DefaultServer
- readBinary(BinaryReadContext) - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
-
Read the binary message.
- readBinaryMessage(BinaryReadContext) - Static method in class io.ebeaninternal.api.TransactionEventTable.TableIUD
- readBinaryMessage(BinaryReadContext) - Static method in class io.ebeaninternal.server.cache.RemoteCacheEvent
- readBinaryMessage(BinaryReadContext) - Static method in class io.ebeaninternal.server.transaction.RemoteTableMod
- readBinaryMessage(SpiEbeanServer, BinaryReadContext) - Static method in class io.ebeaninternal.server.transaction.BeanPersistIds
- readBoolean() - Method in class io.ebeaninternal.api.BinaryReadContext
- readData(DataInput) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- readData(DataInput) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Read the Id value from the binary DataInput.
- readData(DataInput) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- readData(DataInput) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- readData(DataInput) - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.BooleanBase
- readData(DataInput) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesBase
- readData(DataInput) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- readData(DataInput) - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- readData(DataInput) - Method in class io.ebeaninternal.server.type.ScalarTypeString
- readData(DataInput) - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- readData(DataInput) - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- readDocStore(DocStore) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Read the top level doc store deployment information.
- readExternal(ObjectInput) - Method in class io.ebeaninternal.server.cache.CachedBeanData
- readExternal(ObjectInput) - Method in class io.ebeaninternal.server.cache.CachedBeanId
- readExternal(ObjectInput) - Method in class io.ebeaninternal.server.cache.CachedManyIds
- readInt() - Method in class io.ebeaninternal.api.BinaryReadContext
- ReadJson - Class in io.ebeaninternal.server.json
-
Context for JSON read processing.
- ReadJson(BeanDescriptor<?>, JsonParser, JsonReadOptions, Object, boolean) - Constructor for class io.ebeaninternal.server.json.ReadJson
-
Construct with parser and readOptions.
- readLong() - Method in class io.ebeaninternal.api.BinaryReadContext
- readNextBean() - Method in class io.ebeaninternal.server.core.DtoQueryRequest
- readOnlyConnection(Object, boolean) - Method in interface io.ebeaninternal.server.transaction.DataSourceSupplier
-
Return a connection from the read only DataSource taking into account a tenantId for multi-tenant lazy loading.
- readOnlyDataSource() - Method in interface io.ebeaninternal.api.SpiTransactionManager
-
Return the read only DataSource (if defined).
- readOnlyDataSource() - Method in class io.ebeaninternal.server.core.DefaultServer
- readOnlyDataSource() - Method in interface io.ebeaninternal.server.transaction.DataSourceSupplier
-
Return the read only DataSource to use for the current request.
- readOnlyDataSource() - Method in class io.ebeaninternal.server.transaction.TransactionManager
- readOnlyLogger() - Method in interface io.ebeaninternal.api.SpiLogManager
-
Logger used for read only transactions.
- readSet(DataReader, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- readSet(DataReader, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- readSet(DataReader, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyJsonBasic
- readSet(DataReader, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyJsonMapper
- readSet(DbReadContext, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- readSet(DbReadContext, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- readSet(DbReadContext, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- readSet(DbReadContext, EntityBean) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Read the id value from the result set and set it to the bean also returning it.
- readSet(DbReadContext, EntityBean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- readSet(DbReadContext, EntityBean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- readType(DbReadContext) - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return the associated InheritInfo for this DB row read.
- readType(Class<?>) - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Return the associated InheritInfo for this bean type.
- readUTF() - Method in class io.ebeaninternal.api.BinaryReadContext
- readValueUsingObjectMapper(Class<?>) - Method in interface io.ebeaninternal.api.json.SpiJsonReader
- readValueUsingObjectMapper(Class<?>) - Method in class io.ebeaninternal.server.json.ReadJson
-
Read the property value using Jackson ObjectMapper.
- RECURSE - Static variable in class io.ebeaninternal.server.persist.Flags
-
Indicates persist cascade.
- reference(Class<T>, Object) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Return a Reference bean.
- referenceIdPropertyOnly(EntityBeanIntercept) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- refresh(BeanCollection<?>, EntityBean) - Method in interface io.ebeaninternal.server.deploy.BeanCollectionHelp
-
Apply the new refreshed BeanCollection to the appropriate property of the parent bean.
- refresh(BeanCollection<?>, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanListHelp
- refresh(BeanCollection<?>, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanMapHelp
- refresh(BeanCollection<?>, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanSetHelp
- refresh(Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- REFRESH_BEAN - Enum constant in enum io.ebeaninternal.api.SpiQuery.Mode
- refreshMany(Object, String) - Method in class io.ebeaninternal.server.core.DefaultServer
- regex(String, String) - Method in class io.ebeaninternal.server.el.ElFilter
- regex(String, String, int) - Method in class io.ebeaninternal.server.el.ElFilter
- region(String) - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- register(BeanPersistController) - Method in class io.ebeaninternal.server.core.DefaultServer
- register(BeanPersistController) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Register the new BeanPersistController.
- register(BeanPersistController) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistController
-
Register a new BeanPersistController and return the resulting chain.
- register(BeanPersistListener) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Register the new BeanPersistController.
- register(BeanPersistListener) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistListener
-
Register a new BeanPersistListener and return the resulting chain.
- register(BeanPostConstructListener) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPostConstructListener
-
Register a new BeanPostCreate and return the resulting chain.
- register(BeanPostLoad) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPostLoad
-
Register a new BeanPostLoad and return the resulting chain.
- register(BeanQueryAdapter) - Method in class io.ebeaninternal.server.deploy.ChainedBeanQueryAdapter
-
Register a new BeanQueryAdapter and return the resulting chain.
- register(TransactionCallback) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- register(TransactionCallback) - Method in class io.ebeaninternal.server.core.DefaultServer
- register(TransactionCallback) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- register(TransactionCallback) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- register(TransactionCallback) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- register(BeanPropertyAssocMany<?>, BeanCollection<?>) - Method in interface io.ebeaninternal.api.LoadBeanContext
-
Register a BeanCollection into the load context.
- register(BeanPropertyAssocMany<?>, BeanCollection<?>) - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Register a collection for lazy loading.
- register(BeanPropertyAssocMany<?>, BeanCollection<?>) - Method in class io.ebeaninternal.server.query.CQuery
- register(TransactionManager) - Method in class io.ebeaninternal.server.transaction.DefaultTransactionScopeManager
- register(TransactionManager) - Method in class io.ebeaninternal.server.transaction.ExternalTransactionScopeManager
- register(TransactionManager) - Method in class io.ebeaninternal.server.transaction.TransactionScopeManager
-
Register the transaction manager (for use by external transaction scopes).
- register(String, EntityBeanIntercept) - Method in interface io.ebeaninternal.api.LoadContext
-
Register a Bean for lazy loading.
- register(String, EntityBeanIntercept) - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Register a reference for lazy loading.
- register(String, EntityBeanIntercept) - Method in class io.ebeaninternal.server.query.CQuery
- register(String, EntityBeanIntercept, BeanPropertyAssocOne<?>) - Method in interface io.ebeaninternal.api.LoadContext
-
Register a Bean with inheritance.
- register(String, BeanPropertyAssocMany<?>, BeanCollection<?>) - Method in interface io.ebeaninternal.api.LoadContext
-
Register a collection for lazy loading.
- registerBeanInherit(BeanPropertyAssocOne<?>, EntityBeanIntercept) - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Register a reference with inheritance for lazy loading.
- registerBeanInherit(BeanPropertyAssocOne<?>, EntityBeanIntercept) - Method in class io.ebeaninternal.server.query.CQuery
- registerColumn(BeanDescriptor<?>, String) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- registerColumn(BeanDescriptor<?>, String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
- registerColumn(BeanDescriptor<?>, String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- registerDeferred(PersistDeferredRelationship) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Register a "Deferred Relationship" that requires an additional update later.
- registerDeferred(PersistDeferredRelationship) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- registerDeferred(PersistDeferredRelationship) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- registerDeferred(PersistDeferredRelationship) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- registerDeferred(PersistDeferredRelationship) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- registerDeleteBean() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- registerDeleteBean(Integer) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Add a deleting bean to the registered list.
- registerDeleteBean(Integer) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- registerDeleteBean(Integer) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Add a bean to the registed list.
- registerDeleteBean(Integer) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Add a bean to the registed list.
- registerDeleteBean(Integer) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Add a bean to the registed list.
- registerInputStreams(List<InputStream>) - Method in class io.ebeaninternal.server.persist.BatchedPstmt
-
Register any inputStreams that should be closed after execution.
- registerInvalidationPath(String, String, Set<String>) - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Register invalidation events for embedded/nested documents the given path and properties.
- registerInvalidationPath(String, String, Set<String>) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
Register a doc store invalidation listener for the given bean type, path and properties.
- registerOut(int, int) - Method in class io.ebeaninternal.api.BindParams
-
Register the parameter as an Out parameter using position.
- registerOut(String, int) - Method in class io.ebeaninternal.api.BindParams
-
Register the named parameter as an Out parameter.
- registerPaths() - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
In deployment phase read the embedded/nested document information.
- registerPaths() - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
Register invalidation paths for embedded documents.
- registerServer(Database) - Method in class io.ebeaninternal.server.cluster.ClusterManager
- RelationalQueryEngine - Interface in io.ebeaninternal.server.core
- RelationalQueryRequest - Class in io.ebeaninternal.server.core
-
Wraps the objects involved in executing a SqlQuery.
- relativePrefix(String) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
- RemoteCacheEvent - Class in io.ebeaninternal.server.cache
-
Cache events broadcast across the cluster.
- RemoteCacheEvent(boolean) - Constructor for class io.ebeaninternal.server.cache.RemoteCacheEvent
-
Clear all the caches.
- RemoteCacheEvent(boolean, List<String>) - Constructor for class io.ebeaninternal.server.cache.RemoteCacheEvent
-
Create with the read options.
- RemoteCacheEvent(Class<?>) - Constructor for class io.ebeaninternal.server.cache.RemoteCacheEvent
-
Clear caches for the given bean type.
- RemoteTableMod - Class in io.ebeaninternal.server.transaction
- RemoteTableMod(Set<String>) - Constructor for class io.ebeaninternal.server.transaction.RemoteTableMod
- remoteTransactionEvent(RemoteTransactionEvent) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
An event from another server in the cluster used to notify local BeanListeners of remote inserts updates and deletes.
- remoteTransactionEvent(RemoteTransactionEvent) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Another server in the cluster sent this event so that we can inform local BeanListeners of inserts updates and deletes that occurred remotely (on another server in the cluster).
- remoteTransactionEvent(RemoteTransactionEvent) - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Notify local BeanPersistListeners etc of events from another server in the cluster.
- RemoteTransactionEvent - Class in io.ebeaninternal.server.transaction
- RemoteTransactionEvent(SpiEbeanServer) - Constructor for class io.ebeaninternal.server.transaction.RemoteTransactionEvent
-
Create from Reading and processing from remote server.
- RemoteTransactionEvent(String) - Constructor for class io.ebeaninternal.server.transaction.RemoteTransactionEvent
-
Create for sending to other servers in the cluster.
- remove() - Method in class io.ebeaninternal.json.ModifyAwareIterator
- remove() - Method in class io.ebeaninternal.json.ModifyAwareListIterator
- remove(int) - Method in class io.ebeaninternal.json.ModifyAwareList
- remove(Object) - Method in class io.ebeaninternal.json.ModifyAwareList
- remove(Object) - Method in class io.ebeaninternal.json.ModifyAwareMap
- remove(Object) - Method in class io.ebeaninternal.json.ModifyAwareSet
- remove(Object) - Method in class io.ebeaninternal.server.cache.DefaultServerCache
-
Remove an entry from the cache.
- remove(Object) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- removeAll(Collection<?>) - Method in class io.ebeaninternal.json.ModifyAwareList
- removeAll(Collection<?>) - Method in class io.ebeaninternal.json.ModifyAwareSet
- removeCount - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- removeFromBuffer(BeanCollection<?>) - Method in interface io.ebeaninternal.api.LoadManyBuffer
-
Removes an element from the buffer.
- removeFromPersistenceContext() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Remove deleted beans from the persistence context early.
- removeHits(BeanCacheResult<T>) - Method in interface io.ebeaninternal.api.CacheIdLookup
-
Remove the hits returning the beans fetched from L2 cache.
- removeHits(BeanCacheResult<T>) - Method in class io.ebeaninternal.api.CacheIdLookupMany
-
Process the hits returning the beans fetched from cache and adjusting the in expression (to not fetch the hits).
- removeHits(BeanCacheResult<T>) - Method in class io.ebeaninternal.api.CacheIdLookupSingle
- removeHits(BeanCacheResult<T>) - Method in class io.ebeaninternal.api.NaturalKeyQueryData
-
Adjust the IN clause removing the hit entry.
- removeIds(Set<Object>) - Method in interface io.ebeaninternal.server.expression.IdInCommon
-
Remove Ids that where obtained from l2 cache.
- removeIds(Set<Object>) - Method in class io.ebeaninternal.server.expression.IdInExpression
- removeIds(Set<Object>) - Method in class io.ebeaninternal.server.expression.InExpression
- renderDbType(DbPlatformType, boolean) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the DB column type definition.
- replace(SpiTransaction) - Method in interface io.ebeaninternal.api.SpiTransactionScopeManager
- replace(SpiTransaction) - Method in class io.ebeaninternal.server.transaction.DefaultTransactionScopeManager
- replace(SpiTransaction) - Method in class io.ebeaninternal.server.transaction.TransactionScopeManager
-
Replace the current transaction with this one.
- replicas() - Method in class io.ebeanservice.docstore.api.mapping.DocumentMapping
-
Return the number of replicas.
- replicas(int) - Method in class io.ebeanservice.docstore.api.mapping.DocumentMapping
-
Set the number of replicas.
- reportProfiling() - Method in class io.ebeaninternal.server.autotune.NoAutoTuneService
- requestComplete() - Method in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
- requestComplete() - Method in class io.ebeaninternal.server.core.DtoQueryRequest
- requestComplete() - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
- requiresNamedParamsPrepare() - Method in class io.ebeaninternal.api.BindParams
-
Return true if named parameters are being used and they have not yet been ordered.
- requireSqlDistinct() - Method in class io.ebeaninternal.api.ManyWhereJoins
-
Return true if this is an aggregation query or if there are no extra many where joins.
- requiresViewEntityCacheInvalidation() - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Return true if there are 'view based entities' using l2 query caching and so need to be invalidated based on changes to dependent tables.
- reset() - Method in class io.ebeaninternal.api.BindParams
-
Reset positioned parameters (usually due to bind parameter expansion).
- reset() - Static method in class io.ebeaninternal.api.DbOffline
-
Reset the offline platform and runningMigration flag.
- reset() - Method in interface io.ebeaninternal.api.SpiSqlUpdate
-
Reset bind position to be ready for another bind execute.
- reset() - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- reset() - Method in class io.ebeaninternal.server.query.CQueryPlanStats
-
Reset the internal statistics counters.
- resetBeanCacheAutoMode(boolean) - Method in interface io.ebeaninternal.api.SpiQuery
-
Reset AUTO mode to OFF for findList().
- resetBeanCacheAutoMode(boolean) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- resetBeanCacheAutoMode(boolean) - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Reset Bean cache mode AUTO - require explicit setting for bean cache use with findList().
- resetBeanCacheAutoMode(boolean) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- resetDepth() - Method in class io.ebeaninternal.server.core.PersistRequest
-
Reset the transaction depth back to 0.
- resetForInsert() - Method in class io.ebeaninternal.server.core.DefaultBeanState
- resetMany(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Reset the many properties to be empty and ready for reloading.
- resetManyProperties(Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Reset the many properties to empty state ready for reloading.
- resetStatistics() - Method in class io.ebeaninternal.server.query.CQueryPlan
-
Reset the query statistics.
- results() - Method in class io.ebeaninternal.server.persist.BatchedPstmt
-
Return the execution results (row counts).
- resultSet - Variable in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
- resultSet() - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
- resultSet() - Method in class io.ebeaninternal.server.core.SpiResultSet
- resultSet(ResultSet, String...) - Method in class io.ebeaninternal.server.rawsql.DRawSqlService
- retainAll(Collection<?>) - Method in class io.ebeaninternal.json.ModifyAwareList
- retainAll(Collection<?>) - Method in class io.ebeaninternal.json.ModifyAwareSet
- reverse() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoinColumn
-
Reverse the direction of the join.
- rollback() - Method in class io.ebeaninternal.api.ScopedTransaction
- rollback() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
This will always throw a PersistenceException.
- rollback() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Rollback the transaction.
- rollback() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- rollback(Throwable) - Method in class io.ebeaninternal.api.ScopedTransaction
- rollback(Throwable) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
This will always throw a PersistenceException.
- rollback(Throwable) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Rollback the transaction.
- rollback(Throwable) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Rollback the transaction.
- rollbackAndContinue() - Method in class io.ebeaninternal.api.ScopedTransaction
- rollbackAndContinue() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- rollbackAndContinue() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- rollbackAndContinue() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- rollbackTransIfRequired() - Method in class io.ebeaninternal.server.core.BeanRequest
-
Rollback the transaction if it was created for this request.
- rollbackTransIfRequired() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Rollback the transaction if it was created for this request.
- rollbackTransIfRequired() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- root() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the root bean type if part of inheritance hierarchy.
- root(Class<?>) - Static method in class io.ebeaninternal.server.deploy.PersistenceContextUtil
-
Find and return the root bean type for the given class.
- ROOT_ELPREFIX - Static variable in interface io.ebeaninternal.server.el.ElPropertyDeploy
-
This is the elPrefix for all root level properties.
- rootName() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the full name taking into account inheritance.
- RowReader<T> - Interface in io.ebeaninternal.server.core
-
Read a row building a result for that row.
- RsetDataReader - Class in io.ebeaninternal.server.type
- RsetDataReader(DataTimeZone, ResultSet) - Constructor for class io.ebeaninternal.server.type.RsetDataReader
- RsetDataReaderIndexed - Class in io.ebeaninternal.server.type
-
A DataReader with indexed positions for the properties to read specifically for RawSql use.
- RsetDataReaderIndexed(DataTimeZone, ResultSet, int[]) - Constructor for class io.ebeaninternal.server.type.RsetDataReaderIndexed
- run() - Method in class io.ebeaninternal.server.cache.DefaultServerCache.EvictionRunnable
- run() - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- runEviction() - Method in class io.ebeaninternal.server.cache.DefaultServerCache
-
Run the eviction based on Idle time, Time to live and LRU last access.
- runServerConfigStartup(DatabaseBuilder) - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
-
Run any ServerConfigStartup listeners.
S
- save(EntityBean, Transaction) - Method in interface io.ebeaninternal.server.core.Persister
-
Insert or update the bean depending on its state.
- save(EntityBean, Transaction) - Method in class io.ebeaninternal.server.persist.DefaultPersister
-
Insert or update the bean.
- save(Object) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Persist the bean by either performing an insert or update.
- save(Object, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Save the bean with an explicit transaction.
- saveAll(Object...) - Method in class io.ebeaninternal.server.core.DefaultServer
- saveAll(Collection<?>) - Method in class io.ebeaninternal.server.core.DefaultServer
- saveAll(Collection<?>, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- saveBatch() - Method in interface io.ebeaninternal.server.persist.SaveMany
-
Save the many property (after the associated bean persist).
- SaveMany - Interface in io.ebeaninternal.server.persist
-
Save many that can be queued up to execute after the associated bean has been actually been persisted.
- saveState() - Method in class io.ebeaninternal.server.idgen.UuidV1IdGenerator
-
Saves the state to the state file;
- saveState() - Method in class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
-
Method to overwrite to save the state in a non volatile place.
- scalarType() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the scalarType.
- scalarType() - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- scalarType() - Method in interface io.ebeaninternal.server.query.STreeProperty
-
Return the underlying scalar type for the property (for findSingleAttribute).
- scalarType(int) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the Scalar type for the given JDBC type.
- scalarType(int) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- scalarType(int) - Method in interface io.ebeaninternal.server.deploy.BeanDescriptorMap
-
Return the scalarType for the given JDBC type.
- scalarType(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- scalarType(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- scalarType(String) - Method in interface io.ebeaninternal.server.deploy.BeanDescriptorMap
-
Return the scalarType for the given logical type.
- ScalarTypeArray - Interface in io.ebeaninternal.server.type
-
DB Array types.
- ScalarTypeBool - Interface in io.ebeaninternal.server.type
-
Boolean ScalarType's must implement to support DDL default values etc.
- ScalarTypeBoolean - Class in io.ebeaninternal.server.type
-
ScalarType for Boolean and boolean.
- ScalarTypeBoolean() - Constructor for class io.ebeaninternal.server.type.ScalarTypeBoolean
- ScalarTypeBoolean.BooleanBase - Class in io.ebeaninternal.server.type
- ScalarTypeBoolean.Native - Class in io.ebeaninternal.server.type
- ScalarTypeBytesBase - Class in io.ebeaninternal.server.type
-
Base type for binary types.
- ScalarTypeBytesEncrypted - Class in io.ebeaninternal.server.type
-
Encrypted ScalarType that wraps a byte[] types.
- ScalarTypeBytesEncrypted(ScalarTypeBytesBase, DataEncryptSupport) - Constructor for class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- ScalarTypeEncryptedWrapper<T> - Class in io.ebeaninternal.server.type
- ScalarTypeEncryptedWrapper(ScalarType<T>, ScalarTypeBytesBase, DataEncryptSupport) - Constructor for class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- ScalarTypeEnum<T> - Interface in io.ebeaninternal.server.type
-
Marker interface for the Enum scalar types.
- ScalarTypeLogicalType - Interface in io.ebeaninternal.server.type
-
Marks types that can be mapped differently to different DB platforms.
- ScalarTypeString - Class in io.ebeaninternal.server.type
-
ScalarType for String.
- ScalarTypeUUIDBinary - Class in io.ebeaninternal.server.type
- ScalarTypeWrapper<B,
S> - Class in io.ebeaninternal.server.type -
A ScalarType that uses a ScalarTypeConverter to convert to and from another underlying ScalarType.
- ScalarTypeWrapper(Class<B>, ScalarType<S>, ScalarTypeConverter<B, S>) - Constructor for class io.ebeaninternal.server.type.ScalarTypeWrapper
- scheduleBackgroundTrim() - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Run periodic trim of query plans.
- scope() - Method in interface io.ebeaninternal.api.SpiTransactionManager
-
Return the scope manager for this server.
- scope() - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Return the scope manager.
- ScopedTransaction - Class in io.ebeaninternal.api
-
Manage scoped (typically thread local) transactions.
- ScopedTransaction(TransactionScopeManager) - Constructor for class io.ebeaninternal.api.ScopedTransaction
- scopedTransactionEnter(TxScope) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Start an enhanced transactional method.
- scopedTransactionEnter(TxScope) - Method in class io.ebeaninternal.server.core.DefaultServer
- scopedTransactionExit(Object, int) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Handle the end of an enhanced Transactional method.
- scopedTransactionExit(Object, int) - Method in class io.ebeaninternal.server.core.DefaultServer
- ScopeTrans - Class in io.ebeaninternal.api
-
Used internally to handle the scoping of transactions for methods.
- ScopeTrans(boolean, boolean, SpiTransaction, TxScope) - Constructor for class io.ebeaninternal.api.ScopeTrans
- script() - Method in class io.ebeaninternal.server.core.DefaultServer
- search(DatabaseBuilder.Settings) - Static method in class io.ebeaninternal.server.core.bootup.BootupClassPathSearch
-
Search the classPath for the classes we are interested in returning them as BootupClasses.
- searchAnalyzer() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- searchAnalyzer(String) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- secondaryQueriesMinBatchSize() - Method in interface io.ebeaninternal.api.LoadContext
-
Return the minimum batch size when using QueryIterator with query joins.
- secondaryQueriesMinBatchSize() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
For use with QueryIterator and secondary queries this returns the minimum batch size that should be loaded before executing the secondary queries.
- secondaryQuery() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return secondary queries if required.
- secondaryQuery() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- secondaryTableJoinPrefix() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Returns null unless this property is using a secondary table.
- select(FetchGroup<T>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- select(FetchGroup<T>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- select(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- select(String) - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- select(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- select(String) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
set the properties to include on the base / root entity.
- selectAllForLazyLoadProperty() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return true if select all properties was used to ensure the property invoking a lazy load was included in the query.
- selectAllForLazyLoadProperty() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Return true if select all properties was used to ensure the property invoking a lazy load was included in the query.
- selectDistinct() - Method in class io.ebeaninternal.server.querydefn.OrmQueryLimitRequest
- selectDistinctOnSql() - Method in class io.ebeaninternal.server.querydefn.OrmQueryLimitRequest
- selectLastInsertedId() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the SQL used to fetch the last inserted id value.
- selectLastInsertedId(boolean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the SQL used to return the last inserted id.
- selectProperties(OrmQueryProperties) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the select properties.
- selectProperties(OrmQueryProperties) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- selectProperties(Set<String>) - Method in interface io.ebeaninternal.api.SpiQueryFetch
-
Specify the select properties.
- selectProperties(Set<String>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- selectProperties(Set<String>) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Set select properties that are already parsed.
- sendChangeLog(ChangeSet) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Send the change set to be prepared and then logged.
- sendChangeLog(ChangeSet) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- sendChangeLog(ChangeSet) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- sendChangeLog(ChangeSet) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- sendChangeLog(ChangeSet) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- server - Variable in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
- server - Variable in class io.ebeaninternal.server.core.BeanRequest
- server - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- server() - Method in class io.ebeaninternal.server.core.BeanRequest
- ServerLookup - Interface in io.ebeaninternal.server.cluster
-
Returns Database instances for remote message reading.
- service(Class<S>) - Static method in class io.ebeaninternal.server.core.ServiceUtil
- ServiceUtil - Class in io.ebeaninternal.server.core
- ServiceUtil() - Constructor for class io.ebeaninternal.server.core.ServiceUtil
- set(int, E) - Method in class io.ebeaninternal.json.ModifyAwareList
- set(int, Object) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- set(E) - Method in class io.ebeaninternal.json.ModifyAwareListIterator
- set(Query.Property<P>, P) - Method in class io.ebeaninternal.server.querydefn.DefaultUpdateQuery
- set(SpiTransaction) - Method in class io.ebeaninternal.server.transaction.DefaultTransactionScopeManager
- set(SpiTransaction) - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Set the transaction onto the scope.
- set(SpiTransaction) - Method in class io.ebeaninternal.server.transaction.TransactionScopeManager
-
Set a new Transaction for this serverName and Thread.
- set(String, Object) - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- set(String, Object) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- set(String, Object) - Method in class io.ebeaninternal.server.querydefn.DefaultUpdateQuery
- set(String, Object, ScalarType<Object>) - Method in class io.ebeaninternal.server.querydefn.OrmUpdateProperties
- SET - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
Find returning a Set.
- SET - Enum constant in enum io.ebeaninternal.server.deploy.ManyType
- setAggregation() - Method in class io.ebeaninternal.api.ManyWhereJoins
-
Mark this as part of an aggregation query (so using group by clause).
- setAggregation(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setAggregationPrefix(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set the path to the aggregation.
- setAllDocNested(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Set the nested path that all contained expressions share.
- setAllLoaded(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Set all properties to be loaded (recurse to embedded beans).
- setAllowLoadErrors() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setAllRegionsEnabled(boolean) - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
- setAllRegionsEnabled(boolean) - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Enable or disable all cache regions.
- setArrayParameter(int, Collection<?>) - Method in class io.ebeaninternal.api.BindParams
-
Set a named In parameter that is multi-valued.
- setArrayParameter(int, Collection<?>) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setArrayParameter(String, Collection<?>) - Method in class io.ebeaninternal.api.BindParams
-
Set a named In parameter that is multi-valued.
- setArrayParameter(String, Collection<?>) - Method in interface io.ebeaninternal.api.SpiQuery
-
Bind the named multi-value array parameter which we would use with Postgres ANY.
- setArrayParameter(String, Collection<?>) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setArrayParameter(String, Collection<?>) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setArrayParameter(String, Collection<?>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setArrayParameter(String, Collection<?>) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setAsOfBaseTable() - Method in interface io.ebeaninternal.api.SpiQuery
-
Set when the base table is using history.
- setAsOfBaseTable() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setAutoPersistUpdates(boolean) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setAutoPersistUpdates(boolean) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setAutoPersistUpdates(boolean) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setAutoPersistUpdates(boolean) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setAutoTableMod(boolean) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setAutoTune(boolean) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setAutoTuned(boolean) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set to true if this query has been tuned by autoTune.
- setAutoTuned(boolean) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setBase(OrmQueryProperties) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Set the base / root query properties.
- setBaseTable(TableName, String, String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set the base table.
- setBaseTable(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanTable
-
Set the base table for this BeanTable.
- setBaseTable(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setBatchControl(BatchControl) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Set the BatchControl used to batch up persist requests.
- setBatchControl(BatchControl) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setBatchControl(BatchControl) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Set the BatchControl to the transaction.
- setBatchControl(BatchControl) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Set the BatchControl to the transaction.
- setBatchControl(BatchControl) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Set the BatchControl to the transaction.
- setBatched() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Set when request is added to the JDBC batch.
- setBatchFlushOnMixed(boolean) - Method in class io.ebeaninternal.server.persist.BatchControl
-
Set this flag to false to allow batching of a mix of Beans and UpdateSql (or CallableSql).
- setBatchMode(boolean) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setBatchMode(boolean) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setBatchMode(boolean) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setBatchMode(boolean) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setBatchOnCascade(boolean) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setBatchOnCascade(boolean) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setBatchOnCascade(boolean) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setBatchOnCascade(boolean) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setBatchSize(int) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setBatchSize(int) - Method in class io.ebeaninternal.server.persist.BatchControl
-
Set the size of batch execution.
- setBatchSize(int) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setBatchSize(int) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setBatchSize(int) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setBeanCacheMode(CacheMode) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setBeanCacheMode(CacheMode) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setBeanFinder(BeanFindController) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set the BeanFinder to use for beans of this type.
- setBeanTable(BeanTable) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
-
Set the bean table.
- setBind(BindCapture, long, long) - Method in interface io.ebeaninternal.api.SpiQueryBindCapture
-
Set the captured bind values that we can use later to collect a query plan.
- setBindLog(String) - Method in class io.ebeaninternal.server.core.PersistRequestCallableSql
-
The the log of bind values.
- setBindLog(String) - Method in class io.ebeaninternal.server.core.PersistRequestOrmUpdate
-
Set the bound values.
- setBindLog(String) - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
-
Set the bound values.
- setBound(BindParams, CallableStatement) - Method in class io.ebeaninternal.server.core.PersistRequestCallableSql
-
These need to be set for use with Non-batch execution.
- setBoundId(Object) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Set the Id value that was bound.
- setBufferFetchSizeHint(int) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setBufferFetchSizeHint(int) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setBufferFetchSizeHint(int) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setCache(Cache) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Enable L2 bean and query caching based on Cache annotation.
- setCacheDataValue(EntityBean, Object, PersistenceContext) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Read the value for this property from L2 cache entry and set it to the bean.
- setCacheDataValue(EntityBean, Object, PersistenceContext) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
A Many (element collection) property in bean cache to held as JSON.
- setCacheDataValue(EntityBean, Object, PersistenceContext) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- setCacheDataValue(EntityBean, Object, PersistenceContext) - Method in class io.ebeaninternal.server.deploy.BeanPropertyJsonMapper
- setCancelableQuery(CancelableQuery) - Method in interface io.ebeaninternal.api.SpiCancelableQuery
-
Set the underlying cancelable query (with the PreparedStatement).
- setCancelableQuery(CancelableQuery) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Set a Query object that owns the PreparedStatement that can be cancelled.
- setCancelableQuery(CancelableQuery) - Method in class io.ebeaninternal.server.querydefn.AbstractQuery
- setCatchFirst(boolean) - Method in class io.ebeaninternal.server.deploy.DeployPropertyParser
-
Set to true to catch the first property.
- setChangeLogFilter(ChangeLogFilter) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- setClock(Clock) - Method in class io.ebeaninternal.server.core.ClockService
-
Change the clock for testing purposes.
- setClock(Clock) - Method in class io.ebeaninternal.server.core.DefaultServer
- setColumn(String) - Method in class io.ebeaninternal.server.deploy.PartitionMeta
-
Set the db column being partitioned on.
- setColumnPrefix(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
- setColumns(DeployTableJoinColumn[], boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
-
Copy all the columns to this join potentially reversing the columns.
- setConcurrencyMode(ConcurrencyMode) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set the concurrency mode used for beans of this type.
- setContainsMany() - Method in class io.ebeaninternal.server.el.ElPropertyChainBuilder
- setCountDistinct(CountDistinctOrder) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setCountDistinct(CountDistinctOrder) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setCurrentPrefix(String, Map<String, String>) - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Set the JoinNode - used by proxy/reference beans for profiling.
- setCurrentPrefix(String, Map<String, String>) - Method in class io.ebeaninternal.server.query.CQuery
- setCustomIdGenerator(PlatformIdGenerator) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Assign a custom external IdGenerator.
- setData(String) - Method in class io.ebeaninternal.server.transaction.TransactionProfile
-
Set raw data (for JSON tools).
- setDbColumn(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set the database column name this is mapped to.
- setDbColumnDefault(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setDbColumnDefn(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set a specific DB column definition.
- setDbComment(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- setDbComment(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setDbEncryptFunction(DbEncryptFunction, DbEncrypt, int) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setDbInsertable(boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setDbLength(int) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set the DB column length for character columns.
- setDbRead(boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set to true if this property is included in database queries.
- setDbScale(int) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set the Db scale for numeric columns.
- setDbType(int) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set the database jdbc data type this is mapped to.
- setDbUpdateable(boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setDefaultFetchBuffer(int) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the JDBC fetchSize buffer hint if not explicitly set.
- setDefaultFetchBuffer(int) - Method in interface io.ebeaninternal.api.SpiSqlBinding
-
Set the JDBC fetchSize buffer hint if not explicitly set.
- setDefaultFetchBuffer(int) - Method in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
-
Set the JDBC buffer fetchSize hint if not set explicitly.
- setDefaultFetchBuffer(int) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Set the JDBC buffer fetchSize hint if not set explicitly.
- setDefaultFetchBuffer(int) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setDefaultFetchBuffer(int) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setDefaultFetchBuffer(int) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setDefaultRawSqlIfRequired() - Method in interface io.ebeaninternal.api.SpiQuery
-
If this is a RawSql based entity set the default RawSql if not set.
- setDefaultRawSqlIfRequired() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setDefaultSelectClause() - Method in interface io.ebeaninternal.api.SpiQuery
-
Set default select clauses where none have been explicitly defined.
- setDefaultSelectClause() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setDefaultSelectClause(BeanDescriptor<?>) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Set any default select clauses for the main bean and any joins that have not explicitly defined a select clause.
- setDefaultThreshold(long) - Method in interface io.ebeaninternal.api.QueryPlanManager
-
Update the global default threshold used when new query plans are created.
- setDefaultThreshold(long) - Method in class io.ebeaninternal.server.query.CQueryPlanManager
- setDelete(boolean) - Method in class io.ebeaninternal.server.deploy.BeanCascadeInfo
-
Set to true if delete should cascade.
- setDeleteByIdsPlan() - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the query to be delete by ids due to cascading delete.
- setDeleteByIdsPlan() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setDeployOrder(int) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Set the order this property appears in the bean.
- setDescriptor(BeanDescriptor<?>) - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Set the descriptor for this node.
- setDetail(OrmQueryDetail) - Method in interface io.ebeaninternal.api.SpiQuery
-
Replace the query detail.
- setDetail(OrmQueryDetail) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setDisableLazyLoad(boolean) - Method in class io.ebeaninternal.server.core.DefaultBeanState
- setDisableLazyLoading(boolean) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setDisableLazyLoading(boolean) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setDisableReadAuditing() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setDisableReadAuditing() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setDistinct(boolean) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setDistinct(boolean) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Internally set to use SQL DISTINCT on the query but still have id property included.
- setDocCode(DocCode) - Method in class io.ebeaninternal.server.deploy.DeployDocPropertyOptions
-
Read the DocCode deployment options.
- setDocCode(DocCode) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setDocIndexName(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setDocIndexName(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setDocProperty(DocProperty) - Method in class io.ebeaninternal.server.deploy.DeployDocPropertyOptions
-
Read the DocProperty deployment options.
- setDocProperty(DocProperty) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setDocSortable(DocSortable) - Method in class io.ebeaninternal.server.deploy.DeployDocPropertyOptions
-
Read the DocSortable deployment options.
- setDocSortable(DocSortable) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setDocStoreBatchSize(int) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setDocStoreBatchSize(int) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setDocStoreBatchSize(int) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setDocStoreBatchSize(int) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setDocStoreEmbedded(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
-
Set DocStoreEmbedded deployment information.
- setDocStoreMode(DocStoreMode) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setDocStoreMode(DocStoreMode) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setDocStoreMode(DocStoreMode) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setDocStoreMode(DocStoreMode) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setDraft() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setDraft(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Set the draft to true for this entity bean instance.
- setDraft(EntityBean) - Method in interface io.ebeaninternal.server.query.STreeType
-
Set draft status on the entity bean.
- setDraftable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- setDraftableElement() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- setDraftDirty() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setDraftDirty(EntityBean, boolean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
If there is a @DraftDirty property set it's value on the bean.
- setDraftOnly() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setDraftReset() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setEbeanServer(SpiEbeanServer) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Set the server.
- setEbeanServer(SpiEbeanServer) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
-
Set the internal EbeanServer instance to all BeanDescriptors.
- setEbeanServer(SpiEbeanServer) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Set the lazy load server to help create reference collections (that lazy load on demand).
- setElementCollection() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
- setElementDescriptor(BeanDescriptor<?>) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
- setElementProperty() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set when this property is part of a 'element bean' used with ElementCollection.
- setEmbedded() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set to true if this is an embedded property.
- setEmbedded(boolean) - Method in class io.ebeaninternal.server.el.ElPropertyChainBuilder
-
Permits to set whole chain as embedded when the leaf is embedded
- setEmptyBase() - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Set the base query properties to be empty.
- setEnabled(boolean) - Static method in class io.ebeaninternal.api.HelpScopeTrans
-
Defines if the @Transactional does what is supposed to do or is disabled (useful only unit testing)
- setEnabled(boolean) - Method in class io.ebeaninternal.server.deploy.DCacheRegion
- setEnabledRegions(String) - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
- setEnabledRegions(String) - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Set the regions that are enabled.
- setEncrypted(boolean) - Method in class io.ebeaninternal.server.deploy.DeployParser
- setEncryptionKey(Object) - Method in class io.ebeaninternal.api.BindParams.Param
-
Set an encryption key (which can not be logged).
- setEncryptionKey(String, Object) - Method in class io.ebeaninternal.api.BindParams
-
Set an encryption key as a bind value.
- setEntityType(BeanDescriptor.EntityType) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- setExcludedFromHistory() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setExtraWhere(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
-
Set a literal expression to add to the query that lazy loads the collection.
- setExtraWhere(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
- setFetchOrderBy(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Set the order by clause used to order the fetching or the data for this list, set or map.
- setFetchPreference(int) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
- setFetchType(FetchType) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set the default fetch type for this property.
- setField(Field) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set the bean Field associated with this property.
- setFilterMany(SpiExpressionList<?>) - Method in class io.ebeaninternal.server.querydefn.OrmQueryProperties
-
Set the filterMany expression list.
- setFilterMany(String, ExpressionList<?>) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set a filter to a join path.
- setFilterMany(String, ExpressionList<?>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setFirstRow(int) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setFirstRow(int) - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- setFirstRow(int) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setFirstRow(int) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setFirstRow(int) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setFlushOnMixed(boolean) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setFlushOnMixed(boolean) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setFlushOnMixed(boolean) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setFlushOnMixed(boolean) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setFlushOnQuery(boolean) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setFlushOnQuery(boolean) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setFlushOnQuery(boolean) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setFlushOnQuery(boolean) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setForeignKey(PropertyForeignKey) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
- setForeignSqlFormula(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoinColumn
- setFutureFetchAudit(ReadEvent) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the readEvent for future queries (as prepared in foreground thread).
- setFutureFetchAudit(ReadEvent) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setGeneratedId(EntityBean, Transaction) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Set the generated Id value if appropriate.
- setGeneratedKey(Object) - Method in interface io.ebeaninternal.api.SpiSqlUpdate
-
Set the generated key value.
- setGeneratedKey(Object) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setGeneratedKey(Object) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Set the generated key back to the bean.
- setGeneratedKey(Object) - Method in class io.ebeaninternal.server.core.PersistRequestCallableSql
-
Only called for insert with generated keys.
- setGeneratedKey(Object) - Method in class io.ebeaninternal.server.core.PersistRequestOrmUpdate
-
Not called for this type of request.
- setGeneratedKey(Object) - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
-
Not called for this type of request.
- setGeneratedKey(Object) - Method in interface io.ebeaninternal.server.persist.BatchPostExecute
-
For inserts with generated keys.
- setGeneratedProperty(GeneratedProperty) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set the GeneratedValue.
- setGeneratedSql(String) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the generated sql for debug purposes.
- setGeneratedSql(String) - Method in interface io.ebeaninternal.api.SpiSqlUpdate
-
Set the final sql being executed with named parameters replaced etc.
- setGeneratedSql(String) - Method in interface io.ebeaninternal.api.SpiUpdate
-
Set the generated sql used.
- setGeneratedSql(String) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setGeneratedSql(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setGeneratedSql(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- setGenerateMigration() - Static method in class io.ebeaninternal.api.DbOffline
-
Called when the migration is running is order to stop other plugins like the full DDL generation from executing.
- setGetGeneratedKeys(boolean) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setGetGeneratedKeys(boolean) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setGetGeneratedKeys(boolean) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setGetGeneratedKeys(boolean) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setGetGeneratedKeys(boolean) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setGetGeneratedKeys(Boolean) - Method in class io.ebeaninternal.server.persist.BatchControl
-
Set whether or not to use getGeneratedKeys for this batch execution.
- setGetter(BeanPropertyGetter) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set the getter used to read the property value from a bean.
- setHint(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setHistorySupport() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set to true for @History entity beans that have history.
- setId() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set to true if this is included in the unique id.
- setId(Object) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setId(Object, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Set the Id value to the bean (without type conversion).
- setId(T, Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Set the bean id value converting if necessary.
- setIdClass(Class<?>) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set the IdClass to use.
- setIdentityMode(Identity) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- setIdentitySequence(int, int, String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set from
@Sequence - setIdentitySequenceBatchMode(boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Return the sequence increment to use given sequence batch mode.
- setIdentitySequenceGenerator(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Potentially set sequence name from
@GeneratedValue. - setIdentityType(IdType) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- setIdGeneratedValue() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set when GeneratedValue explicitly mapped on Id property.
- setIdGenerator(PlatformIdGenerator) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set the actual IdGenerator for this bean type.
- setIdProperty(DeployBeanProperty) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanTable
-
Set the Id properties.
- setIdType(IdType) - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- setImportedOrphanForRemoval(BeanPropertyAssocOne<?>) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Set an orphan bean that needs to be deleted AFTER the request has persisted.
- setImportedPrimaryKey() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setImportedPrimaryKeyColumn(DeployBeanProperty) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set to true if this is part of the primary key.
- setImportedPrimaryKeyColumn(DeployBeanProperty) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
-
Set to true if this is part of the primary key.
- setIncludeSoftDeletes() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setIncludeSoftDeletes() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setIncrement(int) - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- setInheritInfo(InheritInfo) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set the ORM inheritance mapping information.
- setInheritInfo(InheritInfo) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
- setInheritType(Class<? extends T>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setInlineCountDistinct() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- setInNullType(int) - Method in class io.ebeaninternal.api.BindParams.Param
-
Specify that the In parameter is NULL and the specific type that it is.
- setInsert(int) - Static method in class io.ebeaninternal.server.persist.Flags
-
Set Insert flag.
- setInsertNormal(int) - Static method in class io.ebeaninternal.server.persist.Flags
-
Insert flag and normal in that bean is in NEW state (for insert).
- setInsertOptions(InsertOptions) - Method in class io.ebeaninternal.server.core.PersistRequestBean
- setIntersectionDraftTable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
ManyToMany between 2 @Draftable entities to also need draft intersection table.
- setIntersectionJoin(DeployTableJoin) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
ManyToMany only, join from local table to intersection table.
- setInvalidateQueryCache(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set that this type invalidates query caches.
- setInValue(Object) - Method in class io.ebeaninternal.api.BindParams.Param
-
Set the In value.
- setInverseJoin(DeployTableJoin) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
ManyToMany only, join from foreign table to intersection table.
- setJoinColumns(DeployTableJoinColumn[], boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
- setJoinType(boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
- setJsonDeserialize(boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setJsonSerialize(boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setLabel(String) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setLabel(String) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setLabel(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setLabel(String) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setLabel(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setLabel(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- setLabel(String) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setLabel(String) - Method in class io.ebeaninternal.server.querydefn.DefaultUpdateQuery
- setLabel(String) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setLabel(String) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setLabel(String) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setLazyLoadBatchSize(int) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setLazyLoadedChildBean(EntityBean, Object) - Method in interface io.ebeaninternal.server.deploy.DbReadContext
-
Set back the bean that has just been loaded with its id.
- setLazyLoadedChildBean(EntityBean, Object) - Method in class io.ebeaninternal.server.query.CQuery
- setLazyLoadForParents(BeanPropertyAssocMany<?>) - Method in interface io.ebeaninternal.api.SpiQuery
-
This becomes a lazy loading query for a many relationship.
- setLazyLoadForParents(BeanPropertyAssocMany<?>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setLazyLoadManyPath(String) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the path of the many when +query/+lazy loading query is executed.
- setLazyLoadManyPath(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setLazyLoadProperty(String) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the property that invoked the lazy load and MUST be included in the lazy loading query.
- setLazyLoadProperty(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setLoadDescription(String, String) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the load mode (+lazy or +query) and the load description.
- setLoadDescription(String, String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setLoaded() - Method in class io.ebeaninternal.server.core.DefaultBeanState
- setLoader(BeanCollectionLoader) - Method in class io.ebeaninternal.server.deploy.BeanListHelp
- setLoader(BeanCollectionLoader) - Method in class io.ebeaninternal.server.deploy.BeanListHelpElement
- setLoader(BeanCollectionLoader) - Method in class io.ebeaninternal.server.deploy.BeanMapHelp
- setLoader(BeanCollectionLoader) - Method in class io.ebeaninternal.server.deploy.BeanMapHelpElement
- setLoader(BeanCollectionLoader) - Method in class io.ebeaninternal.server.deploy.BeanSetHelp
- setLoader(BeanCollectionLoader) - Method in class io.ebeaninternal.server.deploy.BeanSetHelpElement
- setLoader(BeanCollectionLoader) - Method in interface io.ebeaninternal.server.deploy.BeanCollectionHelp
-
Set the EbeanServer that owns the configuration.
- setLocalEncrypted() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set to true when the property is encrypted in java rather than in the DB.
- setM2MIncludeJoin(TableJoin) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the extra join for a M2M lazy load.
- setM2MIncludeJoin(TableJoin) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setManualId() - Method in interface io.ebeaninternal.api.SpiQuery
-
Set to true when we only include the Id property if it is explicitly included in the select().
- setManualId() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setManyToMany() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Set to true if this is a many to many.
- setMapKey(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Set the default mapKey to use when returning a Map.
- setMapKey(String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setMapKey(String) - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- setMapKey(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setMappedBy(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
-
Set mappedBy deployment attribute.
- setMarkedDirty(boolean) - Method in class io.ebeaninternal.json.ModifyAwareFlag
- setMarkedDirty(boolean) - Method in class io.ebeaninternal.json.ModifyAwareList
- setMarkedDirty(boolean) - Method in class io.ebeaninternal.json.ModifyAwareMap
- setMarkedDirty(boolean) - Method in class io.ebeaninternal.json.ModifyAwareSet
- setMaxRows(int) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setMaxRows(int) - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- setMaxRows(int) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setMaxRows(int) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setMaxRows(int) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setMerge(int) - Static method in class io.ebeaninternal.server.persist.Flags
-
Set Merge flag.
- setMode(SpiQuery.Mode) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the query mode.
- setMode(SpiQuery.Mode) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setModifyListenMode(BeanCollection.ModifyListenMode) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Set the mode for listening to changes to the List Set or Map.
- setMutationDetection(MutationDetection) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setName(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set the bean shortName.
- setName(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set the name of the property.
- setNativeSql(String) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setNestedUseSavepoint() - Method in class io.ebeaninternal.api.ScopedTransaction
- setNestedUseSavepoint() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setNestedUseSavepoint() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setNestedUseSavepoint() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setNestedUseSavepoint() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setNextParameter(Object) - Method in class io.ebeaninternal.api.BindParams
-
Bind the next positioned parameter.
- setNextParameters(Object...) - Method in class io.ebeaninternal.api.BindParams
- setNotifyCache(boolean) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
-
Set this to false if you don't want eBean to automatically deduce the table modification information and process it.
- setNull(int, int) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setNull(int, int) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- setNull(Query.Property<?>) - Method in class io.ebeaninternal.server.querydefn.DefaultUpdateQuery
- setNull(String) - Method in class io.ebeaninternal.server.querydefn.DefaultUpdateQuery
- setNull(String) - Method in class io.ebeaninternal.server.querydefn.OrmUpdateProperties
- setNull(String, int) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setNull(String, int) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- setNullable(boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set the not nullable of this property.
- setNullParameter(int, int) - Method in class io.ebeaninternal.api.BindParams
-
Set a null parameter using position.
- setNullParameter(int, int) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setNullParameter(int, int) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setNullParameter(int, int) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- setNullParameter(int, int) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setNullParameter(String, int) - Method in class io.ebeaninternal.api.BindParams
-
Set a named In parameter that is null.
- setNullParameter(String, int) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setNullParameter(String, int) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setNullParameter(String, int) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- setNullParameter(String, int) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setO2mJoinTable() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
- setOneToOne() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
-
Set to true if this is a OneToOne.
- setOneToOneExported() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
-
Set to true if this is the exported side of a OneToOne.
- setOrderBy(OrderBy<T>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setOrderColumn(DeployBeanProperty) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- setOrderColumn(DeployOrderColumn) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
- setOrigin(CallOrigin) - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the origin point for the query.
- setOrigin(CallOrigin) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setOrphanRemoval() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
- setOutType(int) - Method in class io.ebeaninternal.api.BindParams.Param
-
Set the Out parameter type.
- setOutValue(Object) - Method in class io.ebeaninternal.api.BindParams.Param
-
Set the OUT value returned by a CallableStatement after it has executed.
- setOwningType(Class<?>) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set to the owning type form a Inheritance heirarchy.
- setPaging(Paging) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setParameter(int, Object) - Method in class io.ebeaninternal.api.BindParams
-
Using position set the In value of a parameter.
- setParameter(int, Object) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setParameter(int, Object) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setParameter(int, Object) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Set an ordered bind parameter according to its position.
- setParameter(int, Object) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- setParameter(int, Object) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setParameter(int, Object, int) - Method in class io.ebeaninternal.api.BindParams
-
Set an In Out parameter using position.
- setParameter(Object) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setParameter(Object) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setParameter(Object) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setParameter(Object) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setParameter(String, Object) - Method in class io.ebeaninternal.api.BindParams
-
Set a named In parameter that is not null.
- setParameter(String, Object) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setParameter(String, Object) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setParameter(String, Object) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Set a named bind parameter.
- setParameter(String, Object) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- setParameter(String, Object) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setParameter(String, Object, int) - Method in class io.ebeaninternal.api.BindParams
-
Set a named In Out parameter.
- setParameters(Object...) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setParameters(Object...) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setParameters(Object...) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setParameters(Object...) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setParentBeanToChild(EntityBean, EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Set the parent bean to the child bean if it has not already been set.
- setParentNode(ObjectGraphNode) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the profile point of the bean or collection that is lazy loading.
- setParentNode(ObjectGraphNode) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setParentToChild(EntityBean, EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Set the parent bean to the child (update the relationship).
- setParentToChild(EntityBean, EntityBean, Object, BeanDescriptor<?>) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocMany
-
Return true if the parent bean has been set to the child (updated the relationship).
- setPartitionMeta(PartitionMeta) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- setPersistCascade(boolean) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setPersistCascade(boolean) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setPersistCascade(boolean) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setPersistCascade(boolean) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setPersistenceContext(PersistenceContext) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set an explicit TransactionContext (typically for a refresh query).
- setPersistenceContext(PersistenceContext) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Set an explicit TransactionContext (typically for a refresh query).
- setPersistenceContext(SpiPersistenceContext) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Set the persistence context to this transaction.
- setPersistenceContext(SpiPersistenceContext) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setPersistenceContext(SpiPersistenceContext) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Set the persistence context to this transaction.
- setPersistenceContext(SpiPersistenceContext) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Set the persistence context to this transaction.
- setPersistenceContext(SpiPersistenceContext) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Set the persistence context to this transaction.
- setPersistenceContextScope(PersistenceContextScope) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setPlatform(Platform) - Static method in class io.ebeaninternal.api.DbOffline
-
Set the platform to use when creating the next EbeanServer instance.
- setPlatform(String) - Static method in class io.ebeaninternal.api.DbOffline
-
Set the platform to use when creating the next EbeanServer instance.
- setPlatformType(IdType) - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- setPreparedSql(String) - Method in class io.ebeaninternal.api.BindParams
-
Set the sql with named parameters replaced with place holder ?.
- setPrimaryKeyExport() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
-
Set as export side of OneToOne with PrimaryKeyJoin.
- setPrimaryKeyJoin(boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
-
Mark as PrimaryKeyJoin (we don't know which side is the export side initially).
- setPrimaryKeyJoin(TableJoin) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
PK is also a FK.
- setProfileLocation(ProfileLocation) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Set the profile location for this transaction.
- setProfileLocation(ProfileLocation) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setProfileLocation(ProfileLocation) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setProfileLocation(ProfileLocation) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setProfileLocation(ProfileLocation) - Method in class io.ebeaninternal.server.querydefn.DefaultUpdateQuery
- setProfileLocation(ProfileLocation) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setProfileLocation(ProfileLocation) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setProfileLocation(ProfileLocation) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setProfilePath(String, String, ProfileLocation) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the on a secondary query given the label, relativePath and profile location of the parent query.
- setProfilePath(String, String, ProfileLocation) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setProfileStream(ProfileStream) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Set the profileStream to catch and time all the events for this transaction.
- setProfileStream(ProfileStream) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setProfileStream(ProfileStream) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setProfileStream(ProfileStream) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setProfileStream(ProfileStream) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setProfilingListener(ProfilingListener) - Method in interface io.ebeaninternal.api.SpiQuery
-
This has the effect of turning on profiling for this query.
- setProfilingListener(ProfilingListener) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setPropertyIndex(int) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setPropertyLoaded(String, boolean) - Method in class io.ebeaninternal.server.core.DefaultBeanState
- setPropertyNames(String[]) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- setPublish(int) - Static method in class io.ebeaninternal.server.persist.Flags
-
Set Publish flag.
- setRaw(String) - Method in class io.ebeaninternal.server.querydefn.DefaultUpdateQuery
- setRaw(String) - Method in class io.ebeaninternal.server.querydefn.OrmUpdateProperties
-
Set a raw expression with no bind values.
- setRaw(String, Object...) - Method in class io.ebeaninternal.server.querydefn.DefaultUpdateQuery
- setRawSql(RawSql) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setReadAuditing() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set read auditing on for this entity bean.
- setReadOnly(boolean) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setReadOnly(boolean) - Method in class io.ebeaninternal.server.core.DefaultBeanState
- setReadOnly(boolean) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setReadOnly(boolean) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setReadOnly(boolean) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setReadOnly(boolean) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setRecurse(int) - Static method in class io.ebeaninternal.server.persist.Flags
-
Set Recurse flag.
- setRelaxedMode() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setRequireOuterJoins(boolean) - Method in class io.ebeaninternal.api.ManyWhereJoins
-
Set the 'mode' to be that joins added are required to be outer joins.
- setResultSet(ResultSet, Object) - Method in class io.ebeaninternal.server.core.DtoQueryRequest
- setResultSet(ResultSet, Object) - Method in class io.ebeaninternal.server.core.RelationalQueryRequest
- setRollbackOnly() - Method in class io.ebeaninternal.api.ScopedTransaction
- setRollbackOnly() - Method in class io.ebeaninternal.api.ScopeTrans
-
Mark the underlying transaction as rollback only.
- setRollbackOnly() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Mark the transaction as rollback only.
- setRollbackOnly() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Mark the transaction as rollback only.
- setRollbackOnly() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Mark the transaction as rollback only.
- setSaveDelete(boolean, boolean) - Method in class io.ebeaninternal.server.deploy.BeanCascadeInfo
-
Set cascade save and delete settings.
- setSaveRecurse() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Set when this request is from cascading persist.
- setScalarType(ScalarType<?>) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setSecondaryTable(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set to true if this property is included in persisting.
- setSecondaryTableJoin(DeployTableJoin, String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setSelectId() - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the query to select the id property only.
- setSelectId() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Set the select clause to select the Id property.
- setSelectLastInsertedId(String, String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set the SQL used to return the last inserted Id.
- setSequence(int, int, String) - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- setSequenceBatchMode(boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- setSequenceGenerator(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- setSequenceName(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- setServer(SpiEbeanServer) - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- setSetter(BeanPropertySetter) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set the setter used to set the property value to a bean.
- setSingleAttribute() - Method in interface io.ebeaninternal.api.SpiQuery
-
Mark the query as selecting a single attribute.
- setSingleAttribute() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setSkipBatchForTopLevel() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- setSkipCache(boolean) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setSkipCache(boolean) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setSkipCache(boolean) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setSkipCache(boolean) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setSoftDelete() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setSortOrder(int) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set the sortOrder for the properties.
- setSqlFormula(String, String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
The property is based on a formula.
- setSqlFormula(String, String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocOne
- setStart(int) - Method in class io.ebeaninternal.server.deploy.meta.DeployIdentityMode
- setStorageEngine(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- setSummary(TransactionProfile.Summary) - Method in class io.ebeaninternal.server.transaction.TransactionProfile
- setTable(String) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
-
set the joined table name.
- setTablespaceMeta(TablespaceMeta) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- setTargetType(Class<?>) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssoc
- setTenantId() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setTenantId(EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Set the Tenant Id value to the bean.
- setTenantId(Object) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the tenantId to use for lazy loading.
- setTenantId(Object) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Set the current Tenant Id.
- setTenantId(Object) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setTenantId(Object) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setTenantId(Object) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setTenantId(Object) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setTenantId(Object) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setTenantValue(EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Set the tenantId onto the bean.
- setTenantValue(EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- setTimeout(int) - Method in class io.ebeaninternal.server.core.DefaultSqlUpdate
- setTimeout(int) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- setTimeout(int) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setTimeout(int) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- setTimeout(int) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- setTotalMicros(long) - Method in class io.ebeaninternal.server.transaction.TransactionProfile
-
Set total micros (for JSON tools).
- setTrans(SpiTransaction) - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Set the transaction from prior persist request.
- setTransactionManager(Object) - Method in class io.ebeaninternal.server.transaction.JtaTransactionManager
-
Initialise this with the Ebean internal transaction manager.
- setTransient() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Mark the property explicitly as a transient property.
- setType(SpiQuery.Type) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the query type (List, Set etc).
- setType(SpiQuery.Type) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setType(PersistRequestUpdateSql.SqlType, String) - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
-
Specify the type of statement executed.
- setType(SqlJoinType) - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
- setType(CascadeType) - Method in class io.ebeaninternal.server.deploy.BeanCascadeInfo
- setTypes(CascadeType[]) - Method in class io.ebeaninternal.server.deploy.BeanCascadeInfo
- setUnderlying(List<SpiExpression>) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Replace the underlying expression list with one organised by nested path.
- setUndirectionalShadow() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Mark this property as a placeholder for a unidirectional relationship.
- setUnidirectional() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanPropertyAssocMany
-
Set to true if this is a unidirectional relationship.
- setUnidirectional(DeployBeanPropertyAssocOne<?>) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- setUnique(boolean) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set to true if the DB column is unique.
- setUnmappedJson() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- setUpdate(int) - Static method in class io.ebeaninternal.server.persist.Flags
-
Parent was not inserted.
- setUpdateAllLoadedProperties(boolean) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- setUpdateAllLoadedProperties(boolean) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- setUpdateAllLoadedProperties(boolean) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- setUpdateAllLoadedProperties(boolean) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- setUpdatedMany() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- setUpdateNormal(int) - Static method in class io.ebeaninternal.server.persist.Flags
-
Not Insert and normal in that bean is in LOADED state (for update).
- setupForDeleteOrUpdate() - Method in interface io.ebeaninternal.api.SpiQuery
-
Set the query to be a delete query.
- setupForDeleteOrUpdate() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Setup to be a delete or update query.
- setUsageProfiling(boolean) - Method in interface io.ebeaninternal.api.SpiQuery
-
Set to false if this query should not be included in the AutoTune usage profiling information.
- setUsageProfiling(boolean) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setUseCache(boolean) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setUseCache(boolean) - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- setUseDocStore(boolean) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setUseDocStore(boolean) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setUseQueryCache(CacheMode) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- setUseQueryCache(CacheMode) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- setUuidGenerator() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Assign the standard UUID generator if one has not been set.
- setValue(EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Set the value of the property without interception or PropertyChangeSupport.
- setValue(EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- setValue(EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyIdClass
- setValue(EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyOrderColumn
- setValue(EntityBean, Object) - Method in interface io.ebeaninternal.server.query.STreePropertyAssoc
-
Add a bean to the parent.
- setValueChanged(EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Set the changed value without invoking interception (lazy loading etc).
- setValueIntercept(EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Set the value of the property.
- setValueIntercept(EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
- setValueIntercept(EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyIdClass
- setValueIntercept(EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanPropertyOrderColumn
- setVersion(EntityBean, Object) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Set the version value returning it in primitive long form.
- setVersionColumn() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
-
Set if this is a version column used for concurrency checking.
- setView(String, String[]) - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Set when entity is based on a view.
- shards() - Method in class io.ebeanservice.docstore.api.mapping.DocumentMapping
-
Return the number of shards.
- shards(int) - Method in class io.ebeanservice.docstore.api.mapping.DocumentMapping
-
Set the number of shards.
- shortName - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- should() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- shutdown() - Method in interface io.ebeaninternal.api.SpiBackgroundExecutor
-
Shutdown any associated thread pools.
- shutdown() - Method in interface io.ebeaninternal.server.autotune.AutoTuneService
-
On shutdown fire garbage collection and collect statistics.
- shutdown() - Method in class io.ebeaninternal.server.autotune.NoAutoTuneService
- shutdown() - Method in interface io.ebeaninternal.server.cluster.ClusterBroadcast
-
Inform the other cluster members that this instance is leaving and shutdown any listeners.
- shutdown() - Method in class io.ebeaninternal.server.cluster.ClusterManager
-
Shutdown the service and Deregister from the cluster.
- shutdown() - Method in class io.ebeaninternal.server.core.DefaultContainer
- shutdown() - Method in class io.ebeaninternal.server.core.DefaultServer
- shutdown() - Method in class io.ebeaninternal.server.transaction.DefaultProfileHandler
- shutdown(boolean) - Method in interface io.ebeaninternal.server.transaction.DataSourceSupplier
-
Shutdown the datasource de-registering the JDBC driver if requested.
- shutdown(boolean, boolean) - Method in class io.ebeaninternal.server.core.DefaultServer
- shutdown(boolean, boolean) - Method in class io.ebeaninternal.server.transaction.TransactionManager
- SimpleAesEncryptor - Class in io.ebeaninternal.server.type
-
Simple AES based encryption and decryption.
- SimpleAesEncryptor() - Constructor for class io.ebeaninternal.server.type.SimpleAesEncryptor
- SimpleDataTimeZone - Class in io.ebeaninternal.server.core.timezone
-
Implementation of DataTimeZone when single Calendar instance is used.
- SimpleDataTimeZone(String) - Constructor for class io.ebeaninternal.server.core.timezone.SimpleDataTimeZone
- SimpleExpression - Class in io.ebeaninternal.server.expression
- SimpleExpression(String, Op, Object) - Constructor for class io.ebeaninternal.server.expression.SimpleExpression
- simpleName() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the simple name of the entity bean.
- SimpleTextParser - Class in io.ebeaninternal.server.querydefn
- SimpleTextParser(String) - Constructor for class io.ebeaninternal.server.querydefn.SimpleTextParser
- simplify() - Method in interface io.ebeaninternal.api.SpiExpression
-
Simplify nested expressions if possible.
- simplify() - Method in class io.ebeaninternal.server.expression.InExpression
- simplify() - Method in class io.ebeaninternal.server.expression.SimpleExpression
- simplify() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- simplify() - Method in class io.ebeaninternal.server.expression.IdInExpression
- simplifyExpressions() - Method in interface io.ebeaninternal.api.SpiQuery
-
Simplify nested expression lists where possible.
- simplifyExpressions() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- size() - Method in class io.ebeaninternal.api.BindParams.OrderedList
-
Return the number of bind parameters in this list.
- size() - Method in class io.ebeaninternal.api.BindParams
- size() - Method in interface io.ebeaninternal.api.LoadManyBuffer
-
The actual size.
- size() - Method in class io.ebeaninternal.api.NaturalKeySet
- size() - Method in class io.ebeaninternal.json.ModifyAwareList
- size() - Method in class io.ebeaninternal.json.ModifyAwareMap
- size() - Method in class io.ebeaninternal.json.ModifyAwareSet
- size() - Method in class io.ebeaninternal.server.cache.DefaultServerCache
-
Return the number of elements in the cache.
- size() - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Return the number of properties that make up the id.
- size() - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- size() - Method in class io.ebeaninternal.server.persist.BatchedPstmt
-
Return the number of batched statements.
- size() - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- size() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping
-
Return the number of columns in this column mapping.
- size() - Method in class io.ebeaninternal.server.util.ArrayStack
- size(Class<?>) - Method in class io.ebeaninternal.server.transaction.DefaultPersistenceContext
- skipWordConvert() - Method in class io.ebeaninternal.server.deploy.DeployPropertyParser
-
Skip if in raw sql expression with from tableName or join tableName.
- slowQueryCheck(long, int) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Check for slow query event.
- slowQueryCheck(long, int, SpiQuery<?>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Check for slow query event.
- slowQueryCheck(long, int, SpiQuery<?>) - Method in class io.ebeaninternal.server.core.DefaultServer
- SOFT - Enum constant in enum io.ebeaninternal.server.persist.DeleteMode
-
Soft/logical delete.
- SOFT_DELETED - Enum constant in enum io.ebeaninternal.api.SpiQuery.TemporalMode
-
Includes soft deletes rows in the result.
- softDeleted(Object) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistListener
- softDeletePredicate(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- softDeletePredicate(String) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
- softDeletePredicate(String) - Method in interface io.ebeaninternal.server.query.STreePropertyAssoc
-
Return the soft delete predicate.
- softDeletePredicate(String) - Method in interface io.ebeaninternal.server.query.STreeType
-
Return the soft delete predicate using the given table alias.
- softDeletePredicates() - Method in interface io.ebeaninternal.api.SpiQuery
- softDeletePredicates() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- softDeleteValue(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- sort(String) - Method in class io.ebeaninternal.server.el.ElFilter
- sort(List<ImportedIdSimple>) - Static method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
-
Return the list as an array sorted into the same order as the Bean Properties.
- sort(List<T>, String) - Method in class io.ebeaninternal.server.core.DefaultServer
- sort(List<T>, String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- sortable() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- sortable(Boolean) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- sortableMap - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
Map of properties to 'raw' properties.
- sortFetchPaths(BeanDescriptor<?>) - Method in class io.ebeaninternal.server.querydefn.OrmQueryDetail
-
Sort the fetch paths into depth order adding any missing parent paths if necessary.
- sortOrder() - Method in class io.ebeaninternal.server.core.DefaultBeanState
- sortProperties() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
- SpiBackgroundExecutor - Interface in io.ebeaninternal.api
-
Internal Extension to BackgroundExecutor with shutdown.
- SpiBeanType - Interface in io.ebeaninternal.api
-
SPI interface for underlying BeanDescriptor.
- SpiBeanTypeManager - Interface in io.ebeaninternal.api
-
Manager of SpiBeanTypes.
- SpiCacheControl - Interface in io.ebeaninternal.api
- SpiCacheManager - Interface in io.ebeaninternal.server.cache
-
The cache service for server side caching of beans and query results.
- SpiCacheRegion - Interface in io.ebeaninternal.api
-
Cache region can be enabled independently.
- SpiCallableSql - Interface in io.ebeaninternal.api
- SpiCancelableQuery - Interface in io.ebeaninternal.api
-
Cancellable query, that has a delegate.
- SpiDbQueryPlan - Interface in io.ebeaninternal.api
-
Internal database query plan being capture.
- SpiDdlGenerator - Interface in io.ebeaninternal.api
-
DDL generate and run for drop all/create all.
- SpiDdlGeneratorProvider - Interface in io.ebeaninternal.api
-
Provides the DDL Generator for create-all/drop-all.
- SpiDtoQuery<T> - Interface in io.ebeaninternal.api
-
Internal extension to DtoQuery.
- SpiEbeanServer - Interface in io.ebeaninternal.api
-
Service Provider extension to EbeanServer.
- SpiExpression - Interface in io.ebeaninternal.api
-
An expression that becomes part of a Where clause or Having clause.
- SpiExpressionBind - Interface in io.ebeaninternal.api
-
Expression bind values capture.
- SpiExpressionFactory - Interface in io.ebeaninternal.api
- SpiExpressionList<T> - Interface in io.ebeaninternal.api
-
Internal extension of ExpressionList.
- SpiExpressionRequest - Interface in io.ebeaninternal.api
-
Request object used for gathering expression sql and bind values.
- SpiExpressionValidation - Class in io.ebeaninternal.api
-
Property expression validation request for a given root bean type.
- SpiExpressionValidation(BeanType<?>) - Constructor for class io.ebeaninternal.api.SpiExpressionValidation
- SpiFetchGroup<T> - Interface in io.ebeaninternal.server.querydefn
-
Service API of FetchGroup.
- SpiJsonContext - Interface in io.ebeaninternal.api
-
Extended Json Context for internal server use.
- SpiJsonReader - Interface in io.ebeaninternal.api.json
- SpiJsonWriter - Interface in io.ebeaninternal.api.json
-
Internal API extensions for JSON writing of Bean properties.
- SpiJunction<T> - Interface in io.ebeaninternal.api
-
SPI methods for Junction.
- SpiLogger - Interface in io.ebeaninternal.api
-
Logger for SQL, TXN and Summary logging.
- SpiLoggerFactory - Interface in io.ebeaninternal.api
-
API for Plugins to define the logger for io.ebean.SQL, io.ebean.TXN and io.ebean.SUM.
- SpiLogManager - Interface in io.ebeaninternal.api
-
Log manager for SQL, TXN and Summary logging.
- SpiNamedParam - Interface in io.ebeaninternal.api
- SpiOrmQueryRequest<T> - Interface in io.ebeaninternal.server.core
-
Defines the ORM query request api.
- SpiPersistenceContext - Interface in io.ebeaninternal.api
-
SPI extension to PersistenceContext.
- SpiProfileHandler - Interface in io.ebeaninternal.api
-
Handle the logging or processing of transaction profiling information that is collected.
- SpiProfileTransactionEvent - Interface in io.ebeaninternal.api
-
Event that adds to a profiling transaction.
- SpiQuery<T> - Interface in io.ebeaninternal.api
-
Object Relational query - Internal extension to Query object.
- SpiQuery.Mode - Enum in io.ebeaninternal.api
- SpiQuery.TemporalMode - Enum in io.ebeaninternal.api
- SpiQuery.Type - Enum in io.ebeaninternal.api
-
The type of query result.
- SpiQueryBindCapture - Interface in io.ebeaninternal.api
-
Capture query bind values and with those actual database query plans.
- SpiQueryFetch - Interface in io.ebeaninternal.api
-
Query select and fetch properties (that avoids parsing).
- SpiQueryManyJoin - Interface in io.ebeaninternal.api
-
A SQL Join for a ToMany property included in the query.
- SpiQueryPlan - Interface in io.ebeaninternal.api
-
The internal ORM "query plan".
- SpiQuerySecondary - Interface in io.ebeaninternal.api
-
The secondary query paths for 'query joins' and 'lazy loading'.
- SpiRawSql - Interface in io.ebeaninternal.server.rawsql
-
Internal service API for Raw Sql.
- SpiRawSql.ColumnMapping - Class in io.ebeaninternal.server.rawsql
-
Defines the column mapping for raw sql DB columns to bean properties.
- SpiRawSql.ColumnMapping.Column - Class in io.ebeaninternal.server.rawsql
-
A Column of the RawSql that is mapped to a bean property (or ignored).
- SpiRawSql.Key - Class in io.ebeaninternal.server.rawsql
-
A key for the RawSql object using for the query plan.
- SpiRawSql.Sql - Class in io.ebeaninternal.server.rawsql
-
Represents the sql part of the query.
- SpiResultSet - Class in io.ebeaninternal.server.core
-
Hold the JDBC PreparedStatement and ResultSet.
- SpiResultSet(PreparedStatement, ResultSet) - Constructor for class io.ebeaninternal.server.core.SpiResultSet
- SpiSqlBinding - Interface in io.ebeaninternal.api
-
SQL query binding (for SqlQuery and DtoQuery).
- SpiSqlQuery - Interface in io.ebeaninternal.api
-
SQL query - Internal extension to SqlQuery.
- SpiSqlUpdate - Interface in io.ebeaninternal.api
- SpiTransaction - Interface in io.ebeaninternal.api
-
Extends Transaction with additional API required on server.
- SpiTransactionManager - Interface in io.ebeaninternal.api
-
Service provider interface for the transaction manager.
- SpiTransactionProxy - Class in io.ebeaninternal.api
-
Proxy for an underlying SpiTransaction (most of the API).
- SpiTransactionProxy() - Constructor for class io.ebeaninternal.api.SpiTransactionProxy
- SpiTransactionScopeManager - Interface in io.ebeaninternal.api
- SpiTxnLogger - Interface in io.ebeaninternal.api
-
Per Transaction logging of SQL, TXN and Summary messages.
- SpiUpdate<T> - Interface in io.ebeaninternal.api
-
Internal extension to the Update interface.
- SpiUpdate.OrmUpdateType - Enum in io.ebeaninternal.api
-
The type of the update request.
- SpiUpdatePlan - Interface in io.ebeaninternal.api
-
A plan for executing bean updates for a given set of changed properties.
- SQ_EX - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
A sub-query expression used as part of where clause.
- SQ_EXISTS - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
A sub-query used as part of an exists where clause.
- sql - Variable in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
- sql() - Method in interface io.ebeaninternal.api.SpiExpressionRequest
-
Return the accumulated expression sql for all expressions in this request.
- sql() - Method in interface io.ebeaninternal.api.SpiLogManager
-
Hmmmm, return the SQL logger for logging truncate statements.
- sql() - Method in interface io.ebeaninternal.api.SpiQueryPlan
-
The SQL for the query plan.
- sql() - Method in interface io.ebeaninternal.api.SpiUpdatePlan
-
Return the update SQL statement.
- sql() - Method in class io.ebeaninternal.server.expression.DefaultExpressionRequest
- sql() - Method in class io.ebeaninternal.server.persist.BatchedPstmt
-
Return the sql
- sql() - Method in class io.ebeaninternal.server.query.CQueryPlan
- sql(String, Object...) - Method in interface io.ebeaninternal.api.SpiTxnLogger
-
Log a SQL message.
- SQL - Enum constant in enum io.ebeaninternal.server.deploy.BeanDescriptor.EntityType
- SQL_DELETE - Enum constant in enum io.ebeaninternal.server.core.PersistRequestUpdateSql.SqlType
- SQL_FALSE - Static variable in interface io.ebeaninternal.api.SpiExpression
- SQL_INSERT - Enum constant in enum io.ebeaninternal.server.core.PersistRequestUpdateSql.SqlType
- SQL_TRUE - Static variable in interface io.ebeaninternal.api.SpiExpression
- SQL_UNKNOWN - Enum constant in enum io.ebeaninternal.server.core.PersistRequestUpdateSql.SqlType
- SQL_UPDATE - Enum constant in enum io.ebeaninternal.server.core.PersistRequestUpdateSql.SqlType
- sqlAppend(DbSqlContext) - Method in interface io.ebeaninternal.server.deploy.id.ImportedId
-
Append the the SQL query statement.
- sqlAppend(DbSqlContext) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdEmbedded
- sqlAppend(DbSqlContext) - Method in class io.ebeaninternal.server.deploy.id.ImportedIdSimple
- SqlBeanLoad - Class in io.ebeaninternal.server.query
-
Controls the loading of property data into a bean.
- sqlJoinType() - Method in class io.ebeaninternal.api.PropertyJoin
-
Return true if this join is required to be an outer join.
- SqlJoinType - Enum in io.ebeaninternal.server.query
-
Inner join, Outer join or automatic determination based on cardinality and optionality.
- sqlQuery(String) - Method in class io.ebeaninternal.server.core.DefaultServer
- sqlRow(ResultSet, String, boolean) - Method in class io.ebeaninternal.server.rawsql.DRawSqlService
- SqlTreeBuilder - Class in io.ebeaninternal.server.query
-
Factory for SqlTree.
- SqlTreeJoin - Interface in io.ebeaninternal.server.query
-
Extra Sql joins conditionally added if required (after children are joined).
- SqlTreeProperties - Class in io.ebeaninternal.server.query
-
The select properties for a node in the SqlTree.
- sqlUpdate(String) - Method in class io.ebeaninternal.server.core.DefaultServer
- Standard() - Constructor for class io.ebeaninternal.server.deploy.BindMaxLength.Standard
- start() - Method in class io.ebeaninternal.server.core.DefaultServer
-
Start any services after registering with the ClusterManager.
- start(int) - Method in class io.ebeaninternal.api.BinaryWriteContext
-
Start a message part with a given type code.
- startBind(boolean) - Method in class io.ebeaninternal.server.core.PersistRequest
-
Effectively set start nanos if we are collecting metrics on a label.
- startBind(boolean) - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
- startBool(Junction.Type) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Start a junction.
- startBoolGroup() - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Start a Bool which may contain Must, Must Not, Should.
- startBoolGroupList(Junction.Type) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Start a Must, Must Not or Should list.
- startBoolMust() - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Start a conjunction.
- startBoolMustNot() - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Start a boolean NOT.
- startGroupBy() - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Start group by clause.
- startNano - Variable in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
- startNanos - Variable in class io.ebeaninternal.server.core.PersistRequest
- startNanoTime() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the start timestamp for the transaction (JVM side).
- startNanoTime() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- startNanoTime() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- startNanoTime() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- startNanoTime() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- startNested(String) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Start nested path expressions.
- startNot() - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Start a not wrapping an expression.
- startsWith(String) - Method in class io.ebeaninternal.server.el.CharMatch
- startsWith(String, String) - Method in class io.ebeaninternal.server.el.ElFilter
- startsWith(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
-
Starts With - property like value%.
- startsWith(String, String) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- startup() - Method in interface io.ebeaninternal.server.autotune.AutoTuneService
-
Load the query tuning information.
- startup() - Method in class io.ebeaninternal.server.autotune.NoAutoTuneService
- startup() - Method in interface io.ebeaninternal.server.cluster.ClusterBroadcast
-
Inform the other cluster members that this instance has come online and start any listeners etc.
- statement() - Method in class io.ebeaninternal.server.core.SpiResultSet
- statement(BatchPostExecute) - Method in class io.ebeaninternal.server.persist.BatchedPstmt
-
Return the statement adding the postExecute task.
- statistics(boolean) - Method in class io.ebeaninternal.server.cache.DefaultServerCache
- storageEngine() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the storage engine.
- store() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- store(Boolean) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- store(Object, T) - Method in interface io.ebeanservice.docstore.api.DocStoreQueryUpdate
-
Process the bean storing in the document store.
- Str - Class in io.ebeaninternal.server.util
-
String utility for adding strings together.
- Str() - Constructor for class io.ebeaninternal.server.util.Str
- STreeProperty - Interface in io.ebeaninternal.server.query
-
A property in the SQL Tree.
- STreePropertyAssoc - Interface in io.ebeaninternal.server.query
- STreePropertyAssocMany - Interface in io.ebeaninternal.server.query
- STreePropertyAssocOne - Interface in io.ebeaninternal.server.query
- STreeType - Interface in io.ebeaninternal.server.query
-
Bean type interface for Sql query tree.
- stringParser() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- stringParser() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- stringParser() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- strValue() - Method in class io.ebeaninternal.server.expression.SimpleExpression
-
Return the String bind value taking into account named parameters.
- subList(int, int) - Method in class io.ebeaninternal.json.ModifyAwareList
- sum(String, Object...) - Method in interface io.ebeaninternal.api.SpiTxnLogger
-
Log a Summary message.
- Summary() - Constructor for class io.ebeaninternal.server.transaction.TransactionProfile.Summary
- supportsSelectLastInsertedId() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if this bean uses a SQL select to fetch the last inserted id value.
- suppressForeignKey() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return true if foreign keys to the base table should be suppressed.
T
- tableAlias(String) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Return a table alias without many where clause joins.
- tableAliasManyWhere(String) - Method in interface io.ebeaninternal.server.deploy.DbSqlContext
-
Return a table alias that takes into account many where joins.
- tableAliasMapping(String) - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping.Column
-
Prepend the path to the property name.
- tableAliasMapping(String, String) - Method in class io.ebeaninternal.server.rawsql.DRawSqlBuilder
- tableAliasMapping(String, String) - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping
-
Modify any column mappings with the given table alias to have the path prefix.
- TableIUD(String, boolean, boolean, boolean) - Constructor for class io.ebeaninternal.api.TransactionEventTable.TableIUD
- tableJoin() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
return the join to use for the bean.
- TableJoin - Class in io.ebeaninternal.server.deploy
-
Represents a join to another table.
- TableJoin(DeployTableJoin) - Constructor for class io.ebeaninternal.server.deploy.TableJoin
- TableJoin(DeployTableJoin, PropertyForeignKey) - Constructor for class io.ebeaninternal.server.deploy.TableJoin
-
Create a TableJoin.
- TableJoinColumn - Class in io.ebeaninternal.server.deploy
-
A join pair of local and foreign properties.
- TableJoinColumn(DeployTableJoinColumn) - Constructor for class io.ebeaninternal.server.deploy.TableJoinColumn
-
Create the pair.
- TableModState - Class in io.ebeaninternal.server.transaction
-
Holds timestamp of last modification per table.
- TableModState() - Constructor for class io.ebeaninternal.server.transaction.TableModState
- tableName() - Method in class io.ebeaninternal.api.TransactionEventTable.TableIUD
- tablespaceMeta() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the tablespace details of the bean.
- TablespaceMeta - Class in io.ebeaninternal.server.deploy
-
Meta data for table spaces.
- TablespaceMeta(String, String, String) - Constructor for class io.ebeaninternal.server.deploy.TablespaceMeta
- target() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
- target() - Method in interface io.ebeaninternal.server.query.STreePropertyAssoc
-
Return the type of the target (other side).
- targetDescriptor() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return the BeanDescriptor of the target.
- targetIdProperty() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return the Id property of the target entity type.
- targetType() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssoc
-
Return the type of the target.
- targetType() - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Same as getPropertyType().
- TChangeLogHolder - Class in io.ebeaninternal.server.transaction
-
Holder of the changes handling the case when we send the changes prior to commit or rollback as we hit the allowed 'batch size'.
- TChangeLogHolder(SpiTransaction, int) - Constructor for class io.ebeaninternal.server.transaction.TChangeLogHolder
-
Construct with the owning transaction and batch size to use.
- temporalMode() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the Temporal mode for the query.
- temporalMode() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- tenantId() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the tenantId to use for lazy loading.
- tenantId() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Return the current Tenant Id.
- tenantId() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- tenantId() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
-
Return the tenantId associated with this request.
- tenantId() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- tenantId() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- tenantId() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- tenantId() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- tenantProperty() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the tenant property when multi-tenant partitioning support is used.
- test(Class<?>) - Method in class io.ebeaninternal.server.core.bootup.BootupClasses
- text() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- textCommonTerms(String, TextCommonTerms) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- textCommonTerms(String, TextCommonTerms) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- textExpression() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the text expressions.
- textExpression() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- textMatch(String, String, Match) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- textMultiMatch(String, MultiMatch) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- textQueryString(String, TextQueryString) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- textQueryString(String, TextQueryString) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- textSimple(String, TextSimple) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- textSimple(String, TextSimple) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- timeCreated() - Method in interface io.ebeaninternal.api.SpiUpdatePlan
-
Return the time this plan was created.
- timeLastUsed() - Method in interface io.ebeaninternal.api.SpiUpdatePlan
-
Return the time this plan was last used.
- timeout() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the query timeout.
- timeout() - Method in interface io.ebeaninternal.api.SpiUpdate
-
Return the timeout in seconds.
- timeout() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Return the timeout.
- timeout() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
-
Return the timeout in seconds.
- timeStamp - Variable in class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
- toArray() - Method in class io.ebeaninternal.json.ModifyAwareList
- toArray() - Method in class io.ebeaninternal.json.ModifyAwareSet
- toArray(T[]) - Method in class io.ebeaninternal.json.ModifyAwareList
- toArray(T[]) - Method in class io.ebeaninternal.json.ModifyAwareSet
- toBean(Class<T>, JsonParser) - Method in class io.ebeaninternal.server.json.DJsonContext
- toBean(Class<T>, JsonParser, JsonReadOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- toBean(Class<T>, Reader) - Method in class io.ebeaninternal.server.json.DJsonContext
- toBean(Class<T>, Reader, JsonReadOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- toBean(Class<T>, String) - Method in class io.ebeaninternal.server.json.DJsonContext
- toBean(Class<T>, String, JsonReadOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- toBean(T, JsonParser) - Method in class io.ebeaninternal.server.json.DJsonContext
- toBean(T, JsonParser, JsonReadOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- toBean(T, Reader) - Method in class io.ebeaninternal.server.json.DJsonContext
- toBean(T, Reader, JsonReadOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- toBean(T, String) - Method in class io.ebeaninternal.server.json.DJsonContext
- toBean(T, String, JsonReadOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- toBeanType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.Native
- toBeanType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesBase
- toBeanType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- toBeanType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- toBeanType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeString
- toBeanType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- toBeanType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- toJdbcType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.Native
- toJdbcType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesBase
- toJdbcType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- toJdbcType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- toJdbcType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeString
- toJdbcType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- toJdbcType(Object) - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- toJson(Object) - Method in class io.ebeaninternal.server.json.DJsonContext
- toJson(Object, JsonGenerator) - Method in class io.ebeaninternal.server.json.DJsonContext
- toJson(Object, JsonGenerator, FetchPath) - Method in class io.ebeaninternal.server.json.DJsonContext
- toJson(Object, JsonGenerator, JsonWriteOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- toJson(Object, FetchPath) - Method in class io.ebeaninternal.server.json.DJsonContext
- toJson(Object, JsonWriteOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- toJson(Object, Writer) - Method in class io.ebeaninternal.server.json.DJsonContext
- toJson(Object, Writer, FetchPath) - Method in class io.ebeaninternal.server.json.DJsonContext
- toJson(Object, Writer, JsonWriteOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- toJson(String, Collection<?>) - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
Write the collection.
- toJson(String, Collection<?>) - Method in class io.ebeaninternal.server.json.WriteJson
- toJsonPretty(Object) - Method in class io.ebeaninternal.server.json.DJsonContext
- toJunction() - Method in interface io.ebeaninternal.api.SpiExpressionList
-
Return the expression list as a Junction (for ElasticSearch).
- toJunction() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- toList(Class<T>, JsonParser) - Method in class io.ebeaninternal.server.json.DJsonContext
- toList(Class<T>, JsonParser, JsonReadOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- toList(Class<T>, Reader) - Method in class io.ebeaninternal.server.json.DJsonContext
- toList(Class<T>, Reader, JsonReadOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- toList(Class<T>, String) - Method in class io.ebeaninternal.server.json.DJsonContext
- toList(Class<T>, String, JsonReadOptions) - Method in class io.ebeaninternal.server.json.DJsonContext
- toObject(Type, JsonParser) - Method in class io.ebeaninternal.server.json.DJsonContext
- toObject(Type, Reader) - Method in class io.ebeaninternal.server.json.DJsonContext
- toObject(Type, String) - Method in class io.ebeaninternal.server.json.DJsonContext
- toString() - Method in class io.ebeaninternal.api.HashQuery
- toString() - Method in class io.ebeaninternal.api.ScopedTransaction
- toString() - Method in class io.ebeaninternal.api.ScopeTrans
- toString() - Method in class io.ebeaninternal.api.TransactionEventTable.TableIUD
- toString() - Method in class io.ebeaninternal.api.TransactionEventTable
- toString() - Method in class io.ebeaninternal.json.ModifyAwareList
- toString() - Method in class io.ebeaninternal.json.ModifyAwareMap
- toString() - Method in class io.ebeaninternal.json.ModifyAwareSet
- toString() - Method in class io.ebeaninternal.server.cache.CachedBeanData
- toString() - Method in class io.ebeaninternal.server.cache.CachedBeanId
- toString() - Method in class io.ebeaninternal.server.cache.CachedManyIds
- toString() - Method in class io.ebeaninternal.server.cache.RemoteCacheEvent
- toString() - Method in class io.ebeaninternal.server.core.DefaultServer
- toString() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Summary description.
- toString() - Method in class io.ebeaninternal.server.deploy.BeanFkeyProperty
- toString() - Method in class io.ebeaninternal.server.deploy.BeanProperty
- toString() - Method in class io.ebeaninternal.server.deploy.BeanTable
- toString() - Method in class io.ebeaninternal.server.deploy.DynamicPropertyAggregationFormulaMTO
- toString() - Method in class io.ebeaninternal.server.deploy.InheritInfo
- toString() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanDescriptor
-
Summary description.
- toString() - Method in class io.ebeaninternal.server.deploy.meta.DeployBeanProperty
- toString() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoin
- toString() - Method in class io.ebeaninternal.server.deploy.meta.DeployTableJoinColumn
- toString() - Method in class io.ebeaninternal.server.deploy.TableJoin
- toString() - Method in class io.ebeaninternal.server.deploy.TableJoinColumn
- toString() - Method in class io.ebeaninternal.server.deploy.TablespaceMeta
- toString() - Method in class io.ebeaninternal.server.el.ElPropertyChain
- toString() - Method in class io.ebeaninternal.server.persist.MultiValueWrapper
- toString() - Method in class io.ebeaninternal.server.query.CQueryPlan
- toString() - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- toString() - Method in class io.ebeaninternal.server.query.NativeSqlQueryPlanKey
- toString() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- toString() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- toString() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- toString() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.ColumnMapping.Column
- toString() - Method in class io.ebeaninternal.server.rawsql.SpiRawSql.Sql
- toString() - Method in class io.ebeaninternal.server.transaction.BeanPersistIdMap
- toString() - Method in class io.ebeaninternal.server.transaction.BeanPersistIds
- toString() - Method in class io.ebeaninternal.server.transaction.DefaultPersistenceContext
- toString() - Method in class io.ebeaninternal.server.transaction.DeleteByIdMap
- toString() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- toString() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- toString() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- toString() - Method in class io.ebeaninternal.server.transaction.RemoteTableMod
- toString() - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- toString() - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- toString() - Method in class io.ebeaninternal.server.util.ArrayStack
- toString() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyMapping
- toString() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyOptions
- touchedTables() - Method in class io.ebeaninternal.server.cache.CacheChangeSet
-
Return the touched tables.
- transaction - Variable in class io.ebeaninternal.api.LoadRequest
- transaction - Variable in class io.ebeaninternal.api.SpiTransactionProxy
- transaction - Variable in class io.ebeaninternal.server.core.AbstractSqlQueryRequest
- transaction - Variable in class io.ebeaninternal.server.core.BeanRequest
- transaction() - Method in class io.ebeaninternal.api.LoadRequest
-
Return the transaction to use if this is a secondary query.
- transaction() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the transaction explicitly assigned or null.
- transaction() - Method in interface io.ebeaninternal.api.SpiSqlBinding
-
Return the transaction explicitly associated to the query.
- transaction() - Method in class io.ebeaninternal.server.core.BeanRequest
-
Return the Transaction associated with this request.
- transaction() - Method in class io.ebeaninternal.server.query.CQuery
- transaction() - Method in class io.ebeaninternal.server.query.QueryFutureIds
- transaction() - Method in class io.ebeaninternal.server.query.QueryFutureList
- transaction() - Method in class io.ebeaninternal.server.query.QueryFutureRowCount
- transaction() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- transaction() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- transaction() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- transaction() - Method in interface io.ebeanservice.docstore.api.DocQueryRequest
-
Return the transaction for this request (can be null for document store only queries).
- transaction(SpiTransaction) - Method in class io.ebeaninternal.server.core.BeanRequest
-
Set the transaction to use for this request.
- transaction(SpiTransaction) - Method in interface io.ebeanservice.docstore.api.DocQueryRequest
-
Set the (document store) transaction to use for this query.
- TransactionEvent - Class in io.ebeaninternal.api
-
Holds information for a transaction.
- TransactionEvent() - Constructor for class io.ebeaninternal.api.TransactionEvent
-
Create the TransactionEvent, one per Transaction.
- transactionEventTable() - Method in interface io.ebeaninternal.api.SpiCallableSql
- TransactionEventTable - Class in io.ebeaninternal.api
- TransactionEventTable() - Constructor for class io.ebeaninternal.api.TransactionEventTable
- TransactionEventTable.TableIUD - Class in io.ebeaninternal.api
- transactionManager() - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Return the transaction manager.
- transactionManager() - Method in class io.ebeaninternal.server.core.DefaultServer
-
Return the transaction manager.
- TransactionManager - Class in io.ebeaninternal.server.transaction
-
Manages transactions.
- TransactionManager(TransactionManagerOptions) - Constructor for class io.ebeaninternal.server.transaction.TransactionManager
-
Create the TransactionManager
- TransactionManagerOptions - Class in io.ebeaninternal.server.transaction
-
Objects supplied for constructing the TransactionManager.
- TransactionManagerOptions(SpiServer, boolean, DatabaseBuilder.Settings, TransactionScopeManager, ClusterManager, BackgroundExecutor, DocStoreUpdateProcessor, BeanDescriptorManager, DataSourceSupplier, SpiProfileHandler, SpiLogManager, TableModState, ServerCacheNotify, ClockService) - Constructor for class io.ebeaninternal.server.transaction.TransactionManagerOptions
- TransactionProfile - Class in io.ebeaninternal.server.transaction
-
Profiling information for a single transaction that has completed.
- TransactionProfile(long, ProfileLocation) - Constructor for class io.ebeaninternal.server.transaction.TransactionProfile
-
Create with profileId, total micros and encoded profile data.
- TransactionProfile.Summary - Class in io.ebeaninternal.server.transaction
- TransactionScopeManager - Class in io.ebeaninternal.server.transaction
-
Manages the Transactions typically held in a ThreadLocal.
- TransactionScopeManager() - Constructor for class io.ebeaninternal.server.transaction.TransactionScopeManager
- translate(OrmQueryRequest<T>, String, String, SQLException) - Method in interface io.ebeaninternal.server.core.OrmQueryEngine
-
Translate the SQLException to a specific persistence exception type if possible.
- translate(OrmQueryRequest<T>, String, String, SQLException) - Method in class io.ebeaninternal.server.query.DefaultOrmQueryEngine
- translate(String, String, SQLException) - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- translate(String, SQLException) - Method in interface io.ebeaninternal.api.SpiTransaction
-
Translate the SQLException.
- translate(String, SQLException) - Method in class io.ebeaninternal.api.SpiTransactionProxy
- translate(String, SQLException) - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
- translate(String, SQLException) - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
- translate(String, SQLException) - Method in class io.ebeaninternal.server.transaction.JtaTransaction
- translate(String, SQLException) - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Translate the SQLException into a specific exception if possible based on the DB platform.
- translateSqlException(SQLException) - Method in class io.ebeaninternal.server.core.PersistRequest
-
Translate the SQLException into a specific exception given the platform.
- trim(String) - Static method in class io.ebeaninternal.server.persist.TrimLogSql
-
Replace new line chars for nicer logging of multi-line sql strings.
- trimFrequency - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- TrimLogSql - Class in io.ebeaninternal.server.persist
-
Utility to improve logging of raw SQL that contains new line characters.
- TrimLogSql() - Constructor for class io.ebeaninternal.server.persist.TrimLogSql
- trimOnPut - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- trimPath(int) - Method in interface io.ebeaninternal.api.SpiExpressionList
-
Return a copy of the ExpressionList with the path trimmed for filterMany() expressions.
- trimPath(int) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- trimPath(int) - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- trimPath(int) - Method in class io.ebeaninternal.server.expression.FilterExprPath
-
Return a copy of the FilterExprPath trimming off leading part of the path due to a proceeding (earlier) query join etc.
- truncate(Class<?>...) - Method in class io.ebeaninternal.server.core.DefaultServer
- truncate(String...) - Method in class io.ebeaninternal.server.core.DefaultServer
- ttlCount - Variable in class io.ebeaninternal.server.cache.DefaultServerCache
- tuneFetchProperties(OrmQueryDetail) - Method in interface io.ebeaninternal.api.SpiQuery
-
AutoTune tune the detail specifying properties to select on already defined joins and adding extra joins where they are missing.
- tuneFetchProperties(OrmQueryDetail) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- tuneQuery(SpiQuery<?>) - Method in interface io.ebeaninternal.server.autotune.AutoTuneService
-
Called when a query thinks it should be automatically tuned by AutoTune.
- tuneQuery(SpiQuery<?>) - Method in class io.ebeaninternal.server.autotune.NoAutoTuneService
- txn(String, Object...) - Method in interface io.ebeaninternal.api.SpiTxnLogger
-
Log a Transaction message.
- TxnProfileEventCodes - Interface in io.ebeaninternal.api
-
Event codes used in transaction profiling.
- type - Variable in class io.ebeaninternal.server.core.PersistRequest
- type() - Method in class io.ebeaninternal.api.BindParams.Param
-
Return the jdbc type of this parameter.
- type() - Method in interface io.ebeaninternal.api.SpiDtoQuery
-
Return the associated DTO bean type.
- type() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the type of query (List, Set, Map, Bean, rowCount etc).
- type() - Method in class io.ebeaninternal.server.core.PersistRequest
-
Return the type of this request.
- type() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the class type this BeanDescriptor describes.
- type() - Method in class io.ebeaninternal.server.deploy.BeanProperty
-
Return the property type.
- type() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- type() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- type() - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- type() - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- type() - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- type() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyMapping
-
Return the type of the property.
- type() - Method in class io.ebeanservice.docstore.api.mapping.DocumentMapping
-
Return the type.
- type(int) - Method in class io.ebeaninternal.server.type.DefaultTypeManager
-
Return the ScalarType for the given jdbc type as per java.sql.Types.
- type(int) - Method in interface io.ebeaninternal.server.type.TypeManager
-
Return the ScalarType for a given jdbc type.
- type(DocPropertyType) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyMapping
-
Set the type of the property.
- type(Class<?>) - Method in class io.ebeaninternal.server.type.DefaultTypeManager
-
This can return null if no matching ScalarType is found.
- type(Class<?>) - Method in interface io.ebeaninternal.server.type.TypeManager
-
Return the ScalarType for a given logical type.
- type(Class<?>, int) - Method in class io.ebeaninternal.server.type.DefaultTypeManager
-
Return a ScalarType for a given class.
- type(Class<?>, int) - Method in interface io.ebeaninternal.server.type.TypeManager
-
For java.util.Date and java.util.Calendar additionally pass the jdbc type that you would like the ScalarType to map to.
- type(Type, Class<?>) - Method in class io.ebeaninternal.server.type.DefaultTypeManager
- type(Type, Class<?>) - Method in interface io.ebeaninternal.server.type.TypeManager
-
Find and return the ScalarType taking into account the property type with generics.
- type(String) - Method in class io.ebeaninternal.server.type.DefaultTypeManager
- type(String) - Method in interface io.ebeaninternal.server.type.TypeManager
-
Return the scalar type for the given logical type.
- TYPE_BEANIUD - Static variable in interface io.ebeaninternal.api.BinaryWritable
- TYPE_CACHE - Static variable in interface io.ebeaninternal.api.BinaryWritable
- TYPE_TABLEIUD - Static variable in interface io.ebeaninternal.api.BinaryWritable
- TYPE_TABLEMOD - Static variable in interface io.ebeaninternal.api.BinaryWritable
- typeFor(Type, boolean) - Method in interface io.ebeaninternal.server.type.PlatformArrayTypeFactory
-
Return the ScalarType to handle DB ARRAY for the given element type.
- typeForEnum(ScalarType<?>, boolean) - Method in interface io.ebeaninternal.server.type.PlatformArrayTypeFactory
-
Return the ScalarType to handle DB ARRAY for the given enum element type.
- TypeManager - Interface in io.ebeaninternal.server.type
-
Convert an Object to the required type.
- TypeReflectHelper - Class in io.ebeaninternal.server.type
- TypeReflectHelper() - Constructor for class io.ebeaninternal.server.type.TypeReflectHelper
U
- underlying() - Method in interface io.ebeaninternal.server.querydefn.SpiFetchGroup
-
Return the underlying detail for copy purposes.
- underlying(Object) - Method in class io.ebeaninternal.server.deploy.BeanListHelp
- underlying(Object) - Method in class io.ebeaninternal.server.deploy.BeanListHelpElement
- underlying(Object) - Method in class io.ebeaninternal.server.deploy.BeanMapHelp
- underlying(Object) - Method in class io.ebeaninternal.server.deploy.BeanMapHelpElement
- underlying(Object) - Method in class io.ebeaninternal.server.deploy.BeanSetHelp
- underlying(Object) - Method in class io.ebeaninternal.server.deploy.BeanSetHelpElement
- underlying(Object) - Method in interface io.ebeaninternal.server.deploy.BeanCollectionHelp
-
Return the underlying collection of beans.
- underlyingList() - Method in interface io.ebeaninternal.api.SpiExpressionList
-
Return the underlying list of expressions.
- underlyingList() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- unidirectional() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the "shadow" property to support unidirectional relationships.
- uniqueProps() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- UNKNOWN - Enum constant in enum io.ebeaninternal.api.SpiUpdate.OrmUpdateType
- unknownProperties() - Method in class io.ebeaninternal.api.SpiExpressionValidation
-
Return the set of properties considered as having unknown paths.
- unparsed(String) - Method in class io.ebeaninternal.server.rawsql.DRawSqlService
- unRegisterBean() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- unregisterBeans() - Method in interface io.ebeaninternal.api.SpiTransaction
-
Unregister the persisted beans.
- unregisterBeans() - Method in class io.ebeaninternal.api.SpiTransactionProxy
- unregisterBeans() - Method in class io.ebeaninternal.server.transaction.DocStoreOnlyTransaction
-
Unregister the persisted beans (when persisting at the top level).
- unregisterBeans() - Method in class io.ebeaninternal.server.transaction.ExternalJdbcTransaction
-
Unregister the persisted beans (when persisting at the top level).
- unregisterBeans() - Method in class io.ebeaninternal.server.transaction.JtaTransaction
-
Unregister the persisted beans (when persisting at the top level).
- unsetMerge(int) - Static method in class io.ebeaninternal.server.persist.Flags
- unsetPublish(int) - Static method in class io.ebeaninternal.server.persist.Flags
- unsetRecurse(int) - Static method in class io.ebeaninternal.server.persist.Flags
- UnsupportedDocStoreExpression - Interface in io.ebeaninternal.server.expression
-
Marked interface for expressions unsupported in doc store.
- unwrapEntry(DefaultServerCache.CacheEntry) - Method in class io.ebeaninternal.server.cache.DefaultServerCache
-
Unwrap the cache entry - override for query cache to unwrap to the query result.
- unwrapEntry(DefaultServerCache.CacheEntry) - Method in class io.ebeaninternal.server.cache.DefaultServerQueryCache
- update - Variable in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
-
Behavior on update.
- update() - Method in interface io.ebeaninternal.api.json.SpiJsonReader
- update() - Method in class io.ebeaninternal.server.core.OrmQueryRequest
- update() - Method in interface io.ebeaninternal.server.core.SpiOrmQueryRequest
-
Execute the query as a update.
- update() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- update() - Method in class io.ebeaninternal.server.json.ReadJson
-
Do we update an existing bean?
- update() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- update() - Method in class io.ebeaninternal.server.querydefn.DefaultUpdateQuery
- update(EntityBean, Transaction) - Method in interface io.ebeaninternal.server.core.Persister
-
Update the bean.
- update(EntityBean, Transaction) - Method in class io.ebeaninternal.server.persist.DefaultPersister
-
Update the bean.
- update(Transaction) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- update(Transaction) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- update(SpiQuery<T>) - Method in interface io.ebeaninternal.api.SpiEbeanServer
- update(SpiQuery<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- update(OrmQueryRequest<T>) - Method in interface io.ebeaninternal.server.core.OrmQueryEngine
-
Execute the query as a update statement.
- update(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.CQueryEngine
- update(OrmQueryRequest<T>) - Method in class io.ebeaninternal.server.query.DefaultOrmQueryEngine
- update(PersistRequestBean<?>) - Method in interface io.ebeaninternal.server.persist.BeanPersister
-
execute the update bean request.
- update(Class<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- update(Object) - Method in class io.ebeaninternal.server.core.DefaultServer
- update(Object, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
- update(Object, PersistRequestBean<T>, DocStoreUpdateContext) - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Process an update persist request.
- update(Object, PersistRequestBean<T>, DocStoreUpdateContext) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- update(Map<String, Object>, long) - Method in class io.ebeaninternal.server.cache.CachedBeanData
-
Create and return a new version of CachedBeanData based on this entry applying the given changes.
- UPDATE - Enum constant in enum io.ebeaninternal.api.SpiQuery.Type
-
Update query.
- UPDATE - Enum constant in enum io.ebeaninternal.api.SpiUpdate.OrmUpdateType
- UPDATE - Enum constant in enum io.ebeaninternal.server.core.PersistRequest.Type
- updateAll(Collection<?>, Transaction) - Method in class io.ebeaninternal.server.core.DefaultServer
-
Update all beans in the collection with an explicit transaction.
- updateAll(Collection<?>) - Method in class io.ebeaninternal.server.core.DefaultServer
- updated(Object, Set<String>) - Method in class io.ebeaninternal.server.deploy.ChainedBeanPersistListener
- updatedManyForL2Cache() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the list of updated many properties for L2 cache update (can be null).
- updatedProperties() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- updatedValues() - Method in class io.ebeaninternal.server.core.PersistRequestBean
- updateEmbedded(PersistRequestBean<T>, DocStoreUpdates) - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Process the persist request adding any embedded/nested document invalidation to the docStoreUpdates.
- updateEmbedded(PersistRequestBean<T>, DocStoreUpdates) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- updateEmbedded(Object, String, String, DocUpdateContext) - Method in interface io.ebeanservice.docstore.api.DocStoreBeanAdapter
-
Process an update of an embedded document.
- updateEmbedded(Object, String, String, DocUpdateContext) - Method in class io.ebeanservice.docstore.api.support.DocStoreBeanBaseAdapter
- updateHash() - Method in class io.ebeaninternal.api.BindParams
-
Updates the hash.
- updateImportedIdSql(ImportedId) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return a Sql update statement to set the importedId value (deferred execution).
- updatePlan(String) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Get a UpdatePlan for a given hash.
- updatePlan(String, SpiUpdatePlan) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Add a UpdatePlan to the cache with a given hash.
- updatePlanHash() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the key for an update persist request.
- updateProcessor() - Method in interface io.ebeanservice.docstore.api.DocStoreIntegration
-
Return the DocStoreUpdateProcessor to use.
- updateProperties() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the properties for an update query.
- updateProperties() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- updateSql() - Method in class io.ebeaninternal.server.core.PersistRequestUpdateSql
-
Return the UpdateSql.
- UPDATESQL - Enum constant in enum io.ebeaninternal.server.core.PersistRequest.Type
- updateStatement() - Method in interface io.ebeaninternal.api.SpiUpdate
-
Return the update statement.
- updateStatement() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmUpdate
- updateTable() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the table to update depending if the request is a 'publish' one or normal.
- useMaster - Variable in class io.ebeaninternal.server.querydefn.AbstractQuery
- useReferences(boolean) - Method in interface io.ebeaninternal.api.LoadContext
-
Use soft-references for streaming queries, so unreachable entries can be garbage collected.
- usingConnection(Connection) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- usingConnection(Connection) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- usingConnection(Connection) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- usingConnection(Connection) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- usingDatabase(Database) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- usingFuture() - Method in interface io.ebeaninternal.api.SpiQuery
-
Set that this is a future query that will execute in the background.
- usingFuture() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- usingMaster() - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- usingMaster() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- usingMaster() - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- usingTransaction(Transaction) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- usingTransaction(Transaction) - Method in class io.ebeaninternal.server.querydefn.DefaultDtoQuery
- usingTransaction(Transaction) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- usingTransaction(Transaction) - Method in class io.ebeaninternal.server.querydefn.DefaultRelationalQuery
- UTF8() - Constructor for class io.ebeaninternal.server.deploy.BindMaxLength.UTF8
- UUID_EPOCH_OFFSET - Static variable in class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
- UuidV1IdGenerator - Class in io.ebeaninternal.server.idgen
-
IdGenerator for java util UUID.
- UuidV1RndIdGenerator - Class in io.ebeaninternal.server.idgen
-
IdGenerator for (pseudo) type 1 UUIDs.
- UuidV1RndIdGenerator() - Constructor for class io.ebeaninternal.server.idgen.UuidV1RndIdGenerator
- UuidV4IdGenerator - Class in io.ebeaninternal.server.idgen
-
IdGenerator for java util UUID.
- UuidV4IdGenerator() - Constructor for class io.ebeaninternal.server.idgen.UuidV4IdGenerator
V
- validate() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- validate(BeanType<T>) - Method in interface io.ebeaninternal.api.SpiQuery
-
Validate the query returning the set of properties with unknown paths.
- validate(BeanType<T>) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
-
Validate all the expression properties/paths given the bean descriptor.
- validate(SpiExpressionValidation) - Method in interface io.ebeaninternal.api.SpiExpression
-
Validate all the properties/paths associated with this expression.
- validate(SpiExpressionValidation) - Method in class io.ebeaninternal.server.expression.InExpression
- validate(SpiExpressionValidation) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- validate(SpiExpressionValidation) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- validate(SpiExpressionValidation) - Method in class io.ebeaninternal.server.expression.IdInExpression
- validate(String) - Method in class io.ebeaninternal.api.SpiExpressionValidation
-
Validate that the property expression (path) is valid.
- validateQuery(Query<T>) - Method in class io.ebeaninternal.server.core.DefaultServer
- value() - Method in class io.ebeaninternal.server.expression.SimpleExpression
-
Return the bind value taking into account named parameters.
- value(Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- Value() - Constructor for class io.ebeaninternal.server.querydefn.OrmUpdateProperties.Value
- valueAsEntityBean(EntityBean) - Method in class io.ebeaninternal.server.deploy.BeanPropertyAssocOne
-
Return the property value as an entity bean.
- valueAsEntityBean(EntityBean) - Method in interface io.ebeaninternal.server.query.STreePropertyAssocOne
-
Return the property value as an entity bean from the parent.
- valueOf(String) - Static method in enum io.ebeaninternal.api.ConcurrencyMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.ebeaninternal.api.SpiQuery.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.ebeaninternal.api.SpiQuery.TemporalMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.ebeaninternal.api.SpiQuery.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.ebeaninternal.api.SpiUpdate.OrmUpdateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.ebeaninternal.server.core.PersistRequest.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.ebeaninternal.server.core.PersistRequestUpdateSql.SqlType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.ebeaninternal.server.deploy.BeanDescriptor.EntityType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.ebeaninternal.server.deploy.ManyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.ebeaninternal.server.expression.BitwiseOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.ebeaninternal.server.expression.Op
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.ebeaninternal.server.persist.DeleteMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.ebeaninternal.server.query.SqlJoinType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum io.ebeaninternal.api.ConcurrencyMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.ebeaninternal.api.SpiQuery.Mode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.ebeaninternal.api.SpiQuery.TemporalMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.ebeaninternal.api.SpiQuery.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.ebeaninternal.api.SpiUpdate.OrmUpdateType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class io.ebeaninternal.api.TransactionEventTable
- values() - Method in class io.ebeaninternal.json.ModifyAwareMap
- values() - Static method in enum io.ebeaninternal.server.core.PersistRequest.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.ebeaninternal.server.core.PersistRequestUpdateSql.SqlType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.ebeaninternal.server.deploy.BeanDescriptor.EntityType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.ebeaninternal.server.deploy.ManyType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.ebeaninternal.server.expression.BitwiseOp
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.ebeaninternal.server.expression.Op
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.ebeaninternal.server.persist.DeleteMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class io.ebeaninternal.server.query.DefaultSqlRow
- values() - Static method in enum io.ebeaninternal.server.query.SqlJoinType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class io.ebeaninternal.server.transaction.BeanPersistIdMap
- values() - Method in class io.ebeaninternal.server.transaction.DeleteByIdMap
- values(EntityBean) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Return the id values for a given bean.
- values(EntityBean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- values(EntityBean) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- version() - Method in class io.ebeaninternal.server.core.PersistRequestBean
-
Return the version in long form (if set).
- VERSION - Enum constant in enum io.ebeaninternal.api.ConcurrencyMode
-
Use a version column.
- versionEnd() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the find versions end timestamp.
- versionEnd() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- versionProperty() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the first version property that exists on the bean.
- VERSIONS - Enum constant in enum io.ebeaninternal.api.SpiQuery.TemporalMode
-
Query runs potentially returning many versions of the same bean.
- versionStart() - Method in interface io.ebeaninternal.api.SpiQuery
-
Return the find versions start timestamp.
- versionStart() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- VIEW - Enum constant in enum io.ebeaninternal.server.deploy.BeanDescriptor.EntityType
- visit(MetricVisitor) - Method in class io.ebeaninternal.server.cache.DefaultServerCache
- visit(MetricVisitor) - Method in class io.ebeaninternal.server.query.CQueryPlan
-
Return a copy of the current query statistics.
- visit(BeanDescriptor<?>, BeanPropertyVisitor) - Static method in class io.ebeaninternal.server.deploy.visitor.VisitProperties
-
Visit a single Descriptor using the given visitor.
- visit(InheritInfo) - Method in interface io.ebeaninternal.server.deploy.InheritInfoVisitor
-
visit the InheritInfo for this node.
- visit(InheritInfo) - Method in class io.ebeaninternal.server.deploy.visitor.VisitProperties.InheritChildVisitor
- visit(BeanPropertyVisitor, BeanProperty) - Method in class io.ebeaninternal.server.deploy.visitor.VisitProperties
-
Visit the property.
- visit(DocPropertyVisitor) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyMapping
-
Visit this property and any nested children.
- visit(DocPropertyVisitor) - Method in class io.ebeanservice.docstore.api.mapping.DocumentMapping
-
Visit all the properties in the document structure.
- visitAllInheritanceChildren(Consumer<BeanType<?>>) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
- visitBegin() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyAdapter
- visitBegin() - Method in interface io.ebeanservice.docstore.api.mapping.DocPropertyVisitor
-
Begin visiting the document structure.
- visitBeginList(DocPropertyMapping) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyAdapter
- visitBeginList(DocPropertyMapping) - Method in interface io.ebeanservice.docstore.api.mapping.DocPropertyVisitor
-
Start visiting a nested list.
- visitBeginObject(DocPropertyMapping) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyAdapter
- visitBeginObject(DocPropertyMapping) - Method in interface io.ebeanservice.docstore.api.mapping.DocPropertyVisitor
-
Start visiting a nested object.
- visitChildren(InheritInfoVisitor) - Method in class io.ebeaninternal.server.deploy.InheritInfo
-
Visit all the children in the inheritance tree.
- visitEmbedded(BeanPropertyAssocOne<?>) - Method in class io.ebeaninternal.server.deploy.visitor.BaseTablePropertyVisitor
-
Not required in that you can use the visitEmbeddedScalar.
- visitEmbedded(BeanPropertyAssocOne<?>) - Method in interface io.ebeaninternal.server.deploy.visitor.BeanPropertyVisitor
-
Visit an embedded property.
- visitEmbeddedScalar(BeanProperty, BeanPropertyAssocOne<?>) - Method in class io.ebeaninternal.server.deploy.visitor.BaseTablePropertyVisitor
-
Override this method.
- visitEmbeddedScalar(BeanProperty, BeanPropertyAssocOne<?>) - Method in interface io.ebeaninternal.server.deploy.visitor.BeanPropertyVisitor
-
Visit the scalar property of an embedded bean.
- visitEnd() - Method in interface io.ebeaninternal.server.deploy.visitor.BeanPropertyVisitor
-
Completed visiting all the properties on the bean.
- visitEnd() - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyAdapter
- visitEnd() - Method in interface io.ebeanservice.docstore.api.mapping.DocPropertyVisitor
-
Finished visiting the document structure.
- visitEndList(DocPropertyMapping) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyAdapter
- visitEndList(DocPropertyMapping) - Method in interface io.ebeanservice.docstore.api.mapping.DocPropertyVisitor
-
End visiting a nested list.
- visitEndObject(DocPropertyMapping) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyAdapter
- visitEndObject(DocPropertyMapping) - Method in interface io.ebeanservice.docstore.api.mapping.DocPropertyVisitor
-
End visiting a nested object.
- visitInheritanceProperties(BeanDescriptor<?>, BeanPropertyVisitor) - Method in class io.ebeaninternal.server.deploy.visitor.VisitProperties
-
Visit all the other inheritance properties that are not on the root.
- visitMany(BeanPropertyAssocMany<?>) - Method in class io.ebeaninternal.server.deploy.visitor.BaseTablePropertyVisitor
-
Not part of base table.
- visitMany(BeanPropertyAssocMany<?>) - Method in interface io.ebeaninternal.server.deploy.visitor.BeanPropertyVisitor
-
Visit a OneToMany or ManyToMany property.
- visitMetrics(MetricVisitor) - Method in class io.ebeaninternal.api.ExtraMetrics
-
Collect the metrics.
- visitMetrics(MetricVisitor) - Method in interface io.ebeaninternal.api.SpiEbeanServer
-
Visit all the metrics (typically reporting them).
- visitMetrics(MetricVisitor) - Method in class io.ebeaninternal.server.cache.DefaultCacheAdapter
- visitMetrics(MetricVisitor) - Method in class io.ebeaninternal.server.cache.DefaultServerCacheManager
- visitMetrics(MetricVisitor) - Method in interface io.ebeaninternal.server.cache.SpiCacheManager
-
Visit and collect the metrics.
- visitMetrics(MetricVisitor) - Method in class io.ebeaninternal.server.core.DefaultServer
- visitMetrics(MetricVisitor) - Method in interface io.ebeaninternal.server.core.Persister
-
Visit the metrics.
- visitMetrics(MetricVisitor) - Method in interface io.ebeaninternal.server.core.RelationalQueryEngine
-
Visit the metrics.
- visitMetrics(MetricVisitor) - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Visit all the ORM query plan metrics (includes UpdateQuery with updates and deletes).
- visitMetrics(MetricVisitor) - Method in class io.ebeaninternal.server.deploy.BeanDescriptorManager
- visitMetrics(MetricVisitor) - Method in class io.ebeaninternal.server.persist.DefaultPersister
- visitMetrics(MetricVisitor) - Method in interface io.ebeaninternal.server.persist.PersistExecute
-
Visit the metrics.
- visitMetrics(MetricVisitor) - Method in class io.ebeaninternal.server.query.DefaultRelationalQueryEngine
- visitMetrics(MetricVisitor) - Method in class io.ebeaninternal.server.transaction.TransactionManager
- visitOneExported(BeanPropertyAssocOne<?>) - Method in class io.ebeaninternal.server.deploy.visitor.BaseTablePropertyVisitor
-
Not part of base table.
- visitOneExported(BeanPropertyAssocOne<?>) - Method in interface io.ebeaninternal.server.deploy.visitor.BeanPropertyVisitor
-
Visit the exported side of a OneToOne property.
- visitOneImported(BeanPropertyAssocOne<?>) - Method in class io.ebeaninternal.server.deploy.visitor.BaseTablePropertyVisitor
-
Override this method for the foreign key.
- visitOneImported(BeanPropertyAssocOne<?>) - Method in interface io.ebeaninternal.server.deploy.visitor.BeanPropertyVisitor
-
Visit the imported side of a OneToOne property.
- visitProperties(BeanDescriptor<?>, BeanPropertyVisitor) - Method in class io.ebeaninternal.server.deploy.visitor.VisitProperties
- VisitProperties - Class in io.ebeaninternal.server.deploy.visitor
-
Makes use of BeanVisitor and PropertyVisitor to navigate BeanDescriptors and their properties.
- VisitProperties() - Constructor for class io.ebeaninternal.server.deploy.visitor.VisitProperties
- VisitProperties.InheritChildVisitor - Class in io.ebeaninternal.server.deploy.visitor
-
Helper used to visit all the inheritInfo/BeanDescriptor in the inheritance hierarchy (to add their 'local' properties).
- visitProperty(DocPropertyMapping) - Method in class io.ebeanservice.docstore.api.mapping.DocPropertyAdapter
- visitProperty(DocPropertyMapping) - Method in interface io.ebeanservice.docstore.api.mapping.DocPropertyVisitor
-
Visit a property.
- visitScalar(BeanProperty, boolean) - Method in class io.ebeaninternal.server.deploy.visitor.BaseTablePropertyVisitor
-
Override this method for normal scalar property.
- visitScalar(BeanProperty, boolean) - Method in interface io.ebeaninternal.server.deploy.visitor.BeanPropertyVisitor
-
Visit a scalar property specify allowing non-null (e.g. embedded bean scalar properties).
W
- whenCreatedProperty() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the 'when created' property if there is one defined.
- whenModifiedProperty() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the 'when modified' property if there is one defined.
- where() - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- where() - Method in class io.ebeaninternal.server.expression.FilterExpressionList
- where() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- where() - Method in class io.ebeaninternal.server.querydefn.DefaultUpdateQuery
- where(Expression) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- where(ExpressionList<T>, String, Object[]) - Method in class io.ebeaninternal.server.expression.DefaultExpressionFactory
- where(String, Object...) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- whereExprBindValues() - Method in class io.ebeaninternal.server.query.CQueryPredicates
-
Return the bind values for the where expression.
- whereExpressions() - Method in interface io.ebeaninternal.api.SpiQuery
-
Can return null if no expressions where added to the where clause.
- whereExpressions() - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- whereIdInSql() - Method in class io.ebeaninternal.server.deploy.BeanDescriptor
-
Return the "where id in" sql (for use with UpdateQuery).
- with(long, long, long, Instant) - Method in interface io.ebeaninternal.api.SpiDbQueryPlan
-
Extend with queryTimeMicros, captureCount, captureMicros and when the bind values were captured.
- with(ServerCacheFactory, QueryCacheEntryValidate) - Method in class io.ebeaninternal.server.cache.CacheManagerOptions
- with(ServerCacheOptions, ServerCacheOptions) - Method in class io.ebeaninternal.server.cache.CacheManagerOptions
- with(CurrentTenantProvider) - Method in class io.ebeaninternal.server.cache.CacheManagerOptions
- withDeleteByIds() - Method in interface io.ebeaninternal.api.CQueryPlanKey
-
Return a query plan key taking into account persist cascading.
- withDeleteByIds() - Method in class io.ebeaninternal.server.query.NativeSqlQueryPlanKey
- withLock(Query.LockType) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- withLock(Query.LockType) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- withLock(Query.LockType, Query.LockWait) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- withLock(Query.LockType, Query.LockWait) - Method in class io.ebeaninternal.server.querydefn.DefaultOrmQuery
- wrapExternalConnection(Connection) - Method in class io.ebeaninternal.server.transaction.TransactionManager
-
Wrap the externally supplied Connection.
- write(JsonGenerator, Object) - Method in class io.ebeaninternal.server.json.DJsonScalar
- write(WriteJson) - Method in class io.ebeaninternal.server.json.WriteJson.WriteBean
- write(Object) - Method in class io.ebeaninternal.json.DJsonService
-
Write the nested Map/List as json.
- write(Object, JsonGenerator) - Method in class io.ebeaninternal.json.DJsonService
-
Write the nested Map/List as json to the jsonGenerator.
- write(Object, Writer) - Method in class io.ebeaninternal.json.DJsonService
-
Write the nested Map/List as json to the writer.
- writeAllEquals(Map<String, Object>) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write an all equals expression.
- writeBean(BeanDescriptor<T>, EntityBean) - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
Write the bean properties.
- writeBean(BeanDescriptor<T>, EntityBean) - Method in class io.ebeaninternal.server.json.WriteJson
- writeBinary(BinaryWriteContext) - Method in interface io.ebeaninternal.api.BinaryWritable
-
Write message in binary format.
- writeBinary(BinaryWriteContext) - Method in class io.ebeaninternal.api.TransactionEventTable.TableIUD
- writeBinary(BinaryWriteContext) - Method in class io.ebeaninternal.api.TransactionEventTable
- writeBinary(BinaryWriteContext) - Method in class io.ebeaninternal.server.cache.RemoteCacheEvent
- writeBinary(BinaryWriteContext) - Method in class io.ebeaninternal.server.transaction.BeanPersistIds
- writeBinary(BinaryWriteContext) - Method in class io.ebeaninternal.server.transaction.RemoteTableMod
- writeBinary(BinaryWriteContext) - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
- writeBinary(InputStream, int) - Method in class io.ebeaninternal.server.json.WriteJson
- writeBinaryAsBytes(int) - Method in class io.ebeaninternal.server.transaction.RemoteTransactionEvent
-
Write a binary message to byte array given an initial buffer size.
- writeBinaryField(String, byte[]) - Method in class io.ebeaninternal.server.json.WriteJson
- writeBoolean(boolean) - Method in class io.ebeaninternal.server.json.WriteJson
- writeBooleanField(String, boolean) - Method in class io.ebeaninternal.server.json.WriteJson
- writeCollection(Collection<Object>, JsonGenerator) - Method in class io.ebeaninternal.json.DJsonService
-
Write the collection as json array to the jsonGenerator.
- writeData(DataOutput, byte[]) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesBase
- writeData(DataOutput, byte[]) - Method in class io.ebeaninternal.server.type.ScalarTypeBytesEncrypted
- writeData(DataOutput, B) - Method in class io.ebeaninternal.server.type.ScalarTypeWrapper
- writeData(DataOutput, Boolean) - Method in class io.ebeaninternal.server.type.ScalarTypeBoolean.BooleanBase
- writeData(DataOutput, Object) - Method in class io.ebeaninternal.server.deploy.BeanProperty
- writeData(DataOutput, Object) - Method in interface io.ebeaninternal.server.deploy.id.IdBinder
-
Write the Id value to binary DataOuput.
- writeData(DataOutput, Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderEmbedded
- writeData(DataOutput, Object) - Method in class io.ebeaninternal.server.deploy.id.IdBinderSimple
- writeData(DataOutput, String) - Method in class io.ebeaninternal.server.type.ScalarTypeString
- writeData(DataOutput, UUID) - Method in class io.ebeaninternal.server.type.ScalarTypeUUIDBinary
- writeData(DataOutput, T) - Method in class io.ebeaninternal.server.type.ScalarTypeEncryptedWrapper
- writeDocQuery(DocQueryContext) - Method in interface io.ebeaninternal.api.SpiExpression
-
Write the expression as an elastic search expression.
- writeDocQuery(DocQueryContext) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
-
Write being aware if it is the Top level "text" expressions.
- writeDocQuery(DocQueryContext) - Method in class io.ebeaninternal.server.expression.IdInExpression
- writeDocQuery(DocQueryContext) - Method in class io.ebeaninternal.server.expression.InExpression
- writeDocQuery(DocQueryContext) - Method in class io.ebeaninternal.server.expression.SimpleExpression
- writeDocQuery(DocQueryContext, SpiExpression) - Method in interface io.ebeaninternal.api.SpiExpressionList
-
Write the top level where expressions taking into account possible extra idEquals expression.
- writeDocQuery(DocQueryContext, SpiExpression) - Method in class io.ebeaninternal.server.expression.DefaultExpressionList
- writeDocQueryJunction(DocQueryContext) - Method in interface io.ebeaninternal.api.SpiJunction
-
Write the Junction taking into account it is implied.
- writeEndArray() - Method in class io.ebeaninternal.server.json.WriteJson
- writeEndObject() - Method in class io.ebeaninternal.server.json.WriteJson
- writeEqualTo(String, Object) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write a equalTo expression.
- writeExists(boolean, String) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write an exists expression.
- writeExternal(ObjectOutput) - Method in class io.ebeaninternal.server.cache.CachedBeanData
- writeExternal(ObjectOutput) - Method in class io.ebeaninternal.server.cache.CachedBeanId
- writeExternal(ObjectOutput) - Method in class io.ebeaninternal.server.cache.CachedManyIds
- writeFieldName(String) - Method in class io.ebeaninternal.server.json.WriteJson
- writeId(Object) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write an Id equals expression.
- writeIds(Collection<?>) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write an ID in expression.
- writeIEqualTo(String, String) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write a case insensitive equalTo expression.
- writeIn(String, Object[], boolean) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write an In expression.
- writeINotEqualTo(String, String) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write a case insensitive notEqualTo expression.
- WriteJson - Class in io.ebeaninternal.server.json
- WriteJson(JsonGenerator, JsonConfig.Include) - Constructor for class io.ebeaninternal.server.json.WriteJson
-
Construct for Json scalar use.
- WriteJson(SpiEbeanServer, JsonGenerator, FetchPath, Map<String, JsonWriteBeanVisitor<?>>, Object, JsonConfig.Include, boolean) - Constructor for class io.ebeaninternal.server.json.WriteJson
-
Construct for full bean use (normal).
- WriteJson.WriteBean - Class in io.ebeaninternal.server.json
- writeLike(String, String, LikeType, boolean) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write a Like expression.
- writeMatch(String, String, Match) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write a Match expression.
- writeMultiMatch(String, MultiMatch) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write a Multi-match expression.
- writeNull() - Method in class io.ebeaninternal.server.json.WriteJson
- writeNullField(String) - Method in class io.ebeaninternal.server.json.WriteJson
- writeNumber(double) - Method in class io.ebeaninternal.server.json.WriteJson
- writeNumber(int) - Method in class io.ebeaninternal.server.json.WriteJson
- writeNumber(long) - Method in class io.ebeaninternal.server.json.WriteJson
- writeNumber(BigDecimal) - Method in class io.ebeaninternal.server.json.WriteJson
- writeNumberField(String, double) - Method in class io.ebeaninternal.server.json.WriteJson
- writeNumberField(String, float) - Method in class io.ebeaninternal.server.json.WriteJson
- writeNumberField(String, int) - Method in class io.ebeaninternal.server.json.WriteJson
- writeNumberField(String, long) - Method in class io.ebeaninternal.server.json.WriteJson
- writeNumberField(String, short) - Method in class io.ebeaninternal.server.json.WriteJson
- writeNumberField(String, BigDecimal) - Method in class io.ebeaninternal.server.json.WriteJson
- writeRange(String, Op, Object, Op, Object) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write a range operation with a lower and upper values.
- writeRange(String, String, Object) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write a range operation with one value.
- writeRaw(String) - Method in class io.ebeaninternal.server.json.WriteJson
- writeRaw(String, Object[]) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write a raw expression with bind values (might not be supported).
- writeRawValue(String) - Method in class io.ebeaninternal.server.json.WriteJson
- writeScalar(JsonGenerator, Object) - Method in class io.ebeaninternal.server.json.DJsonContext
- writeSimple(Op, String, Object) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write one of the base expressions.
- writeStartArray() - Method in class io.ebeaninternal.server.json.WriteJson
- writeStartArray(String) - Method in class io.ebeaninternal.server.json.WriteJson
- writeStartObject() - Method in class io.ebeaninternal.server.json.WriteJson
- writeStartObject(String) - Method in class io.ebeaninternal.server.json.WriteJson
- writeString(String) - Method in class io.ebeaninternal.server.json.WriteJson
- writeStringField(String, String) - Method in class io.ebeaninternal.server.json.WriteJson
- writeTextCommonTerms(String, TextCommonTerms) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write a common terms expression.
- writeTextQueryString(String, TextQueryString) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write a query string expression.
- writeTextSimple(String, TextSimple) - Method in interface io.ebeaninternal.server.expression.DocQueryContext
-
Write a simple expression.
- writeValueUsingObjectMapper(String, Object) - Method in interface io.ebeaninternal.api.json.SpiJsonWriter
-
Write value using underlying Jaskson object mapper if available.
- writeValueUsingObjectMapper(String, Object) - Method in class io.ebeaninternal.server.json.WriteJson
Z
- ZERO - Static variable in class io.ebeaninternal.server.persist.Flags
-
No flags set.
- zone - Variable in class io.ebeaninternal.server.core.timezone.MySqlDataTimeZone
- zone - Variable in class io.ebeaninternal.server.core.timezone.SimpleDataTimeZone
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form