Uses of Interface
org.hibernate.engine.spi.SessionFactoryImplementor
Package
Description
Support for integrating Jakarta Bean Validation.
Support for handling named queries during the bootstrap process.
A range of SPIs allowing integration with—and customization of—the process of building metadata.
Byte Buddy support internals
Package defining bytecode code enhancement (instrumentation) support.
An SPI modelling various aspects of the second-level cache configuration.
Internal implementations and support for second-level caching.
Defines the integration aspect of Hibernate's second-level caching, allowing
a "caching backend" to be plugged in as a cache provider.
Defines contracts for transactional and concurrent access to cached
entity and
collection data.
This package defines formats for disassembled state kept in the second level cache.
This package provides a framework intended to reduce the work needed to implement
a caching provider.
Internal implementations and support around "current session" handling.
SPI-level contracts around "current session" and "current tenant" support.
This package abstracts over the multifarious dialects of SQL
understood by the databases supported by Hibernate.
Support for
Dialect
-specific identity column handling.Support for temporary tables.
Support for many of the internal workings of Hibernate.
An SPI for dealing with parameters of native queries.
This package defines some central internal SPI abstractions
used throughout the implementation of Hibernate.
Defines the event types and event listener interfaces for
events produced by the stateful
Session
.Contains a framework of strategies for efficient retrieval of
database-generated values.
Contains a framework of strategies for retrieving database-generated ids.
An SPI for extensions which integrate with Hibernate via the Java
ServiceLoader
facility.An internal package containing implementations of central Hibernate APIs,
mostly defined in
org.hibernate
.Internal utility classes
Defines Hibernate implementation of Java Persistence specification.
Support for set and map ordering
An SPI supporting custom instantiation of
entity instances and
embeddable objects.
This package abstracts persistence mechanisms for collections.
Defines support for performing mutation operations against collections.
This package abstracts persistence mechanisms for entities.
Defines support for performing mutation operations originating
from persistence-context events.
An SPI for integrating custom entity and collection persisters.
Contains some functions for pretty-printing things for exception and log messages.
Defines the internal implementation of the stored procedure SPI.
Validation for HQL queries.
Everything related to HQL/JPQL, native SQL, and criteria queries.
Support for named queries
Support for defining result set mappings used in
NativeQuery
,
ProcedureCall
, and StoredProcedureQuery
.Support for mutable result/fetch builder graphs nodes built dynamically via
Hibernate's
NativeQuery
APIsContains a range of internal abstractions for dealing with query execution,
query plans, query options, and query parameters.
Implementation of the SPIs for native SQL query support.
SPIs for native SQL query support.
This package defines a semantic model of HQL queries.
An SPI for defining, registering, and rendering functions in HQL.
Package for the SQM-backed Query implementation details
Support for multi-table SQM mutation (insert, update, delete) operations using
a table to temporarily hold the matching ids.
SPI for handling SQM UPDATE and DELETE queries
Package for the translation of SQM into SQL AST
Nodes representing expressions in the SQM tree.
An SPI for managing JDBC connections and other heavyweight resources, based around the
idea of a "JDBC session".
Implementation of the SPI for integrating pluggable services.
Defines an SPI for integrating pluggable services.
This package contains helper classes for rendering SQL fragments and SQL statements.
Package defining a SQL AST for use in generation of SQL.
Package defining support for creating and consuming a SQL AST.
Support for common table expressions (CTE) in a SQL tree.
AST nodes representing expressions in a SQL tree.
AST nodes representing root tables and joins in a SQL tree.
Implementation of the SPI for execution of SQL statements via JDBC.
SQL AST extensions for model mutations.
Support for building
TableMutation
references for persisting entity mutation eventsExtensions to
JdbcOperation
for model mutations.The built-in implementation of the statistics collection service.
An SPI allowing customized statistics collection.
Most contracts here have been replaced by the new runtime
mapping model.
A Hibernate
Type
is a strategy for mapping a Java
property type to a JDBC type or types.Contracts for reading and writing values to and from JDBC.
Defines a registry for Hibernate
Type
s.An API for user-defined custom types which extend the set of built-in
types defined in
org.hibernate.type
.-
Uses of SessionFactoryImplementor in org.hibernate.boot.beanvalidation
Modifier and TypeMethodDescriptionActivationContext.getSessionFactory()
Access the SessionFactory being built to trigger this BV activationModifier and TypeMethodDescriptionvoid
BeanValidationIntegrator.disintegrate
(SessionFactoryImplementor sessionFactory, SessionFactoryServiceRegistry serviceRegistry) void
BeanValidationIntegrator.integrate
(Metadata metadata, BootstrapContext bootstrapContext, SessionFactoryImplementor sessionFactory) ModifierConstructorDescriptionHibernateTraversableResolver
(EntityPersister persister, ConcurrentHashMap<EntityPersister, Set<String>> associationsPerEntityPersister, SessionFactoryImplementor factory) -
Uses of SessionFactoryImplementor in org.hibernate.boot.internal
Modifier and TypeMethodDescriptionInFlightMetadataCollectorImpl.buildNamedQueryRepository
(SessionFactoryImplementor sessionFactory) MetadataImpl.buildNamedQueryRepository
(SessionFactoryImplementor sessionFactory) void
InFlightMetadataCollectorImpl.initSessionFactory
(SessionFactoryImplementor sessionFactory) void
MetadataImpl.initSessionFactory
(SessionFactoryImplementor sessionFactory) NamedHqlQueryDefinitionImpl.resolve
(SessionFactoryImplementor factory) NamedNativeQueryDefinitionImpl.resolve
(SessionFactoryImplementor factory) NamedProcedureCallDefinitionImpl.resolve
(SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.boot.query
Modifier and TypeMethodDescriptionNamedCallableQueryDefinition.ParameterMapping.resolve
(SessionFactoryImplementor factory) NamedCallableQueryDefinition.resolve
(SessionFactoryImplementor factory) NamedHqlQueryDefinition.resolve
(SessionFactoryImplementor factory) NamedNativeQueryDefinition.resolve
(SessionFactoryImplementor factory) NamedProcedureCallDefinition.resolve
(SessionFactoryImplementor factory) NamedQueryDefinition.resolve
(SessionFactoryImplementor factory) Resolve the mapping definition into its run-time memento form -
Uses of SessionFactoryImplementor in org.hibernate.boot.spi
Modifier and TypeMethodDescriptionAbstractDelegatingMetadata.buildNamedQueryRepository
(SessionFactoryImplementor sessionFactory) MetadataImplementor.buildNamedQueryRepository
(SessionFactoryImplementor sessionFactory) void
AbstractDelegatingMetadata.initSessionFactory
(SessionFactoryImplementor sessionFactory) void
MetadataImplementor.initSessionFactory
(SessionFactoryImplementor sessionFactoryImplementor) -
Uses of SessionFactoryImplementor in org.hibernate.bytecode.internal.bytebuddy
Modifier and TypeMethodDescriptionProxyFactoryFactoryImpl.buildProxyFactory
(SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.bytecode.spi
Modifier and TypeMethodDescriptionProxyFactoryFactory.buildProxyFactory
(SessionFactoryImplementor sessionFactory) Build a proxy factory specifically for handling runtime lazy loading. -
Uses of SessionFactoryImplementor in org.hibernate.cache.cfg.spi
Modifier and TypeMethodDescriptionDomainDataRegionBuildingContext.getSessionFactory()
Access to the SessionFactory for which a Region is being built. -
Uses of SessionFactoryImplementor in org.hibernate.cache.internal
Modifier and TypeMethodDescriptionDisabledCaching.getSessionFactory()
EnabledCaching.getSessionFactory()
Modifier and TypeMethodDescriptionNoCachingRegionFactory.buildQueryResultsRegion
(String regionName, SessionFactoryImplementor sessionFactory) NoCachingRegionFactory.buildTimestampsRegion
(String regionName, SessionFactoryImplementor sessionFactory) DefaultCacheKeysFactory.createCollectionKey
(Object id, CollectionPersister persister, SessionFactoryImplementor factory, String tenantIdentifier) SimpleCacheKeysFactory.createCollectionKey
(Object id, CollectionPersister persister, SessionFactoryImplementor factory, String tenantIdentifier) DefaultCacheKeysFactory.createEntityKey
(Object id, EntityPersister persister, SessionFactoryImplementor factory, String tenantIdentifier) SimpleCacheKeysFactory.createEntityKey
(Object id, EntityPersister persister, SessionFactoryImplementor factory, String tenantIdentifier) void
CollectionCacheInvalidator.disintegrate
(SessionFactoryImplementor sessionFactory, SessionFactoryServiceRegistry serviceRegistry) void
CollectionCacheInvalidator.integrate
(Metadata metadata, SessionFactoryImplementor sessionFactory, SessionFactoryServiceRegistry serviceRegistry) static Object
DefaultCacheKeysFactory.staticCreateCollectionKey
(Object id, CollectionPersister persister, SessionFactoryImplementor factory, String tenantIdentifier) static Object
DefaultCacheKeysFactory.staticCreateEntityKey
(Object id, EntityPersister persister, SessionFactoryImplementor factory, String tenantIdentifier) ModifierConstructorDescriptionDisabledCaching
(SessionFactoryImplementor sessionFactory) EnabledCaching
(SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.cache.jcache.internal
Modifier and TypeMethodDescriptionprotected boolean
JCacheRegionFactory.cacheExists
(String unqualifiedRegionName, SessionFactoryImplementor sessionFactory) protected StorageAccess
JCacheRegionFactory.createQueryResultsRegionStorageAccess
(String regionName, SessionFactoryImplementor sessionFactory) protected StorageAccess
JCacheRegionFactory.createTimestampsRegionStorageAccess
(String regionName, SessionFactoryImplementor sessionFactory) protected final String
JCacheRegionFactory.defaultRegionName
(String regionName, SessionFactoryImplementor sessionFactory, String defaultRegionName, List<String> legacyDefaultRegionNames) JCacheRegionFactory.getOrCreateCache
(String unqualifiedRegionName, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.cache.spi
Modifier and TypeMethodDescriptionRegionFactory.buildQueryResultsRegion
(String regionName, SessionFactoryImplementor sessionFactory) Create a namedRegion
for holding query result sets.RegionFactory.buildTimestampsRegion
(String regionName, SessionFactoryImplementor sessionFactory) Create a namedRegion
for holding timestamps used to determine when a cached query result set is stale.CacheKeysFactory.createCollectionKey
(Object id, CollectionPersister persister, SessionFactoryImplementor factory, String tenantIdentifier) CacheKeysFactory.createEntityKey
(Object id, EntityPersister persister, SessionFactoryImplementor factory, String tenantIdentifier) -
Uses of SessionFactoryImplementor in org.hibernate.cache.spi.access
Modifier and TypeMethodDescriptionCollectionDataAccess.generateCacheKey
(Object id, CollectionPersister collectionDescriptor, SessionFactoryImplementor factory, String tenantIdentifier) To create instances of CollectionCacheKey for this region, Hibernate will invoke this method exclusively so that generated implementations can generate optimised keys.EntityDataAccess.generateCacheKey
(Object id, EntityPersister rootEntityDescriptor, SessionFactoryImplementor factory, String tenantIdentifier) To create instances of keys for this region, Hibernate will invoke this method exclusively so that generated implementations can generate optimised keys. -
Uses of SessionFactoryImplementor in org.hibernate.cache.spi.entry
Modifier and TypeMethodDescriptionCacheEntryStructure.destructure
(Object structured, SessionFactoryImplementor factory) Convert the previous structured form of the item back into its item form.StructuredCacheEntry.destructure
(Object structured, SessionFactoryImplementor factory) StructuredCollectionCacheEntry.destructure
(Object structured, SessionFactoryImplementor factory) StructuredMapCacheEntry.destructure
(Object structured, SessionFactoryImplementor factory) UnstructuredCacheEntry.destructure
(Object structured, SessionFactoryImplementor factory) -
Uses of SessionFactoryImplementor in org.hibernate.cache.spi.support
Modifier and TypeMethodDescriptionRegionFactoryTemplate.buildQueryResultsRegion
(String regionName, SessionFactoryImplementor sessionFactory) RegionFactoryTemplate.buildTimestampsRegion
(String regionName, SessionFactoryImplementor sessionFactory) protected abstract StorageAccess
RegionFactoryTemplate.createQueryResultsRegionStorageAccess
(String regionName, SessionFactoryImplementor sessionFactory) protected abstract StorageAccess
RegionFactoryTemplate.createTimestampsRegionStorageAccess
(String regionName, SessionFactoryImplementor sessionFactory) AbstractCollectionDataAccess.generateCacheKey
(Object id, CollectionPersister persister, SessionFactoryImplementor factory, String tenantIdentifier) AbstractEntityDataAccess.generateCacheKey
(Object id, EntityPersister rootEntityDescriptor, SessionFactoryImplementor factory, String tenantIdentifier) CollectionReadWriteAccess.generateCacheKey
(Object id, CollectionPersister collectionDescriptor, SessionFactoryImplementor factory, String tenantIdentifier) EntityReadWriteAccess.generateCacheKey
(Object id, EntityPersister rootEntityDescriptor, SessionFactoryImplementor factory, String tenantIdentifier) -
Uses of SessionFactoryImplementor in org.hibernate.context.internal
Modifier and TypeMethodDescriptionprotected SessionFactoryImplementor
ThreadLocalSessionContext.getFactory()
Getter for property 'factory'.ModifierConstructorDescriptionConstructs a JTASessionContextConstructs a new ManagedSessionContextConstructs a ThreadLocal -
Uses of SessionFactoryImplementor in org.hibernate.context.spi
Modifier and TypeMethodDescriptionAbstractCurrentSessionContext.factory()
Access to the SessionFactoryModifierConstructorDescriptionprotected
-
Uses of SessionFactoryImplementor in org.hibernate.dialect
Modifier and TypeMethodDescriptionDialect.createOptionalTableUpdateOperation
(EntityMutationTarget mutationTarget, OptionalTableUpdate optionalTableUpdate, SessionFactoryImplementor factory) Create aMutationOperation
for a updating an optional tableDialectDelegateWrapper.createOptionalTableUpdateOperation
(EntityMutationTarget mutationTarget, OptionalTableUpdate optionalTableUpdate, SessionFactoryImplementor factory) H2Dialect.createOptionalTableUpdateOperation
(EntityMutationTarget mutationTarget, OptionalTableUpdate optionalTableUpdate, SessionFactoryImplementor factory) OracleDialect.createOptionalTableUpdateOperation
(EntityMutationTarget mutationTarget, OptionalTableUpdate optionalTableUpdate, SessionFactoryImplementor factory) PostgresPlusDialect.createOptionalTableUpdateOperation
(EntityMutationTarget mutationTarget, OptionalTableUpdate optionalTableUpdate, SessionFactoryImplementor factory) PostgreSQLDialect.createOptionalTableUpdateOperation
(EntityMutationTarget mutationTarget, OptionalTableUpdate optionalTableUpdate, SessionFactoryImplementor factory) SQLServerDialect.createOptionalTableUpdateOperation
(EntityMutationTarget mutationTarget, OptionalTableUpdate optionalTableUpdate, SessionFactoryImplementor factory) static String
MySQLSqlAstTranslator.getSqlType
(CastTarget castTarget, SessionFactoryImplementor factory) static Object
StructHelper.instantiate
(EmbeddableMappingType embeddableMappingType, StructAttributeValues attributeValues, SessionFactoryImplementor sessionFactory) ModifierConstructorDescriptionCockroachSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) DB2iSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement, DatabaseVersion version) DB2SqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) DB2zSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement, DatabaseVersion version) DerbySqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) H2SqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) HANASqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) HSQLSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) MariaDBSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) MySQLSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) OracleSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) PostgreSQLSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) SpannerSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) SqlAstTranslatorWithMerge
(SessionFactoryImplementor sessionFactory, Statement statement) protected
SqlAstTranslatorWithUpsert
(SessionFactoryImplementor sessionFactory, Statement statement) SQLServerSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) SybaseASESqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) SybaseSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) TiDBSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) -
Uses of SessionFactoryImplementor in org.hibernate.dialect.identity
Modifier and TypeMethodDescriptionvoid
H2FinalTableIdentityColumnSupport.render
(TableInsert tableInsert, Consumer<String> sqlAppender, Consumer<ColumnReference> returnColumnHandler, H2IdentityColumnSupport.InsertValuesHandler insertValuesHandler, SessionFactoryImplementor sessionFactory) Deprecated.void
H2IdentityColumnSupport.render
(TableInsert tableInsert, Consumer<String> sqlAppender, Consumer<ColumnReference> returnColumnHandler, H2IdentityColumnSupport.InsertValuesHandler insertValuesHandler, SessionFactoryImplementor sessionFactory) Deprecated. -
Uses of SessionFactoryImplementor in org.hibernate.dialect.temptable
ModifierConstructorDescriptionTemporaryTableCreationWork
(TemporaryTable temporaryTable, TemporaryTableExporter exporter, SessionFactoryImplementor sessionFactory) TemporaryTableCreationWork
(TemporaryTable temporaryTable, SessionFactoryImplementor sessionFactory) TemporaryTableDropWork
(TemporaryTable temporaryTable, TemporaryTableExporter exporter, SessionFactoryImplementor sessionFactory) TemporaryTableDropWork
(TemporaryTable temporaryTable, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.engine.internal
Modifier and TypeMethodDescriptionstatic <T> VersionValue
UnsavedValueFactory.getUnsavedVersionValue
(KeyValue bootVersionMapping, VersionJavaType<T> jtd, Long length, Integer precision, Integer scale, Getter getter, Supplier<?> templateInstanceAccess, SessionFactoryImplementor sessionFactory) Return theUnsavedValueStrategy
for determining whether an entity instance is unsaved based on the version.ModifierConstructorDescriptionprotected
AbstractEntityEntry
(SessionFactoryImplementor factory, String entityName, Object id, Status status, Status previousStatus, Object[] loadedState, Object[] deletedState, Object version, LockMode lockMode, boolean existsInDatabase, boolean isBeingReplicated, PersistenceContext persistenceContext) This for is used during custom deserialization handling -
Uses of SessionFactoryImplementor in org.hibernate.engine.jdbc.mutation.internal
Modifier and TypeMethodDescriptionstatic boolean
ModelMutationHelper.identifiedResultsCheck
(PreparedStatementDetails statementDetails, int affectedRowCount, int batchPosition, MutationTarget<?> mutationTarget, Object id, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.engine.query.spi
Modifier and TypeMethodDescriptiondefault <R> NativeSelectQueryPlan<R>
NativeQueryInterpreter.createQueryPlan
(NativeSelectQueryDefinition<R> queryDefinition, SessionFactoryImplementor sessionFactory) Creates a new query plan for the passed native query definition -
Uses of SessionFactoryImplementor in org.hibernate.engine.spi
Modifier and TypeInterfaceDescriptionstatic interface
Deprecated, for removal: This API element is subject to removal in a future version.this is no longer usedModifier and TypeClassDescriptionclass
Base delegating implementation of theSessionFactory
andSessionFactoryImplementor
contracts for intended for easier implementation ofSessionFactory
.Modifier and TypeMethodDescriptionprotected SessionFactoryImplementor
SessionFactoryDelegatingImpl.delegate()
SessionDelegatorBaseImpl.getFactory()
SharedSessionContractImplementor.getFactory()
Obtain the factory which created this session.SharedSessionDelegatorBaseImpl.getFactory()
AbstractDelegatingWrapperOptions.getSessionFactory()
LoadQueryInfluencers.getSessionFactory()
SessionDelegatorBaseImpl.getSessionFactory()
default SessionFactoryImplementor
SessionFactoryImplementor.getSessionFactory()
SessionImplementor.getSessionFactory()
default SessionFactoryImplementor
SharedSessionContractImplementor.getSessionFactory()
Obtain the factory which created this session.Modifier and TypeMethodDescriptionstatic EntityKey
EntityKey.deserialize
(ObjectInputStream ois, SessionFactoryImplementor sessionFactory) Custom deserialization routine used during deserialization of a Session/PersistenceContext for increased performance.static int
EntityUniqueKey.generateHashCode
(String entityName, String uniqueKeyName, Type keyType, Object key, SessionFactoryImplementor factory) ModifierConstructorDescriptionCollectionEntry
(PersistentCollection<?> collection, SessionFactoryImplementor factory) For initialized detached collectionsEntityUniqueKey
(String entityName, String uniqueKeyName, Object key, Type keyType, SessionFactoryImplementor factory) LoadQueryInfluencers
(SessionFactoryImplementor sessionFactory) LoadQueryInfluencers
(SessionFactoryImplementor sessionFactory, SessionCreationOptions options) -
Uses of SessionFactoryImplementor in org.hibernate.envers.boot.internal
Modifier and TypeMethodDescriptionvoid
EnversIntegrator.disintegrate
(SessionFactoryImplementor sessionFactory, SessionFactoryServiceRegistry serviceRegistry) void
EnversIntegrator.integrate
(Metadata metadata, BootstrapContext bootstrapContext, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.envers.internal.entities.mapper.relation.query
Modifier and TypeMethodDescriptionprotected abstract QueryBuilder
AbstractRelationQueryGenerator.buildQueryBuilderCommon
(SessionFactoryImplementor sessionFactory) Build the common aspects of aQueryBuilder
used by both query and query-remove strings.protected QueryBuilder
OneAuditEntityQueryGenerator.buildQueryBuilderCommon
(SessionFactoryImplementor sessionFactory) protected QueryBuilder
OneEntityQueryGenerator.buildQueryBuilderCommon
(SessionFactoryImplementor sessionFactory) protected QueryBuilder
ThreeEntityQueryGenerator.buildQueryBuilderCommon
(SessionFactoryImplementor sessionFactory) protected QueryBuilder
TwoEntityOneAuditedQueryGenerator.buildQueryBuilderCommon
(SessionFactoryImplementor sessionFactory) protected QueryBuilder
TwoEntityQueryGenerator.buildQueryBuilderCommon
(SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.envers.internal.tools
Modifier and TypeMethodDescriptionstatic Object
EntityTools.getTargetFromProxy
(SessionFactoryImplementor sessionFactoryImplementor, LazyInitializer lazyInitializer) -
Uses of SessionFactoryImplementor in org.hibernate.envers.internal.tools.query
ModifierConstructorDescriptionQueryBuilder
(String entityName, String alias, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.event.spi
Modifier and TypeMethodDescriptionAbstractEvent.getFactory()
AbstractPreDatabaseOperationEvent.getFactory()
The factory which owns the persister for the entity.PostDeleteEvent.getFactory()
PostInsertEvent.getFactory()
PostUpdateEvent.getFactory()
PostUpsertEvent.getFactory()
ModifierConstructorDescriptionEventEngine
(MetadataImplementor mappings, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.generator.values
Modifier and TypeMethodDescriptionGeneratedValuesMutationDelegate.createTableMutationBuilder
(Expectation expectation, SessionFactoryImplementor sessionFactory) Create aTableMutationBuilder
instance used to build table mutations for this delegate. -
Uses of SessionFactoryImplementor in org.hibernate.generator.values.internal
Modifier and TypeMethodDescriptionvoid
GeneratedValuesMappingProducer.addAffectedTableNames
(Set<String> affectedTableNames, SessionFactoryImplementor sessionFactory) GeneratedValuesMappingProducer.resolve
(JdbcValuesMetadata jdbcResultsMetadata, LoadQueryInfluencers loadQueryInfluencers, SessionFactoryImplementor sessionFactory) ModifierConstructorDescriptionTableUpdateReturningBuilder
(EntityPersister mutationTarget, MutatingTableReference tableReference, List<ColumnReference> generatedColumns, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.graph.internal.parse
Modifier and TypeMethodDescriptionSubGraphGenerator.createSubGraph
(AttributeNodeImplementor<?> attributeNode, String subTypeName, SessionFactoryImplementor sessionFactory) static void
GraphParser.parseInto
(GraphImplementor<?> targetGraph, CharSequence graphString, SessionFactoryImplementor sessionFactory) Parse the passed graph textual representation into the passed Graph.static void
GraphParser.parseInto
(GraphImplementor<?> targetGraph, String graphString, SessionFactoryImplementor sessionFactory) Parse the passed graph textual representation into the passed Graph. -
Uses of SessionFactoryImplementor in org.hibernate.id.insert
Modifier and TypeMethodDescriptiondefault TableInsertBuilder
InsertGeneratedIdentifierDelegate.createTableInsertBuilder
(BasicEntityIdentifierMapping identifierMapping, Expectation expectation, SessionFactoryImplementor sessionFactory) Deprecated, for removal: This API element is subject to removal in a future version.Create aTableInsertBuilder
with any specific identity handling already built in.BasicSelectingDelegate.createTableMutationBuilder
(Expectation expectation, SessionFactoryImplementor factory) GetGeneratedKeysDelegate.createTableMutationBuilder
(Expectation expectation, SessionFactoryImplementor factory) InsertReturningDelegate.createTableMutationBuilder
(Expectation expectation, SessionFactoryImplementor sessionFactory) UniqueKeySelectingDelegate.createTableMutationBuilder
(Expectation expectation, SessionFactoryImplementor factory) ModifierConstructorDescriptionIdentifierGeneratingInsert
(SessionFactoryImplementor sessionFactory) InsertSelectIdentityInsert
(SessionFactoryImplementor sessionFactory) Deprecated.TableInsertReturningBuilder
(PostInsertIdentityPersister mutationTarget, SessionFactoryImplementor sessionFactory) Deprecated, for removal: This API element is subject to removal in a future version.TableInsertReturningBuilder
(EntityPersister mutationTarget, MutatingTableReference tableReference, List<ColumnReference> generatedColumns, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.integrator.spi
Modifier and TypeMethodDescriptionvoid
Integrator.disintegrate
(SessionFactoryImplementor sessionFactory, SessionFactoryServiceRegistry serviceRegistry) Tongue-in-cheek name for a shutdown callback.default void
Integrator.integrate
(Metadata metadata, BootstrapContext bootstrapContext, SessionFactoryImplementor sessionFactory) Perform integration.default void
Integrator.integrate
(Metadata metadata, SessionFactoryImplementor sessionFactory, SessionFactoryServiceRegistry serviceRegistry) Deprecated.- use -
Uses of SessionFactoryImplementor in org.hibernate.internal
Modifier and TypeMethodDescriptionSessionFactoryRegistry.findSessionFactory
(String uuid, String name) SessionImpl.getEntityManagerFactory()
AbstractSharedSessionContract.getFactory()
SessionFactoryRegistry.getNamedSessionFactory
(String name) Get a registered SessionFactory by nameJdbcSessionContextImpl.getSessionFactory()
Deprecated.SessionFactoryRegistry.getSessionFactory
(String uuid) SessionImpl.getSessionFactory()
Modifier and TypeMethodDescriptionvoid
SessionFactoryRegistry.addSessionFactory
(String uuid, String name, boolean isNameAlsoJndiName, SessionFactoryImplementor instance, JndiService jndiService) Adds a SessionFactory to the registryFilterConfiguration.getAliasTableMap
(SessionFactoryImplementor factory) void
CoreMessageLogger.scopingTypesToSessionFactoryAfterAlreadyScoped
(SessionFactoryImplementor factory, SessionFactoryImplementor factory2) protected final void
AbstractSharedSessionContract.setUpMultitenancy
(SessionFactoryImplementor factory, LoadQueryInfluencers loadQueryInfluencers) ModifierConstructorDescriptionConnectionObserverStatsBridge
(SessionFactoryImplementor sessionFactory) CoordinatingEntityNameResolver
(SessionFactoryImplementor sessionFactory, Interceptor interceptor) FilterHelper
(List<FilterConfiguration> filters, Map<String, String> tableToEntityName, SessionFactoryImplementor factory) The map of defined filters.FilterHelper
(List<FilterConfiguration> filters, SessionFactoryImplementor factory) JdbcSessionContextImpl
(SessionFactoryImplementor sessionFactory, StatementInspector statementInspector, PhysicalConnectionHandlingMode connectionHandlingMode, JdbcServices jdbcServices, BatchBuilder batchBuilder, JdbcObserver jdbcObserver) -
Uses of SessionFactoryImplementor in org.hibernate.internal.util
-
Uses of SessionFactoryImplementor in org.hibernate.jpa.internal
-
Uses of SessionFactoryImplementor in org.hibernate.loader.ast.internal
Modifier and TypeFieldDescriptionprotected final SessionFactoryImplementor
SingleIdEntityLoaderSupport.sessionFactory
Modifier and TypeMethodDescriptionAbstractCollectionBatchLoader.getSessionFactory()
protected SessionFactoryImplementor
AbstractMultiIdEntityLoader.getSessionFactory()
Modifier and TypeMethodDescriptionStandardBatchLoaderFactory.createCollectionBatchLoader
(int domainBatchSize, LoadQueryInfluencers influencers, PluralAttributeMapping attributeMapping, SessionFactoryImplementor factory) static SelectStatement
LoaderSelectBuilder.createSelect
(Loadable loadable, List<? extends ModelPart> partsToSelect, List<ModelPart> restrictedParts, DomainResult<?> cachedDomainResult, int numberOfKeysToLoad, LoadQueryInfluencers loadQueryInfluencers, LockOptions lockOptions, Consumer<JdbcParameter> jdbcParameterConsumer, SessionFactoryImplementor sessionFactory) static SelectStatement
LoaderSelectBuilder.createSelect
(Loadable loadable, List<? extends ModelPart> partsToSelect, ModelPart restrictedPart, DomainResult<?> cachedDomainResult, int numberOfKeysToLoad, LoadQueryInfluencers loadQueryInfluencers, LockOptions lockOptions, Consumer<JdbcParameter> jdbcParameterConsumer, SessionFactoryImplementor sessionFactory) Create an SQL AST select-statement based on matching one-or-more keysstatic SelectStatement
LoaderSelectBuilder.createSelectBySingleArrayParameter
(Loadable loadable, ValuedModelPart restrictedPart, LoadQueryInfluencers influencers, LockOptions lockOptions, JdbcParameter jdbcArrayParameter, SessionFactoryImplementor sessionFactory) Create a select-statement (SQL AST) for loading by multiple keys using a single SQL ARRAY parameterstatic SelectStatement
LoaderSelectBuilder.createSelectByUniqueKey
(Loadable loadable, List<? extends ModelPart> partsToSelect, ModelPart restrictedPart, DomainResult<?> cachedDomainResult, LoadQueryInfluencers loadQueryInfluencers, LockOptions lockOptions, Consumer<JdbcParameter> jdbcParameterConsumer, SessionFactoryImplementor sessionFactory) Create an SQL AST select-statement for loading by unique keystatic SelectStatement
LoaderSelectBuilder.createSubSelectFetchSelect
(PluralAttributeMapping attributeMapping, SubselectFetch subselect, DomainResult<?> cachedDomainResult, LoadQueryInfluencers loadQueryInfluencers, LockOptions lockOptions, Consumer<JdbcParameter> jdbcParameterConsumer, SessionFactoryImplementor sessionFactory) Create an SQL AST select-statement used for subselect-based CollectionLoaderstatic <K> K[]
LoaderHelper.normalizeKeys
(K[] keys, BasicValuedModelPart keyPart, SharedSessionContractImplementor session, SessionFactoryImplementor sessionFactory) Normalize an array of keys (primary, foreign or natural).static JdbcMapping
MultiKeyLoadHelper.resolveArrayJdbcMapping
(BasicType<?> arrayBasicType, JdbcMapping keyMapping, Class<?> arrayClass, SessionFactoryImplementor sessionFactory) protected Expression
AbstractNaturalIdLoader.resolveColumnReference
(TableGroup rootTableGroup, SelectableMapping selectableMapping, SqlExpressionResolver sqlExpressionResolver, SessionFactoryImplementor sessionFactory) Helper to resolve ColumnReferencesSingleIdEntityLoaderStandardImpl.resolveLoadPlan
(LockOptions lockOptions, LoadQueryInfluencers loadQueryInfluencers, SessionFactoryImplementor sessionFactory) ModifierConstructorDescriptionAbstractCollectionBatchLoader
(int domainBatchSize, LoadQueryInfluencers influencers, PluralAttributeMapping attributeMapping, SessionFactoryImplementor sessionFactory) AbstractMultiIdEntityLoader
(EntityMappingType entityDescriptor, SessionFactoryImplementor sessionFactory) CollectionBatchLoaderArrayParam
(int domainBatchSize, LoadQueryInfluencers loadQueryInfluencers, PluralAttributeMapping attributeMapping, SessionFactoryImplementor sessionFactory) CollectionBatchLoaderInPredicate
(int domainBatchSize, LoadQueryInfluencers influencers, PluralAttributeMapping attributeMapping, SessionFactoryImplementor sessionFactory) CollectionElementLoaderByIndex
(PluralAttributeMapping attributeMapping, int baseIndex, LoadQueryInfluencers influencers, SessionFactoryImplementor sessionFactory) CollectionElementLoaderByIndex
(PluralAttributeMapping attributeMapping, LoadQueryInfluencers influencers, SessionFactoryImplementor sessionFactory) Shortened form ofCollectionElementLoaderByIndex(PluralAttributeMapping, int, LoadQueryInfluencers, SessionFactoryImplementor)
which applied the collection mapping's PluralAttributeMapping.IndexMetadata.getListIndexBase()CollectionLoaderSingleKey
(PluralAttributeMapping attributeMapping, LoadQueryInfluencers influencers, SessionFactoryImplementor sessionFactory) EntityConcreteTypeLoader
(EntityMappingType entityDescriptor, SessionFactoryImplementor sessionFactory) MultiIdEntityLoaderArrayParam
(EntityMappingType entityDescriptor, SessionFactoryImplementor sessionFactory) MultiIdEntityLoaderStandard
(EntityPersister entityDescriptor, int idColumnSpan, SessionFactoryImplementor sessionFactory) MultiNaturalIdLoadingBatcher
(EntityMappingType entityDescriptor, ModelPart restrictedPart, int batchSize, org.hibernate.loader.ast.internal.MultiNaturalIdLoadingBatcher.KeyValueResolver keyValueResolver, LoadQueryInfluencers loadQueryInfluencers, LockOptions lockOptions, SessionFactoryImplementor sessionFactory) SingleIdArrayLoadPlan
(EntityMappingType entityMappingType, ModelPart restrictivePart, SelectStatement sqlAst, JdbcParametersList jdbcParameters, LockOptions lockOptions, SessionFactoryImplementor sessionFactory) SingleIdEntityLoaderSupport
(EntityMappingType entityDescriptor, SessionFactoryImplementor sessionFactory) SingleIdLoadPlan
(EntityMappingType entityMappingType, ModelPart restrictivePart, SelectStatement sqlAst, JdbcParametersList jdbcParameters, LockOptions lockOptions, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.loader.ast.spi
Modifier and TypeMethodDescriptionBatchLoaderFactory.createCollectionBatchLoader
(int domainBatchSize, LoadQueryInfluencers influencers, PluralAttributeMapping attributeMapping, SessionFactoryImplementor factory) Create a BatchLoader for batch-loadable collections.default <T> EntityBatchLoader<T>
BatchLoaderFactory.createEntityBatchLoader
(int domainBatchSize, EntityMappingType entityDescriptor, SessionFactoryImplementor factory) Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of SessionFactoryImplementor in org.hibernate.metamodel.internal
Modifier and TypeFieldDescriptionprotected final SessionFactoryImplementor
AbstractCompositeIdentifierMapping.sessionFactory
Modifier and TypeMethodDescriptionEmbeddableCompositeUserTypeInstantiator.instantiate
(ValueAccess valuesAccess, SessionFactoryImplementor sessionFactory) EmbeddableInstantiatorDynamicMap.instantiate
(ValueAccess valuesAccess, SessionFactoryImplementor sessionFactory) EmbeddableInstantiatorPojoIndirecting.instantiate
(ValueAccess valuesAccess, SessionFactoryImplementor sessionFactory) EmbeddableInstantiatorPojoOptimized.instantiate
(ValueAccess valuesAccess, SessionFactoryImplementor sessionFactory) EmbeddableInstantiatorPojoStandard.instantiate
(ValueAccess valuesAccess, SessionFactoryImplementor sessionFactory) EmbeddableInstantiatorProxied.instantiate
(ValueAccess valuesAccess, SessionFactoryImplementor sessionFactory) EmbeddableInstantiatorRecordIndirecting.instantiate
(ValueAccess valuesAccess, SessionFactoryImplementor sessionFactory) EmbeddableInstantiatorRecordStandard.instantiate
(ValueAccess valuesAccess, SessionFactoryImplementor sessionFactory) EntityInstantiatorDynamicMap.instantiate
(SessionFactoryImplementor sessionFactory) EntityInstantiatorPojoOptimized.instantiate
(SessionFactoryImplementor sessionFactory) EntityInstantiatorPojoStandard.instantiate
(SessionFactoryImplementor sessionFactory) boolean
AbstractDynamicMapInstantiator.isInstance
(Object object, SessionFactoryImplementor sessionFactory) boolean
AbstractEntityInstantiatorPojo.isInstance
(Object object, SessionFactoryImplementor sessionFactory) boolean
AbstractPojoInstantiator.isInstance
(Object object, SessionFactoryImplementor sessionFactory) boolean
EmbeddableCompositeUserTypeInstantiator.isInstance
(Object object, SessionFactoryImplementor sessionFactory) boolean
EmbeddableInstantiatorProxied.isInstance
(Object object, SessionFactoryImplementor sessionFactory) boolean
EntityInstantiatorPojoStandard.isInstance
(Object object, SessionFactoryImplementor sessionFactory) boolean
AbstractDynamicMapInstantiator.isSameClass
(Object object, SessionFactoryImplementor sessionFactory) boolean
AbstractPojoInstantiator.isSameClass
(Object object, SessionFactoryImplementor sessionFactory) boolean
EmbeddableCompositeUserTypeInstantiator.isSameClass
(Object object, SessionFactoryImplementor sessionFactory) boolean
EmbeddableInstantiatorProxied.isSameClass
(Object object, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.metamodel.mapping.internal
Modifier and TypeMethodDescriptionstatic void
ToOneAttributeMapping.addPrefixedPropertyNames
(Set<String> targetKeyPropertyNames, String prefix, Type type, SessionFactoryImplementor factory) static void
ToOneAttributeMapping.addPrefixedPropertyPaths
(Set<String> targetKeyPropertyNames, String prefix, Type type, SessionFactoryImplementor factory) static Expression
MappingModelCreationHelper.buildColumnReferenceExpression
(TableGroup tableGroup, ModelPart modelPart, SqlExpressionResolver sqlExpressionResolver, SessionFactoryImplementor sessionFactory) static FetchStyle
FetchOptionsHelper.determineFetchStyleByMetadata
(FetchMode mappingFetchMode, AssociationType type, SessionFactoryImplementor sessionFactory) static FetchTiming
FetchOptionsHelper.determineFetchTiming
(FetchStyle style, AssociationType type, boolean lazy, String role, SessionFactoryImplementor sessionFactory) static FetchTiming
FetchOptionsHelper.determineFetchTiming
(FetchStyle style, AssociationType type, SessionFactoryImplementor sessionFactory) static String
MappingModelCreationHelper.getTableIdentifierExpression
(Table table, SessionFactoryImplementor sessionFactory) void
CaseStatementDiscriminatorMappingImpl.CaseStatementDiscriminatorExpression.renderToSql
(SqlAppender sqlAppender, SqlAstTranslator<?> walker, SessionFactoryImplementor sessionFactory) ModifierConstructorDescriptionDiscriminatedAssociationMapping
(DiscriminatedAssociationModelPart modelPart, AnyDiscriminatorPart discriminatorPart, BasicValuedModelPart keyPart, JavaType<?> baseAssociationJtd, FetchTiming fetchTiming, SessionFactoryImplementor sessionFactory) GeneratedValuesProcessor
(EntityPersister entityDescriptor, List<AttributeMapping> generatedAttributes, EventType timing, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.metamodel.mapping.ordering
-
Uses of SessionFactoryImplementor in org.hibernate.metamodel.spi
Modifier and TypeMethodDescriptionEmbeddableInstantiator.instantiate
(ValueAccess valueAccess, SessionFactoryImplementor sessionFactory) Create an instance of the embeddableEntityInstantiator.instantiate
(SessionFactoryImplementor sessionFactory) Create an instance of managed entityboolean
Instantiator.isInstance
(Object object, SessionFactoryImplementor sessionFactory) Performs and "instance of" check to see if the given object is an instance of managed structureboolean
Instantiator.isSameClass
(Object object, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.persister.collection
Modifier and TypeMethodDescriptionAbstractCollectionPersister.getFactory()
CollectionPersister.getFactory()
-
Uses of SessionFactoryImplementor in org.hibernate.persister.collection.mutation
ModifierConstructorDescriptionAbstractUpdateRowsCoordinator
(CollectionMutationTarget mutationTarget, SessionFactoryImplementor sessionFactory) UpdateRowsCoordinatorOneToMany
(CollectionMutationTarget mutationTarget, RowMutationOperations rowMutationOperations, SessionFactoryImplementor sessionFactory) UpdateRowsCoordinatorStandard
(CollectionMutationTarget mutationTarget, RowMutationOperations rowMutationOperations, SessionFactoryImplementor sessionFactory) UpdateRowsCoordinatorTablePerSubclass
(OneToManyPersister mutationTarget, RowMutationOperations rowMutationOperations, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.persister.entity
Modifier and TypeMethodDescriptionAbstractEntityPersister.getFactory()
EntityPersister.getFactory()
Return theSessionFactory
to which this persister belongs.SessionFactoryBasedWrapperOptions.getSessionFactory()
Modifier and TypeMethodDescriptionDiscriminatorType.deepCopy
(Object value, SessionFactoryImplementor factory) Deprecated, for removal: This API element is subject to removal in a future version.AbstractEntityPersister.getSubclassEntityPersister
(Object instance, SessionFactoryImplementor factory) EntityPersister.getSubclassEntityPersister
(Object instance, SessionFactoryImplementor factory) Obtain theEntityPersister
for the concrete class of the given entity instance which participates in a mapped inheritance hierarchy with this persister.DiscriminatorType.toLoggableString
(Object value, SessionFactoryImplementor factory) Deprecated, for removal: This API element is subject to removal in a future version.ModifierConstructorDescription -
Uses of SessionFactoryImplementor in org.hibernate.persister.entity.mutation
Modifier and TypeFieldDescriptionprotected final SessionFactoryImplementor
AbstractMutationCoordinator.factory
Modifier and TypeMethodDescriptionprotected SessionFactoryImplementor
AbstractMutationCoordinator.factory()
ModifierConstructorDescriptionAbstractDeleteCoordinator
(AbstractEntityPersister entityPersister, SessionFactoryImplementor factory) AbstractMutationCoordinator
(AbstractEntityPersister entityPersister, SessionFactoryImplementor factory) DeleteCoordinatorSoft
(AbstractEntityPersister entityPersister, SessionFactoryImplementor factory) DeleteCoordinatorStandard
(AbstractEntityPersister entityPersister, SessionFactoryImplementor factory) InsertCoordinatorStandard
(AbstractEntityPersister entityPersister, SessionFactoryImplementor factory) MergeCoordinator
(AbstractEntityPersister entityPersister, SessionFactoryImplementor factory) UpdateCoordinatorStandard
(AbstractEntityPersister entityPersister, SessionFactoryImplementor factory) protected
UpdateCoordinatorStandard
(AbstractEntityPersister entityPersister, SessionFactoryImplementor factory, MutationOperationGroup staticUpdateGroup, BatchKey batchKey, MutationOperationGroup versionUpdateGroup, BatchKey versionUpdateBatchkey) -
Uses of SessionFactoryImplementor in org.hibernate.persister.spi
-
Uses of SessionFactoryImplementor in org.hibernate.pretty
Modifier and TypeMethodDescriptionstatic String
MessageHelper.collectionInfoString
(@Nullable CollectionPersister persister, @Nullable Object id, SessionFactoryImplementor factory) Generate an info message string relating to a particular managed collection.static String
MessageHelper.collectionInfoString
(@Nullable CollectionPersister persister, Object[] ids, SessionFactoryImplementor factory) Generate an info message string relating to a series of managed collections.static String
MessageHelper.infoString
(@Nullable EntityPersister persister, @Nullable Object id, @Nullable SessionFactoryImplementor factory) Generate an info message string relating to a particular entity.static String
MessageHelper.infoString
(@Nullable EntityPersister persister, @Nullable Object id, Type identifierType, SessionFactoryImplementor factory) Generate an info message string relating to a particular entity,.static String
MessageHelper.infoString
(@Nullable EntityPersister persister, Object[] ids, SessionFactoryImplementor factory) Generate an info message string relating to a series of entities. -
Uses of SessionFactoryImplementor in org.hibernate.procedure.internal
Modifier and TypeMethodDescriptionProcedureParameterMetadataImpl.createBindings
(SessionFactoryImplementor sessionFactory) ModifierConstructorDescriptionProcedureParamBindings
(ProcedureParameterMetadataImpl parameterMetadata, SessionFactoryImplementor sessionFactory) ProcedureParameterBindingImpl
(ProcedureParameterImplementor<T> queryParameter, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.processor.validation
Modifier and TypeClassDescriptionclass
class
Implementation of theMock
objects based on standard annotation processor APIs.Modifier and TypeMethodDescriptionMockCollectionPersister.getFactory()
MockEntityPersister.getFactory()
MockSessionFactory.getSessionFactory()
Modifier and TypeMethodDescriptionstatic @Nullable SqmStatement<?>
Validation.validate
(String hql, @Nullable TypeMirror returnType, boolean checkTyping, Validation.Handler handler, SessionFactoryImplementor factory) static @Nullable SqmStatement<?>
Validation.validate
(String hql, @Nullable TypeMirror returnType, boolean checkTyping, Validation.Handler handler, SessionFactoryImplementor factory, int errorOffset) -
Uses of SessionFactoryImplementor in org.hibernate.query
Modifier and TypeMethodDescriptionBindableType.resolveExpressible
(SessionFactoryImplementor sessionFactory) Resolve this parameter type to the corresponding SqmExpressible -
Uses of SessionFactoryImplementor in org.hibernate.query.internal
Modifier and TypeMethodDescriptionQueryParameterBindingsImpl.copyWithoutValues
(SessionFactoryImplementor sessionFactory) ParameterMetadataImpl.createBindings
(SessionFactoryImplementor sessionFactory) static QueryEngine
QueryEngineImpl.from
(SessionFactoryImplementor sessionFactory, MetadataImplementor metadata) static QueryParameterBindingsImpl
QueryParameterBindingsImpl.from
(ParameterMetadataImplementor parameterMetadata, SessionFactoryImplementor sessionFactory) Constructs a QueryParameterBindings based on the passed informationvoid
NamedObjectRepositoryImpl.prepare
(SessionFactoryImplementor sessionFactory, Metadata bootMetamodel) NamedObjectRepositoryImpl.resolve
(SessionFactoryImplementor sessionFactory, MetadataImplementor bootMetamodel, String registrationName) <T> BindableType<T>
BindingTypeHelper.resolveTemporalPrecision
(TemporalType precision, BindableType<T> declaredParameterType, SessionFactoryImplementor sessionFactory) ModifierConstructorDescriptionNamedQueryDescriptorBuilder
(String name, Map<String, Object> hints, SessionFactoryImplementor sessionFactory) protected
QueryParameterBindingImpl
(QueryParameter<T> queryParameter, SessionFactoryImplementor sessionFactory) Used byProcedureCall
QueryParameterBindingImpl
(QueryParameter<T> queryParameter, SessionFactoryImplementor sessionFactory, BindableType<T> bindType) Used by Query (SQM) and NativeQuery -
Uses of SessionFactoryImplementor in org.hibernate.query.named
Modifier and TypeMethodDescriptionvoid
NamedObjectRepository.prepare
(SessionFactoryImplementor sessionFactory, Metadata bootMetamodel) Prepare for runtime useNamedObjectRepository.resolve
(SessionFactoryImplementor sessionFactory, MetadataImplementor bootMetamodel, String registrationName) Resolve the named query with the given name. -
Uses of SessionFactoryImplementor in org.hibernate.query.results
Modifier and TypeMethodDescriptionvoid
ResultSetMappingImpl.addAffectedTableNames
(Set<String> affectedTableNames, SessionFactoryImplementor sessionFactory) static ResultBuilder
Builders.attributeResult
(String columnAlias, String entityName, String attributePath, SessionFactoryImplementor sessionFactory) static <O,
R> ResultBuilder Builders.converted
(String columnAlias, Class<O> domainJavaType, Class<R> jdbcJavaType, AttributeConverter<O, R> converter, SessionFactoryImplementor sessionFactory) static <O,
R> ResultBuilder Builders.converted
(String columnAlias, Class<O> domainJavaType, Class<R> jdbcJavaType, Class<? extends AttributeConverter<O, R>> converterJavaType, SessionFactoryImplementor sessionFactory) static <R> ResultBuilder
Builders.converted
(String columnAlias, Class<R> jdbcJavaType, AttributeConverter<?, R> converter, SessionFactoryImplementor sessionFactory) static <R> ResultBuilder
Builders.converted
(String columnAlias, Class<R> jdbcJavaType, Class<? extends AttributeConverter<?, R>> converterJavaType, SessionFactoryImplementor sessionFactory) Builders.entity
(String tableAlias, String entityName, SessionFactoryImplementor sessionFactory) Creates a EntityResultBuilder allowing for further configuring of the mapping.Builders.entityCalculated
(String tableAlias, String entityName, SessionFactoryImplementor sessionFactory) Creates a EntityResultBuilder that does not allow any further configuring of the mapping.Builders.entityCalculated
(String tableAlias, String entityName, LockMode explicitLockMode, SessionFactoryImplementor sessionFactory) Creates a EntityResultBuilder that does not allow any further configuring of the mapping.static <J> DynamicResultBuilderInstantiation<J>
Builders.instantiation
(Class<J> targetJavaType, SessionFactoryImplementor factory) ResultSetMappingImpl.resolve
(JdbcValuesMetadata jdbcResultsMetadata, LoadQueryInfluencers loadQueryInfluencers, SessionFactoryImplementor sessionFactory) ResultSetMappingSqlSelection.resolve
(JdbcValuesMetadata jdbcResultsMetadata, SessionFactoryImplementor sessionFactory) static ResultSetMapping
ResultSetMapping.resolveResultSetMapping
(String name, boolean isDynamic, SessionFactoryImplementor sessionFactory) static ResultSetMapping
ResultSetMapping.resolveResultSetMapping
(String name, SessionFactoryImplementor sessionFactory) static ResultBuilder
Builders.resultClassBuilder
(Class<?> resultMappingClass, SessionFactoryImplementor sessionFactory) static DynamicResultBuilderBasic
Builders.scalar
(String columnAlias, Class<?> javaType, SessionFactoryImplementor factory) static DynamicResultBuilderBasic
Builders.scalar
(String columnAlias, String resultAlias, Class<?> javaTypeClass, SessionFactoryImplementor factory) ModifierConstructorDescriptionDomainResultCreationStateImpl
(String stateIdentifier, JdbcValuesMetadata jdbcResultsMetadata, Map<String, Map<String, DynamicFetchBuilderLegacy>> legacyFetchBuilders, Consumer<SqlSelection> sqlSelectionConsumer, LoadQueryInfluencers loadQueryInfluencers, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.query.results.dynamic
ModifierConstructorDescriptionDynamicResultBuilderBasicConverted
(String columnAlias, Class<O> domainJavaType, Class<R> jdbcJavaType, AttributeConverter<O, R> converter, SessionFactoryImplementor sessionFactory) DynamicResultBuilderBasicConverted
(String columnAlias, Class<O> domainJavaType, Class<R> jdbcJavaType, Class<? extends AttributeConverter<O, R>> converterJavaType, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.query.spi
Modifier and TypeMethodDescriptionQueryProducerImplementor.getFactory()
AbstractSelectionQuery.getSessionFactory()
Modifier and TypeMethodDescriptionParameterMetadataImplementor.createBindings
(SessionFactoryImplementor sessionFactory) void
QueryParameterBindingValidator.validate
(BindableType<?> paramType, Object bind, TemporalType temporalPrecision, SessionFactoryImplementor sessionFactory) void
QueryParameterBindingValidator.validate
(BindableType<?> paramType, Object bind, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.query.sql.internal
ModifierConstructorDescriptionNativeSelectQueryPlanImpl
(String sql, Set<String> affectedTableNames, List<ParameterOccurrence> parameterList, ResultSetMapping resultSetMapping, SessionFactoryImplementor sessionFactory) ResultSetMappingProcessor
(ResultSetMapping resultSetMapping, SessionFactoryImplementor factory) SQLQueryParser
(String queryString, SQLQueryParser.ParserContext context, SessionFactoryImplementor factory) -
Uses of SessionFactoryImplementor in org.hibernate.query.sql.spi
Modifier and TypeMethodDescriptionNamedNativeQueryMemento.Builder.build
(SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.query.sqm
Modifier and TypeMethodDescriptiondefault SqmExpressible<J>
SqmExpressible.resolveExpressible
(SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.query.sqm.function
Modifier and TypeMethodDescriptionvoid
SelfRenderingAggregateFunctionSqlAstExpression.renderToSql
(SqlAppender sqlAppender, SqlAstTranslator<?> walker, SessionFactoryImplementor sessionFactory) void
SelfRenderingFunctionSqlAstExpression.renderToSql
(SqlAppender sqlAppender, SqlAstTranslator<?> walker, SessionFactoryImplementor sessionFactory) void
SelfRenderingOrderedSetAggregateFunctionSqlAstExpression.renderToSql
(SqlAppender sqlAppender, SqlAstTranslator<?> walker, SessionFactoryImplementor sessionFactory) void
SelfRenderingWindowFunctionSqlAstExpression.renderToSql
(SqlAppender sqlAppender, SqlAstTranslator<?> walker, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.query.sqm.internal
Modifier and TypeMethodDescriptionstatic boolean
TypecheckUtil.areTypesComparable
(SqmExpressible<?> lhsType, SqmExpressible<?> rhsType, SessionFactoryImplementor factory) static void
TypecheckUtil.assertAssignable
(String hqlString, SqmPath<?> targetPath, SqmTypedNode<?> expression, SessionFactoryImplementor factory) static void
TypecheckUtil.assertComparable
(Expression<?> x, Expression<?> y, SessionFactoryImplementor factory) static Bindable
SqmUtil.determineParameterType
(QueryParameterBinding<?> binding, QueryParameterImplementor<?> parameter, List<SqmParameter<?>> sqmParameters, SqmParameterMappingModelResolutionAccess mappingModelResolutionAccess, SessionFactoryImplementor sessionFactory) static EntityPersister
SqmMappingModelHelper.resolveEntityPersister
(EntityDomainType<?> entityType, SessionFactoryImplementor sessionFactory) Resolve a JPA EntityType descriptor to it's corresponding EntityPersister in the Hibernate mapping type systemModifierConstructorDescriptionSqmCriteriaNodeBuilder
(String uuid, String name, QueryEngine queryEngine, boolean jpaComplianceEnabled, ValueHandlingMode criteriaValueHandlingMode, Supplier<SessionFactoryImplementor> sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.query.sqm.mutation.internal
Modifier and TypeMethodDescriptionstatic Expression
SqmInsertStrategyHelper.createRowNumberingExpression
(QuerySpec querySpec, SessionFactoryImplementor sessionFactory) Creates a row numbering expression, that can be added to the select clause of the query spec.static QuerySpec
MatchingIdSelectionHelper.generateMatchingIdSelectQuery
(EntityMappingType targetEntityDescriptor, SqmDeleteOrUpdateStatement sqmStatement, DomainParameterXref domainParameterXref, Predicate restriction, MultiTableSqmMutationConverter sqmConverter, SessionFactoryImplementor sessionFactory) static SelectStatement
MatchingIdSelectionHelper.generateMatchingIdSelectStatement
(EntityMappingType targetEntityDescriptor, SqmDeleteOrUpdateStatement sqmStatement, boolean queryRoot, Predicate restriction, MultiTableSqmMutationConverter sqmConverter, DomainQueryExecutionContext executionContext, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.query.sqm.mutation.internal.cte
Modifier and TypeMethodDescriptionCteInsertHandler.getSessionFactory()
protected SessionFactoryImplementor
CteInsertStrategy.getSessionFactory()
protected SessionFactoryImplementor
CteMutationStrategy.getSessionFactory()
Modifier and TypeMethodDescriptionprotected abstract void
AbstractCteMutationHandler.addDmlCtes
(CteContainer statement, CteStatement idSelectCte, MultiTableSqmMutationConverter sqmConverter, Map<SqmParameter<?>, List<JdbcParameter>> parameterResolutions, SessionFactoryImplementor factory) protected void
CteDeleteHandler.addDmlCtes
(CteContainer statement, CteStatement idSelectCte, MultiTableSqmMutationConverter sqmConverter, Map<SqmParameter<?>, List<JdbcParameter>> parameterResolutions, SessionFactoryImplementor factory) protected String
CteInsertHandler.addDmlCtes
(CteContainer statement, CteStatement queryCte, List<Map.Entry<List<CteColumn>, Assignment>> assignments, boolean assignsId, MultiTableSqmMutationConverter sqmConverter, Map<SqmParameter<?>, List<List<JdbcParameter>>> parameterResolutions, SessionFactoryImplementor factory) protected void
CteUpdateHandler.addDmlCtes
(CteContainer statement, CteStatement idSelectCte, MultiTableSqmMutationConverter sqmConverter, Map<SqmParameter<?>, List<JdbcParameter>> parameterResolutions, SessionFactoryImplementor factory) protected void
CteDeleteHandler.applyDmlOperations
(CteContainer statement, CteStatement idSelectCte, SessionFactoryImplementor factory, TableGroup updatingTableGroup) protected void
CteSoftDeleteHandler.applyDmlOperations
(CteContainer statement, CteStatement idSelectCte, SessionFactoryImplementor factory, TableGroup updatingTableGroup) protected Expression
AbstractCteMutationHandler.createCountStar
(SessionFactoryImplementor factory, MultiTableSqmMutationConverter sqmConverter) Used by Hibernate Reactiveprotected Expression
CteInsertHandler.createCountStar
(SessionFactoryImplementor factory, MultiTableSqmMutationConverter sqmConverter) static CteTable
CteInsertHandler.createCteTable
(CteTable sqmCteTable, List<CteColumn> sqmCteColumns, SessionFactoryImplementor factory) protected QuerySpec
AbstractCteMutationHandler.createIdSubQuery
(CteStatement idSelectCte, ModelPart fkModelPart, SessionFactoryImplementor factory) protected Predicate
AbstractCteMutationHandler.createIdSubQueryPredicate
(List<? extends Expression> lhsExpressions, CteStatement idSelectCte, SessionFactoryImplementor factory) protected Predicate
AbstractCteMutationHandler.createIdSubQueryPredicate
(List<? extends Expression> lhsExpressions, CteStatement idSelectCte, ModelPart fkModelPart, SessionFactoryImplementor factory) ModifierConstructorDescriptionAbstractCteMutationHandler
(CteTable cteTable, SqmDeleteOrUpdateStatement<?> sqmStatement, DomainParameterXref domainParameterXref, CteMutationStrategy strategy, SessionFactoryImplementor sessionFactory) protected
CteDeleteHandler
(CteTable cteTable, SqmDeleteStatement<?> sqmDeleteStatement, DomainParameterXref domainParameterXref, CteMutationStrategy strategy, SessionFactoryImplementor sessionFactory) CteInsertHandler
(CteTable cteTable, SqmInsertStatement<?> sqmStatement, DomainParameterXref domainParameterXref, SessionFactoryImplementor sessionFactory) protected
CteSoftDeleteHandler
(CteTable cteTable, SqmDeleteStatement<?> sqmDeleteStatement, DomainParameterXref domainParameterXref, CteMutationStrategy strategy, SessionFactoryImplementor sessionFactory) CteUpdateHandler
(CteTable cteTable, SqmUpdateStatement<?> sqmStatement, DomainParameterXref domainParameterXref, CteMutationStrategy strategy, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.query.sqm.mutation.internal.temptable
Modifier and TypeMethodDescriptionAbstractDeleteExecutionDelegate.getSessionFactory()
GlobalTemporaryTableStrategy.getSessionFactory()
LocalTemporaryTableStrategy.getSessionFactory()
PersistentTableStrategy.getSessionFactory()
protected SessionFactoryImplementor
UpdateExecutionDelegate.getSessionFactory()
Modifier and TypeMethodDescriptionstatic QuerySpec
ExecuteWithoutIdTableHelper.createIdMatchingSubQuerySpec
(NavigablePath navigablePath, TableReference rootTableReference, Predicate predicate, EntityPersister rootEntityPersister, SqlExpressionResolver sqlExpressionResolver, SessionFactoryImplementor sessionFactory) void
GlobalTemporaryTableStrategy.release
(SessionFactoryImplementor sessionFactory, JdbcConnectionAccess connectionAccess) void
LocalTemporaryTableStrategy.release
(SessionFactoryImplementor sessionFactory, JdbcConnectionAccess connectionAccess) void
PersistentTableStrategy.release
(SessionFactoryImplementor sessionFactory, JdbcConnectionAccess connectionAccess) ModifierConstructorDescriptionAbstractDeleteExecutionDelegate
(EntityMappingType entityDescriptor, TemporaryTable idTable, AfterUseAction afterUseAction, SqmDeleteStatement<?> sqmDelete, DomainParameterXref domainParameterXref, QueryOptions queryOptions, LoadQueryInfluencers loadQueryInfluencers, QueryParameterBindings queryParameterBindings, Function<SharedSessionContractImplementor, String> sessionUidAccess, SessionFactoryImplementor sessionFactory) GlobalTemporaryTableInsertStrategy
(TemporaryTable entityTable, SessionFactoryImplementor sessionFactory) GlobalTemporaryTableMutationStrategy
(TemporaryTable idTable, SessionFactoryImplementor sessionFactory) GlobalTemporaryTableStrategy
(TemporaryTable temporaryTable, SessionFactoryImplementor sessionFactory) LocalTemporaryTableInsertStrategy
(TemporaryTable entityTable, SessionFactoryImplementor sessionFactory) LocalTemporaryTableMutationStrategy
(TemporaryTable idTable, SessionFactoryImplementor sessionFactory) LocalTemporaryTableStrategy
(TemporaryTable temporaryTable, SessionFactoryImplementor sessionFactory) PersistentTableInsertStrategy
(TemporaryTable entityTable, SessionFactoryImplementor sessionFactory) PersistentTableMutationStrategy
(TemporaryTable idTable, SessionFactoryImplementor sessionFactory) PersistentTableStrategy
(TemporaryTable temporaryTable, SessionFactoryImplementor sessionFactory) RestrictedDeleteExecutionDelegate
(EntityMappingType entityDescriptor, TemporaryTable idTable, AfterUseAction afterUseAction, SqmDeleteStatement<?> sqmDelete, DomainParameterXref domainParameterXref, QueryOptions queryOptions, LoadQueryInfluencers loadQueryInfluencers, QueryParameterBindings queryParameterBindings, Function<SharedSessionContractImplementor, String> sessionUidAccess, SessionFactoryImplementor sessionFactory) SoftDeleteExecutionDelegate
(EntityMappingType entityDescriptor, TemporaryTable idTable, AfterUseAction afterUseAction, SqmDeleteStatement<?> sqmDelete, DomainParameterXref domainParameterXref, QueryOptions queryOptions, LoadQueryInfluencers loadQueryInfluencers, QueryParameterBindings queryParameterBindings, Function<SharedSessionContractImplementor, String> sessionUidAccess, SessionFactoryImplementor sessionFactory) TableBasedDeleteHandler
(SqmDeleteStatement<?> sqmDeleteStatement, DomainParameterXref domainParameterXref, TemporaryTable idTable, AfterUseAction afterUseAction, Function<SharedSessionContractImplementor, String> sessionUidAccess, SessionFactoryImplementor sessionFactory) TableBasedInsertHandler
(SqmInsertStatement<?> sqmInsert, DomainParameterXref domainParameterXref, TemporaryTable entityTable, AfterUseAction afterUseAction, Function<SharedSessionContractImplementor, String> sessionUidAccess, SessionFactoryImplementor sessionFactory) TableBasedUpdateHandler
(SqmUpdateStatement<?> sqmUpdate, DomainParameterXref domainParameterXref, TemporaryTable idTable, AfterUseAction afterUseAction, Function<SharedSessionContractImplementor, String> sessionUidAccess, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.query.sqm.mutation.spi
Modifier and TypeMethodDescriptiondefault void
SqmMultiTableInsertStrategy.release
(SessionFactoryImplementor sessionFactory, JdbcConnectionAccess connectionAccess) Release the strategy.default void
SqmMultiTableMutationStrategy.release
(SessionFactoryImplementor sessionFactory, JdbcConnectionAccess connectionAccess) Release the strategy.ModifierConstructorDescriptionAbstractMutationHandler
(SqmDeleteOrUpdateStatement<?> sqmDeleteOrUpdateStatement, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.query.sqm.sql
Modifier and TypeMethodDescriptionboolean
BaseSqmToSqlAstConverter.AdditionalInsertValues.applySelections
(QuerySpec querySpec, SessionFactoryImplementor sessionFactory) Returns true if the identifier can't be applied directly and needs to be generated separately. -
Uses of SessionFactoryImplementor in org.hibernate.query.sqm.tree.expression
Modifier and TypeMethodDescriptionstatic <T> SqmExpressible<T>
SqmExpressionHelper.toSqmType
(BindableType<T> anticipatedType, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.relational.internal
ModifierConstructorDescriptionSchemaManagerImpl
(SessionFactoryImplementor sessionFactory, MetadataImplementor metadata) -
Uses of SessionFactoryImplementor in org.hibernate.resource.jdbc.spi
Modifier and TypeMethodDescriptionJdbcSessionContext.getSessionFactory()
Deprecated.exposing this here seems to kinda defeat the purpose of this SPI -
Uses of SessionFactoryImplementor in org.hibernate.service.internal
Modifier and TypeMethodDescriptionSessionFactoryServiceRegistryFactoryImpl.buildServiceRegistry
(SessionFactoryImplementor sessionFactory, SessionFactoryOptions options) SessionFactoryServiceRegistryBuilderImpl.buildSessionFactoryServiceRegistry
(SessionFactoryImplementor sessionFactory, SessionFactoryOptions options) SessionFactoryServiceRegistryImpl.create
(ServiceRegistryImplementor parent, List<SessionFactoryServiceInitiator<?>> initiators, List<ProvidedService<?>> providedServices, SessionFactoryImplementor sessionFactory, SessionFactoryOptions sessionFactoryOptions) -
Uses of SessionFactoryImplementor in org.hibernate.service.spi
Modifier and TypeMethodDescriptionSessionFactoryServiceRegistryFactory.buildServiceRegistry
(SessionFactoryImplementor sessionFactory, SessionFactoryOptions sessionFactoryOptions) Create the registry. -
Uses of SessionFactoryImplementor in org.hibernate.spatial.dialect.hana
Modifier and TypeMethodDescriptionHANASpatialFunction.render
(Type firstArgumentType, List arguments, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.sql
ModifierConstructorDescriptionDelete
(SessionFactoryImplementor factory) Insert
(SessionFactoryImplementor sessionFactory) SimpleSelect
(SessionFactoryImplementor factory) Update
(SessionFactoryImplementor factory) -
Uses of SessionFactoryImplementor in org.hibernate.sql.ast
Modifier and TypeMethodDescriptiondefault SqlAstTranslator<JdbcOperationQueryDelete>
SqlAstTranslatorFactory.buildDeleteTranslator
(SessionFactoryImplementor sessionFactory, DeleteStatement statement) Deprecated, for removal: This API element is subject to removal in a future version.default SqlAstTranslator<JdbcOperationQueryInsert>
SqlAstTranslatorFactory.buildInsertTranslator
(SessionFactoryImplementor sessionFactory, InsertStatement statement) Deprecated, for removal: This API element is subject to removal in a future version.<O extends JdbcMutationOperation>
SqlAstTranslator<O>SqlAstTranslatorFactory.buildModelMutationTranslator
(TableMutation<O> mutation, SessionFactoryImplementor sessionFactory) Builds a single-use translator for dealing with model mutationsSqlAstTranslator<? extends JdbcOperationQueryMutation>
SqlAstTranslatorFactory.buildMutationTranslator
(SessionFactoryImplementor sessionFactory, MutationStatement statement) Builds a single-use mutation translatorSqlAstTranslatorFactory.buildSelectTranslator
(SessionFactoryImplementor sessionFactory, SelectStatement statement) Builds a single-use select translatordefault SqlAstTranslator<JdbcOperationQueryUpdate>
SqlAstTranslatorFactory.buildUpdateTranslator
(SessionFactoryImplementor sessionFactory, UpdateStatement statement) Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of SessionFactoryImplementor in org.hibernate.sql.ast.spi
Modifier and TypeMethodDescriptionAbstractSqlAstTranslator.getSessionFactory()
SqlAstCreationContext.getSessionFactory()
The SessionFactoryModifier and TypeMethodDescriptionStandardSqlAstTranslatorFactory.buildDeleteTranslator
(SessionFactoryImplementor sessionFactory, DeleteStatement statement) StandardSqlAstTranslatorFactory.buildInsertTranslator
(SessionFactoryImplementor sessionFactory, InsertStatement statement) <O extends JdbcMutationOperation>
SqlAstTranslator<O>StandardSqlAstTranslatorFactory.buildModelMutationTranslator
(TableMutation<O> mutation, SessionFactoryImplementor sessionFactory) SqlAstTranslator<? extends JdbcOperationQueryMutation>
StandardSqlAstTranslatorFactory.buildMutationTranslator
(SessionFactoryImplementor sessionFactory, MutationStatement statement) StandardSqlAstTranslatorFactory.buildSelectTranslator
(SessionFactoryImplementor sessionFactory, SelectStatement statement) protected <T extends JdbcOperation>
SqlAstTranslator<T>StandardSqlAstTranslatorFactory.buildTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) Consolidated building of a translator for all Query casesStandardSqlAstTranslatorFactory.buildUpdateTranslator
(SessionFactoryImplementor sessionFactory, UpdateStatement statement) static String
AbstractSqlAstTranslator.getCastTypeName
(SqlTypedMapping castTarget, SessionFactoryImplementor factory) Deprecated, for removal: This API element is subject to removal in a future version.static String
AbstractSqlAstTranslator.getSqlTypeName
(SqlTypedMapping castTarget, SessionFactoryImplementor factory) Deprecated, for removal: This API element is subject to removal in a future version.SqlSelection.resolve
(JdbcValuesMetadata jdbcResultsMetadata, SessionFactoryImplementor sessionFactory) ModifierConstructorDescriptionprotected
AbstractSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) StandardSqlAstTranslator
(SessionFactoryImplementor sessionFactory, Statement statement) -
Uses of SessionFactoryImplementor in org.hibernate.sql.ast.tree.cte
Modifier and TypeMethodDescriptionvoid
SelfRenderingCteObject.render
(SqlAppender sqlAppender, SqlAstTranslator<?> walker, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.sql.ast.tree.expression
Modifier and TypeMethodDescriptionvoid
AliasedExpression.renderToSql
(SqlAppender sqlAppender, SqlAstTranslator<?> walker, SessionFactoryImplementor sessionFactory) void
LiteralAsParameter.renderToSql
(SqlAppender sqlAppender, SqlAstTranslator<?> walker, SessionFactoryImplementor sessionFactory) void
SelfRenderingExpression.renderToSql
(SqlAppender sqlAppender, SqlAstTranslator<?> walker, SessionFactoryImplementor sessionFactory) void
SelfRenderingSqlFragmentExpression.renderToSql
(SqlAppender sqlAppender, SqlAstTranslator<?> walker, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.sql.ast.tree.from
Modifier and TypeMethodDescriptionprotected abstract SessionFactoryImplementor
AbstractColumnReferenceQualifier.getSessionFactory()
protected SessionFactoryImplementor
AbstractTableGroup.getSessionFactory()
protected SessionFactoryImplementor
OneToManyTableGroup.getSessionFactory()
ModifierConstructorDescriptionAbstractTableGroup
(boolean canUseInnerJoins, NavigablePath navigablePath, ModelPartContainer modelPartContainer, String sourceAlias, SqlAliasBase sqlAliasBase, SessionFactoryImplementor sessionFactory) CollectionTableGroup
(boolean canUseInnerJoins, NavigablePath navigablePath, PluralAttributeMapping tableGroupProducer, boolean fetched, String sourceAlias, TableReference primaryTableReference, boolean realTableGroup, SqlAliasBase sqlAliasBase, Predicate<String> tableReferenceJoinNameChecker, BiFunction<String, TableGroup, TableReferenceJoin> tableReferenceJoinCreator, SessionFactoryImplementor sessionFactory) CorrelatedPluralTableGroup
(TableGroup correlatedTableGroup, SqlAliasBase sqlAliasBase, QuerySpec querySpec, Consumer<Predicate> joinPredicateConsumer, SessionFactoryImplementor sessionFactory) CorrelatedTableGroup
(TableGroup correlatedTableGroup, SqlAliasBase sqlAliasBase, QuerySpec querySpec, Consumer<Predicate> joinPredicateConsumer, SessionFactoryImplementor sessionFactory) DerivedTableReference
(String identificationVariable, List<String> columnNames, boolean lateral, SessionFactoryImplementor sessionFactory) FunctionTableGroup
(NavigablePath navigablePath, TableGroupProducer tableGroupProducer, FunctionExpression functionExpression, String sourceAlias, List<String> columnNames, boolean lateral, boolean canUseInnerJoins, SessionFactoryImplementor sessionFactory) FunctionTableReference
(FunctionExpression functionExpression, String identificationVariable, List<String> columnNames, boolean lateral, SessionFactoryImplementor sessionFactory) LazyTableGroup
(boolean canUseInnerJoins, NavigablePath navigablePath, boolean fetched, Supplier<TableGroup> tableGroupSupplier, LazyTableGroup.ParentTableGroupUseChecker parentTableGroupUseChecker, TableGroupProducer tableGroupProducer, String sourceAlias, SqlAliasBase sqlAliasBase, SessionFactoryImplementor sessionFactory, TableGroup parentTableGroup) OneToManyTableGroup
(PluralAttributeMapping pluralAttributeMapping, TableGroup elementTableGroup, SessionFactoryImplementor sessionFactory) QueryPartTableGroup
(NavigablePath navigablePath, TableGroupProducer tableGroupProducer, SelectStatement selectStatement, String sourceAlias, List<String> columnNames, boolean lateral, boolean canUseInnerJoins, SessionFactoryImplementor sessionFactory) QueryPartTableGroup
(NavigablePath navigablePath, TableGroupProducer tableGroupProducer, SelectStatement selectStatement, String sourceAlias, List<String> columnNames, Set<String> compatibleTableExpressions, boolean lateral, boolean canUseInnerJoins, SessionFactoryImplementor sessionFactory) QueryPartTableReference
(SelectStatement selectStatement, String identificationVariable, List<String> columnNames, boolean lateral, SessionFactoryImplementor sessionFactory) StandardTableGroup
(boolean canUseInnerJoins, NavigablePath navigablePath, TableGroupProducer tableGroupProducer, boolean fetched, String sourceAlias, TableReference primaryTableReference, boolean realTableGroup, SqlAliasBase sqlAliasBase, Predicate<String> tableReferenceJoinNameChecker, BiFunction<String, TableGroup, TableReferenceJoin> tableReferenceJoinCreator, SessionFactoryImplementor sessionFactory) StandardTableGroup
(boolean canUseInnerJoins, NavigablePath navigablePath, TableGroupProducer tableGroupProducer, String sourceAlias, TableReference primaryTableReference, boolean realTableGroup, SqlAliasBase sqlAliasBase, Predicate<String> tableReferenceJoinNameChecker, BiFunction<String, TableGroup, TableReferenceJoin> tableReferenceJoinCreator, SessionFactoryImplementor sessionFactory) StandardTableGroup
(boolean canUseInnerJoins, NavigablePath navigablePath, TableGroupProducer tableGroupProducer, String sourceAlias, TableReference primaryTableReference, SqlAliasBase sqlAliasBase, SessionFactoryImplementor sessionFactory) ValuesTableGroup
(NavigablePath navigablePath, TableGroupProducer tableGroupProducer, List<Values> valuesList, String sourceAlias, List<String> columnNames, boolean canUseInnerJoins, SessionFactoryImplementor sessionFactory) ValuesTableReference
(List<Values> valuesList, String identificationVariable, List<String> columnNames, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.sql.exec.internal
ModifierConstructorDescriptionJdbcParameterBindingsImpl
(QueryParameterBindings queryParameterBindings, List<ParameterOccurrence> parameterOccurrences, List<JdbcParameterBinder> jdbcParameterBinders, SessionFactoryImplementor factory) -
Uses of SessionFactoryImplementor in org.hibernate.sql.model.ast
Modifier and TypeMethodDescriptionAbstractTableMutation.createMutationOperation
(ValuesAnalysis valuesAnalysis, SessionFactoryImplementor factory) TableMutation.createMutationOperation
(ValuesAnalysis valuesAnalysis, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.sql.model.ast.builder
Modifier and TypeMethodDescriptionprotected SessionFactoryImplementor
AbstractTableMutationBuilder.getSessionFactory()
ModifierConstructorDescriptionAbstractRestrictedTableMutationBuilder
(MutationType mutationType, MutationTarget<?> mutationTarget, MutatingTableReference tableReference, SessionFactoryImplementor sessionFactory) AbstractRestrictedTableMutationBuilder
(MutationType mutationType, MutationTarget<?> mutationTarget, TableMapping table, SessionFactoryImplementor sessionFactory) AbstractTableInsertBuilder
(MutationTarget<?> mutationTarget, MutatingTableReference tableReference, SessionFactoryImplementor sessionFactory) AbstractTableInsertBuilder
(MutationTarget<?> mutationTarget, TableMapping table, SessionFactoryImplementor sessionFactory) AbstractTableMutationBuilder
(MutationType mutationType, MutationTarget<?> mutationTarget, MutatingTableReference mutatingTable, SessionFactoryImplementor sessionFactory) AbstractTableMutationBuilder
(MutationType mutationType, MutationTarget<?> mutationTarget, TableMapping table, SessionFactoryImplementor sessionFactory) AbstractTableUpdateBuilder
(MutationTarget<?> mutationTarget, MutatingTableReference tableReference, SessionFactoryImplementor sessionFactory) AbstractTableUpdateBuilder
(MutationTarget<?> mutationTarget, TableMapping tableMapping, SessionFactoryImplementor sessionFactory) CollectionRowDeleteBuilder
(MutationTarget<?> mutationTarget, MutatingTableReference tableReference, SessionFactoryImplementor sessionFactory, String whereFragment) CollectionRowDeleteByUpdateSetNullBuilder
(MutationTarget<?> mutationTarget, MutatingTableReference tableReference, SessionFactoryImplementor sessionFactory, String whereFragment) TableDeleteBuilderStandard
(MutationTarget<?> mutationTarget, MutatingTableReference tableReference, SessionFactoryImplementor sessionFactory) TableDeleteBuilderStandard
(MutationTarget<?> mutationTarget, MutatingTableReference tableReference, SessionFactoryImplementor sessionFactory, String whereFragment) TableDeleteBuilderStandard
(MutationTarget<?> mutationTarget, TableMapping table, SessionFactoryImplementor sessionFactory) TableInsertBuilderStandard
(MutationTarget<?> mutationTarget, MutatingTableReference tableReference, SessionFactoryImplementor sessionFactory) TableInsertBuilderStandard
(MutationTarget<?> mutationTarget, TableMapping table, SessionFactoryImplementor sessionFactory) TableMergeBuilder
(MutationTarget<?> mutationTarget, MutatingTableReference tableReference, SessionFactoryImplementor sessionFactory) TableMergeBuilder
(MutationTarget<?> mutationTarget, TableMapping tableMapping, SessionFactoryImplementor sessionFactory) TableUpdateBuilderStandard
(MutationTarget<?> mutationTarget, MutatingTableReference tableReference, SessionFactoryImplementor sessionFactory) TableUpdateBuilderStandard
(MutationTarget<?> mutationTarget, MutatingTableReference tableReference, SessionFactoryImplementor sessionFactory, String whereFragment) TableUpdateBuilderStandard
(MutationTarget<?> mutationTarget, TableMapping tableMapping, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.sql.model.internal
Modifier and TypeMethodDescriptionOptionalTableUpdate.createMutationOperation
(ValuesAnalysis valuesAnalysis, SessionFactoryImplementor factory) -
Uses of SessionFactoryImplementor in org.hibernate.sql.model.jdbc
ModifierConstructorDescriptionOptionalTableUpdateOperation
(MutationTarget<?> mutationTarget, OptionalTableUpdate upsert, SessionFactoryImplementor factory) -
Uses of SessionFactoryImplementor in org.hibernate.sql.results.internal
Modifier and TypeMethodDescriptionstatic <R> RowReader<R>
ResultsHelper.createRowReader
(SessionFactoryImplementor sessionFactory, RowTransformer<R> rowTransformer, Class<R> transformedResultJavaType, JdbcValues jdbcValues) static <R> RowReader<R>
ResultsHelper.createRowReader
(SessionFactoryImplementor sessionFactory, RowTransformer<R> rowTransformer, Class<R> transformedResultJavaType, JdbcValuesMapping jdbcValuesMapping) ResolvedSqlSelection.resolve
(JdbcValuesMetadata jdbcResultsMetadata, SessionFactoryImplementor sessionFactory) SqlSelectionImpl.resolve
(JdbcValuesMetadata jdbcResultsMetadata, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.sql.results.jdbc.internal
Modifier and TypeMethodDescriptionDeferredResultSetAccess.getFactory()
DirectResultSetAccess.getFactory()
ResultSetAccess.getFactory()
Modifier and TypeMethodDescriptionvoid
JdbcValuesMappingProducerStandard.addAffectedTableNames
(Set<String> affectedTableNames, SessionFactoryImplementor sessionFactory) JdbcValuesMappingProducerProviderStandard.buildMappingProducer
(SelectStatement sqlAst, SessionFactoryImplementor sessionFactory) JdbcValuesMappingProducerProviderStandard.buildResultSetMapping
(String name, boolean isDynamic, SessionFactoryImplementor sessionFactory) JdbcValuesMappingProducerStandard.resolve
(JdbcValuesMetadata jdbcResultsMetadata, LoadQueryInfluencers loadQueryInfluencers, SessionFactoryImplementor sessionFactory) StandardJdbcValuesMapping.resolveAssemblers
(SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.sql.results.jdbc.spi
Modifier and TypeMethodDescriptionvoid
JdbcValuesMappingProducer.addAffectedTableNames
(Set<String> affectedTableNames, SessionFactoryImplementor sessionFactory) JdbcValuesMappingProducerProvider.buildMappingProducer
(SelectStatement sqlAst, SessionFactoryImplementor sessionFactory) Provide the JdbcValuesMappingProducer to use for the given SQL ASTJdbcValuesMappingProducerProvider.buildResultSetMapping
(String name, boolean isDynamic, SessionFactoryImplementor sessionFactory) Provide a dynamically built JdbcValuesMappingProducerJdbcValuesMappingProducer.resolve
(JdbcValuesMetadata jdbcResultsMetadata, LoadQueryInfluencers loadQueryInfluencers, SessionFactoryImplementor sessionFactory) Resolve the JdbcValuesMapping.JdbcValuesMapping.resolveAssemblers
(SessionFactoryImplementor sessionFactory) default <J> BasicType<J>
JdbcValuesMetadata.resolveType
(int position, JavaType<J> explicitJavaType, SessionFactoryImplementor sessionFactory) Determine the mapping to use for a particular position in the result -
Uses of SessionFactoryImplementor in org.hibernate.stat.internal
-
Uses of SessionFactoryImplementor in org.hibernate.stat.spi
Modifier and TypeMethodDescriptionStatisticsFactory.buildStatistics
(SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.testing.cache
Modifier and TypeMethodDescriptionprotected StorageAccess
CachingRegionFactory.createQueryResultsRegionStorageAccess
(String regionName, SessionFactoryImplementor sessionFactory) protected StorageAccess
CachingRegionFactory.createTimestampsRegionStorageAccess
(String regionName, SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.testing.jdbc
Modifier and TypeMethodDescriptionvoid
SharedDriverManagerTypeCacheClearingIntegrator.disintegrate
(SessionFactoryImplementor sessionFactory, SessionFactoryServiceRegistry serviceRegistry) void
SharedDriverManagerTypeCacheClearingIntegrator.integrate
(Metadata metadata, SessionFactoryImplementor sessionFactory, SessionFactoryServiceRegistry serviceRegistry) -
Uses of SessionFactoryImplementor in org.hibernate.testing.junit4
Modifier and TypeMethodDescriptionprotected SessionFactoryImplementor
BaseCoreFunctionalTestCase.sessionFactory()
protected SessionFactoryImplementor
BaseNonConfigCoreFunctionalTestCase.sessionFactory()
Modifier and TypeMethodDescriptionprotected void
BaseNonConfigCoreFunctionalTestCase.afterSessionFactoryBuilt
(SessionFactoryImplementor sessionFactory) -
Uses of SessionFactoryImplementor in org.hibernate.testing.orm.junit
Modifier and TypeMethodDescriptionSessionFactoryScope.getSessionFactory()
BaseSessionFactoryFunctionalTest.produceSessionFactory
(MetadataImplementor model) SessionFactoryProducer.produceSessionFactory
(MetadataImplementor model) protected SessionFactoryImplementor
BaseSessionFactoryFunctionalTest.sessionFactory()
Modifier and TypeMethodDescriptionprotected void
BaseSessionFactoryFunctionalTest.sessionFactoryBuilt
(SessionFactoryImplementor factory) Modifier and TypeMethodDescriptiondefault void
SessionFactoryScope.withSessionFactory
(Consumer<SessionFactoryImplementor> action) -
Uses of SessionFactoryImplementor in org.hibernate.testing.transaction
Modifier and TypeMethodDescriptionstatic <R> R
TransactionUtil2.fromSession
(SessionFactoryImplementor sfi, Function<SessionImplementor, R> action) static <R> R
TransactionUtil2.fromTransaction
(SessionFactoryImplementor factory, Function<SessionImplementor, R> action) static void
TransactionUtil2.inSession
(SessionFactoryImplementor sfi, Consumer<SessionImplementor> action) static <R> R
TransactionUtil2.inSessionReturn
(SessionFactoryImplementor sfi, Function<SessionImplementor, R> action) static void
TransactionUtil2.inStatelessSession
(SessionFactoryImplementor sfi, Consumer<StatelessSession> action) static void
TransactionUtil2.inStatelessTransaction
(SessionFactoryImplementor factory, Consumer<StatelessSession> action) static void
TransactionUtil2.inTransaction
(SessionFactoryImplementor factory, Consumer<SessionImplementor> action) -
Uses of SessionFactoryImplementor in org.hibernate.tuple
Modifier and TypeMethodDescriptionprotected SessionFactoryImplementor
AbstractNonIdentifierAttribute.sessionFactory()
Deprecated, for removal: This API element is subject to removal in a future version.Modifier and TypeMethodDescriptionstatic NonIdentifierAttribute
PropertyFactory.buildEntityBasedAttribute
(EntityPersister persister, SessionFactoryImplementor sessionFactory, int attributeNumber, Property property, boolean lazyAvailable, RuntimeModelCreationContext creationContext) Deprecated, for removal: This API element is subject to removal in a future version.Generate a non-identifier (and non-version) attribute based on the given mapped property from the given entitystatic VersionProperty
PropertyFactory.buildVersionProperty
(EntityPersister persister, SessionFactoryImplementor sessionFactory, int attributeNumber, Property property, boolean lazyAvailable) Deprecated, for removal: This API element is subject to removal in a future version.Generates a VersionProperty representation for an entity mapping given its version mapping Property.ModifierConstructorDescriptionprotected
AbstractNonIdentifierAttribute
(AttributeSource source, SessionFactoryImplementor sessionFactory, int attributeNumber, String attributeName, Type attributeType, BaselineAttributeInformation attributeInformation) Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of SessionFactoryImplementor in org.hibernate.tuple.component
ModifierConstructorDescriptionprotected
AbstractCompositionAttribute
(AttributeSource source, SessionFactoryImplementor sessionFactory, int entityBasedAttributeNumber, String attributeName, CompositeType attributeType, int columnStartPosition, BaselineAttributeInformation baselineInfo) Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of SessionFactoryImplementor in org.hibernate.tuple.entity
Modifier and TypeMethodDescriptionEntityMetamodel.getSessionFactory()
Deprecated, for removal: This API element is subject to removal in a future version.ModifierConstructorDescriptionprotected
AbstractEntityBasedAttribute
(EntityPersister source, SessionFactoryImplementor sessionFactory, int attributeNumber, String attributeName, Type attributeType, BaselineAttributeInformation attributeInformation) Deprecated, for removal: This API element is subject to removal in a future version.EntityBasedAssociationAttribute
(EntityPersister source, SessionFactoryImplementor sessionFactory, int attributeNumber, String attributeName, AssociationType attributeType, BaselineAttributeInformation baselineInfo) Deprecated, for removal: This API element is subject to removal in a future version.EntityBasedBasicAttribute
(EntityPersister source, SessionFactoryImplementor factory, int attributeNumber, String attributeName, Type attributeType, BaselineAttributeInformation baselineInfo) Deprecated, for removal: This API element is subject to removal in a future version.EntityBasedCompositionAttribute
(EntityPersister source, SessionFactoryImplementor factory, int attributeNumber, String attributeName, CompositeType attributeType, BaselineAttributeInformation baselineInfo) Deprecated, for removal: This API element is subject to removal in a future version.VersionProperty
(EntityPersister source, SessionFactoryImplementor sessionFactory, int attributeNumber, String attributeName, Type attributeType, BaselineAttributeInformation attributeInformation) Deprecated, for removal: This API element is subject to removal in a future version.Constructs VersionProperty instances. -
Uses of SessionFactoryImplementor in org.hibernate.type
Modifier and TypeMethodDescriptionint
AnyType.compare
(Object x, Object y, SessionFactoryImplementor factory) default int
BasicType.compare
(Object x, Object y, SessionFactoryImplementor sessionFactory) int
CollectionType.compare
(Object x, Object y, SessionFactoryImplementor sessionFactory) int
ComponentType.compare
(Object x, Object y, SessionFactoryImplementor sessionFactory) int
EntityType.compare
(Object x, Object y, SessionFactoryImplementor factory) int
MetaType.compare
(Object x, Object y, SessionFactoryImplementor sessionFactory) Deprecated, for removal: This API element is subject to removal in a future version.int
Type.compare
(@Nullable Object x, @Nullable Object y, SessionFactoryImplementor sessionFactory) final Object
AbstractStandardBasicType.deepCopy
(Object value, SessionFactoryImplementor factory) AnyType.deepCopy
(Object value, SessionFactoryImplementor factory) CollectionType.deepCopy
(Object value, SessionFactoryImplementor factory) ComponentType.deepCopy
(Object component, SessionFactoryImplementor factory) CustomType.deepCopy
(Object value, SessionFactoryImplementor factory) EntityType.deepCopy
(Object value, SessionFactoryImplementor factory) MetaType.deepCopy
(Object value, SessionFactoryImplementor factory) Deprecated, for removal: This API element is subject to removal in a future version.final Object
SerializableToBlobType.deepCopy
(Object value, SessionFactoryImplementor factory) @Nullable Object
Type.deepCopy
(@Nullable Object value, SessionFactoryImplementor factory) Return a deep copy of the persistent state, stopping at entities and at collections.UserComponentType.deepCopy
(Object component, SessionFactoryImplementor factory) AbstractType.disassemble
(Object value, SessionFactoryImplementor sessionFactory) AnyType.disassemble
(Object value, SessionFactoryImplementor sessionFactory) CollectionType.disassemble
(Object value, SessionFactoryImplementor sessionFactory) ComponentType.disassemble
(Object value, SessionFactoryImplementor sessionFactory) CustomType.disassemble
(Object value, SessionFactoryImplementor sessionFactory) ManyToOneType.disassemble
(Object value, SessionFactoryImplementor sessionFactory) OneToOneType.disassemble
(Object value, SessionFactoryImplementor sessionFactory) SpecialOneToOneType.disassemble
(Object value, SessionFactoryImplementor sessionFactory) default @Nullable Serializable
Type.disassemble
(@Nullable Object value, SessionFactoryImplementor sessionFactory) Return a disassembled representation of the object.UserComponentType.disassemble
(Object value, SessionFactoryImplementor sessionFactory) AnyType.getAssociatedEntityName
(SessionFactoryImplementor factory) AssociationType.getAssociatedEntityName
(SessionFactoryImplementor factory) Get the entity name of the associated entityCollectionType.getAssociatedEntityName
(SessionFactoryImplementor factory) EntityType.getAssociatedEntityName
(SessionFactoryImplementor factory) The name of the associated entity.EntityType.getAssociatedEntityPersister
(SessionFactoryImplementor factory) AnyType.getAssociatedJoinable
(SessionFactoryImplementor factory) AssociationType.getAssociatedJoinable
(SessionFactoryImplementor factory) Get the "persister" for this association - a class or collection persisterCollectionType.getAssociatedJoinable
(SessionFactoryImplementor factory) EntityType.getAssociatedJoinable
(SessionFactoryImplementor factory) Retrieves theJoinable
defining the associated entity.final Type
CollectionType.getElementType
(SessionFactoryImplementor factory) Get the Hibernate type of the collection elementsfinal int
AbstractStandardBasicType.getHashCode
(Object x, SessionFactoryImplementor factory) int
AbstractType.getHashCode
(Object x, SessionFactoryImplementor factory) int
ComponentType.getHashCode
(Object x, SessionFactoryImplementor factory) int
EntityType.getHashCode
(Object x, SessionFactoryImplementor factory) final int
SerializableToBlobType.getHashCode
(Object x, SessionFactoryImplementor factory) int
Type.getHashCode
(Object x, SessionFactoryImplementor factory) Get a hash code, consistent with persistence "equality".int
UserComponentType.getHashCode
(Object x, SessionFactoryImplementor factory) protected final Object
EntityType.getIdentifier
(Object value, SessionFactoryImplementor sessionFactory) final boolean
AbstractStandardBasicType.isEqual
(Object x, Object y, SessionFactoryImplementor factory) boolean
AbstractType.isEqual
(Object x, Object y, SessionFactoryImplementor factory) boolean
ComponentType.isEqual
(Object x, Object y, SessionFactoryImplementor factory) boolean
EntityType.isEqual
(Object x, Object y, SessionFactoryImplementor factory) final boolean
SerializableToBlobType.isEqual
(Object x, Object y, SessionFactoryImplementor factory) boolean
Type.isEqual
(@Nullable Object x, @Nullable Object y, SessionFactoryImplementor factory) Compare two instances of the class mapped by this type for persistence "equality", that is, equality of persistent state.boolean
UserComponentType.isEqual
(Object x, Object y, SessionFactoryImplementor factory) boolean
CollectionType.isInverse
(SessionFactoryImplementor factory) protected String
CollectionType.renderLoggableString
(Object value, SessionFactoryImplementor factory) protected String
CustomCollectionType.renderLoggableString
(Object value, SessionFactoryImplementor factory) BasicTypeReference.resolveExpressible
(SessionFactoryImplementor sessionFactory) ComponentType.resolveExpressible
(SessionFactoryImplementor sessionFactory) final String
AbstractStandardBasicType.toLoggableString
(Object value, SessionFactoryImplementor factory) AnyType.toLoggableString
(Object value, SessionFactoryImplementor factory) ArrayType.toLoggableString
(Object value, SessionFactoryImplementor factory) CollectionType.toLoggableString
(Object value, SessionFactoryImplementor factory) ComponentType.toLoggableString
(Object value, SessionFactoryImplementor factory) CustomType.toLoggableString
(Object value, SessionFactoryImplementor factory) EntityType.toLoggableString
(Object value, SessionFactoryImplementor factory) Generate a loggable representation of an instance of the value mapped by this type.EnumType.toLoggableString
(Object value, SessionFactoryImplementor factory) Deprecated, for removal: This API element is subject to removal in a future version.MetaType.toLoggableString
(Object value, SessionFactoryImplementor factory) Deprecated, for removal: This API element is subject to removal in a future version.final String
SerializableToBlobType.toLoggableString
(Object value, SessionFactoryImplementor factory) Type.toLoggableString
(@Nullable Object value, SessionFactoryImplementor factory) Generate a representation of the given value for logging purposes.MetaType.toXMLString
(Object value, SessionFactoryImplementor factory) Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of SessionFactoryImplementor in org.hibernate.type.descriptor
Modifier and TypeMethodDescriptionWrapperOptions.getSessionFactory()
Access to the current session factory. -
Uses of SessionFactoryImplementor in org.hibernate.type.internal
Modifier and TypeMethodDescriptionfinal Object
ConvertedBasicTypeImpl.deepCopy
(Object value, SessionFactoryImplementor factory) final int
ConvertedBasicTypeImpl.getHashCode
(Object x, SessionFactoryImplementor factory) final boolean
ConvertedBasicTypeImpl.isEqual
(Object x, Object y, SessionFactoryImplementor factory) final String
ConvertedBasicTypeImpl.toLoggableString
(Object value, SessionFactoryImplementor factory) -
Uses of SessionFactoryImplementor in org.hibernate.type.spi
Modifier and TypeMethodDescriptionTypeConfiguration.getSessionFactory()
Deprecated.This operation is not very typesafe, and we're migrating away from its useModifier and TypeMethodDescriptionvoid
TypeConfiguration.scope
(SessionFactoryImplementor sessionFactory) Scope thisTypeConfiguration
to the givenSessionFactory
. -
Uses of SessionFactoryImplementor in org.hibernate.usertype
Modifier and TypeMethodDescriptionCompositeUserType.instantiate
(ValueAccess values, SessionFactoryImplementor sessionFactory) default boolean
CompositeUserType.isInstance
(Object object, SessionFactoryImplementor sessionFactory) default boolean
CompositeUserType.isSameClass
(Object object, SessionFactoryImplementor sessionFactory) LoggableUserType.toLoggableString
(Object value, SessionFactoryImplementor factory) Generate a loggable string representation of the collection (value). -
Uses of SessionFactoryImplementor in org.hibernate.usertype.internal
Modifier and TypeMethodDescriptionOffsetDateTimeCompositeUserType.instantiate
(ValueAccess values, SessionFactoryImplementor sessionFactory) OffsetTimeCompositeUserType.instantiate
(ValueAccess values, SessionFactoryImplementor sessionFactory) ZonedDateTimeCompositeUserType.instantiate
(ValueAccess values, SessionFactoryImplementor sessionFactory)