Uses of Class
org.hibernate.HibernateException
-
Packages that use HibernateException Package Description org.hibernate org.hibernate.action.spi Defines SPI hooks into theActionQueue.org.hibernate.boot This package contains the contracts that make up the Hibernate native bootstrapping API (building a SessionFactory).org.hibernate.boot.archive.spi Defines the SPI for support of "scanning" of "archives".org.hibernate.boot.model.naming Represents a proposed new approach to allowing hooks into the process of determining the name of database objects (tables, columns, constraints, etc).org.hibernate.boot.registry.classloading.spi The class loading service SPI.org.hibernate.boot.registry.selector.spi Defines actual contract used for strategy selection :StrategySelector.org.hibernate.boot.spi org.hibernate.bytecode.enhance.spi package defining bytecode code enhancement (instrumentation) support.org.hibernate.bytecode.spi Package defining bytecode code enhancement (instrumentation) support.org.hibernate.cache org.hibernate.cache.spi Defines the integration aspect of Hibernate's second-level caching allowing "caching back ends" to be plugged in as a caching provider.org.hibernate.cache.spi.access org.hibernate.cache.spi.entry org.hibernate.cfg org.hibernate.cfg.beanvalidation org.hibernate.collection.spi SPI definitions for persistent collectionsorg.hibernate.context Defines support for "current session" feature.org.hibernate.context.spi SPI level contracts around "current session" support.org.hibernate.dialect.lock Support for Dialect-specific locking strategiesorg.hibernate.engine.jdbc.dialect.spi Contracts supporting Dialect resolution (from JDBC metadata) and Dialect building.org.hibernate.engine.jndi Support for JNDI within Hibernateorg.hibernate.engine.query org.hibernate.engine.spi org.hibernate.engine.transaction.jta.platform.spi org.hibernate.engine.transaction.spi org.hibernate.event.service.spi org.hibernate.event.spi org.hibernate.exception org.hibernate.graph Hibernate's (extended) support for JPA's entity graphsorg.hibernate.id org.hibernate.id.enhanced Enhanced/improved versions of table and sequence based identifier generators targeting portability and unified configurationorg.hibernate.id.uuid org.hibernate.jdbc org.hibernate.loader org.hibernate.loader.entity org.hibernate.mapping org.hibernate.metadata This package defines an API for accessing the Hibernate runtime metamodel.org.hibernate.metamodel org.hibernate.metamodel.mapping.ordering.ast org.hibernate.metamodel.model.domain Hibernate extensions to and implementations of the JPA metamodelorg.hibernate.metamodel.relational org.hibernate.persister.collection org.hibernate.persister.entity org.hibernate.persister.spi org.hibernate.procedure org.hibernate.property.access.spi Defines strategies for accessing the persistent properties of an entity or composite.org.hibernate.proxy org.hibernate.proxy.pojo.bytebuddy org.hibernate.query org.hibernate.query.hql Package defining support for HQL queries (including supprt for JPQL as a subset of HQL).org.hibernate.query.named Support for named queriesorg.hibernate.query.results Support for defining result-set mappings used inNativeQueryandProcedureCall/StoredProcedureQuery.org.hibernate.query.spi org.hibernate.query.sqm org.hibernate.query.sqm.sql Package for the translation of SQM into SQL ASTorg.hibernate.query.sqm.tree.from org.hibernate.resource.transaction Defines the resource-level transaction capabilities of Hibernate, which revolves around theTransactionCoordinatorcontract.org.hibernate.result org.hibernate.service org.hibernate.service.spi org.hibernate.sql.ast Package defining a SQL AST for use in creating and executing various JDBC operationsorg.hibernate.sql.ast.tree.from org.hibernate.sql.exec Package defining support for execution of SQL statements through JDBC.org.hibernate.sql.results Package for processing JDBC ResultSets into hydrated domain model graphs based on a "load plan" defined by a "domain result graph" - one or moreDomainResultnodes with zero-or-moreFetchnodesorg.hibernate.tool.schema.extract.spi org.hibernate.tool.schema.spi org.hibernate.tuple.entity org.hibernate.type org.hibernate.type.descriptor.java org.hibernate.type.descriptor.java.spi org.hibernate.usertype -
-
Uses of HibernateException in org.hibernate
Subclasses of HibernateException in org.hibernate Modifier and Type Class Description classAnnotationExceptionAnnotation related exception.classCallbackExceptionIntended to be thrown fromLifecycleandInterceptorcallbacks.classDuplicateMappingExceptionRaised whenever a duplicate for a certain type occurs.classHibernateErrorMarks a group of exceptions that generally indicate an internal Hibernate error or bug.classInstantiationExceptionThrown if Hibernate can't instantiate a class at runtime.classInvalidMappingExceptionThrown when a mapping is found to be invalid.classJDBCExceptionWraps aSQLException.classLazyInitializationExceptionIndicates an attempt to access not-yet-fetched data outside of a session context.classMappingExceptionAn exception that occurs while reading mapping sources (xml/annotations), usually as a result of something screwy in the O-R mappings.classNonUniqueObjectExceptionThis exception is thrown when an operation would break session-scoped identity.classNonUniqueResultExceptionThrown when the application callsQuery.uniqueResult()and the query returned more than one result.classObjectDeletedExceptionThrown when the user tries to do something illegal with a deleted object.classObjectNotFoundExceptionThrown whenSession.load()fails to select a row with the given primary key (identifier value).classPersistentObjectExceptionThrown when the user passes a persistent instance to aSessionmethod that expects a transient instance.classPessimisticLockExceptionThrown when a pessimistic locking conflict occurs.classPropertyAccessExceptionA problem occurred accessing a property of an instance of a persistent class by reflection, or via enhanced entities.classPropertyNotFoundExceptionIndicates that an expected getter or setter method could not be found on a class.classPropertySetterAccessExceptionclassPropertyValueExceptionThrown when the (illegal) value of a property can not be persisted.classQueryExceptionA problem occurred translating a Hibernate query to SQL due to invalid query syntax, etc.classQueryParameterExceptionParameter invalid or not found in the query.classQueryTimeoutExceptionThrown when a database query timeout occurs.classResourceClosedExceptionIndicates an attempt was made to use a closed resource (Session, SessionFactory, etc).classSessionExceptionThrown when the user calls a method of aSessionthat is in an inappropriate state for the given call (for example, the session is closed or disconnected).classStaleObjectStateExceptionA specialized StaleStateException that carries information about the particular entity instance that was the source of the failure.classStaleStateExceptionThrown when a version number or timestamp check failed, indicating that the Session contained stale data (when using long transactions with versioning).classTransactionExceptionIndicates that a transaction could not be begun, committed or rolled back.classTransientObjectExceptionThrown when the user passes a transient instance to a Session method that expects a persistent instance.classTransientPropertyValueExceptionThrown when a property cannot be persisted because it is an association with a transient unsaved entity instance.classTypeMismatchExceptionUsed when a user provided type does not match the expected one.classUnknownEntityTypeExceptionIndicates an attempt was made to refer to an unknown entity name/class.classUnknownProfileExceptionUsed to indicate a request against an unknown profile name.classUnresolvableObjectExceptionThrown when Hibernate could not resolve an object by id, especially when loading an association.classUnsupportedLockAttemptExceptionThis exception is thrown when an invalid LockMode is selected for an entity.classWrongClassExceptionThrown when loading an entity (by identifier) results in a value that cannot be treated as the subclass type requested by the caller.Methods in org.hibernate that throw HibernateException Modifier and Type Method Description voidSessionFactory. close()Destroy thisSessionFactoryand release all its resources, including caches and connection pools.voidSharedSessionContract. close()End the session by releasing the JDBC connection and cleaning up.default <T> TSharedSessionContract. doReturningWork(ReturningWork<T> work)Perform work using theConnectionunderlying by this session, and return a result.default voidSharedSessionContract. doWork(Work work)Perform work using theConnectionunderlying by this session.SessionSessionFactory. getCurrentSession()Obtains the current session, an instance ofSessionimplicitly associated with some context.FilterDefinitionSessionFactory. getFilterDefinition(String filterName)Obtain the definition of a filter by name.static voidHibernate. initialize(Object proxy)Force initialization of a proxy or persistent collection.SessionSessionFactory. openSession()Open aSession.voidFilter. validate()Perform validation of the filter state. -
Uses of HibernateException in org.hibernate.action.spi
Methods in org.hibernate.action.spi that throw HibernateException Modifier and Type Method Description voidExecutable. beforeExecutions()Called before executing any actions.voidExecutable. execute()Execute this action. -
Uses of HibernateException in org.hibernate.boot
Subclasses of HibernateException in org.hibernate.boot Modifier and Type Class Description classInvalidMappingExceptionIndicates a problem parsing the mapping document at a givenOrigin.classMappingExceptionIndicates a problem parsing a mapping document.classMappingNotFoundExceptionIndicates that a mapping document could not be found at a givenOrigin.classUnsupportedOrmXsdVersionException -
Uses of HibernateException in org.hibernate.boot.archive.spi
Subclasses of HibernateException in org.hibernate.boot.archive.spi Modifier and Type Class Description classArchiveExceptionIndicates a problem accessing or visiting the archive -
Uses of HibernateException in org.hibernate.boot.model.naming
Subclasses of HibernateException in org.hibernate.boot.model.naming Modifier and Type Class Description classIllegalIdentifierExceptionIndicates an attempted use of a name that was deemed illegal -
Uses of HibernateException in org.hibernate.boot.registry.classloading.spi
Subclasses of HibernateException in org.hibernate.boot.registry.classloading.spi Modifier and Type Class Description classClassLoadingExceptionIndicates a problem performing class loading. -
Uses of HibernateException in org.hibernate.boot.registry.selector.spi
Subclasses of HibernateException in org.hibernate.boot.registry.selector.spi Modifier and Type Class Description classStrategySelectionExceptionIndicates a problem performing the selection/resolution. -
Uses of HibernateException in org.hibernate.boot.spi
Subclasses of HibernateException in org.hibernate.boot.spi Modifier and Type Class Description static classInFlightMetadataCollector.DuplicateSecondaryTableException -
Uses of HibernateException in org.hibernate.bytecode.enhance.spi
Subclasses of HibernateException in org.hibernate.bytecode.enhance.spi Modifier and Type Class Description classEnhancementExceptionAn exception indicating some kind of problem performing bytecode enhancement. -
Uses of HibernateException in org.hibernate.bytecode.spi
Subclasses of HibernateException in org.hibernate.bytecode.spi Modifier and Type Class Description classNotInstrumentedExceptionIndicates a condition where an instrumented/enhanced class was expected, but the class was not instrumented/enhanced. -
Uses of HibernateException in org.hibernate.cache
Subclasses of HibernateException in org.hibernate.cache Modifier and Type Class Description classCacheExceptionSomething went wrong in the cacheclassNoCacheRegionFactoryAvailableExceptionIndicates a condition where a second-level cache implementation was expected to be available, but none was found on the classpath. -
Uses of HibernateException in org.hibernate.cache.spi
Methods in org.hibernate.cache.spi that throw HibernateException Modifier and Type Method Description default voidCacheImplementor. evictQueries()Deprecated.only because it's currently never calledList<?>QueryResultsCache. get(QueryKey key, String[] spaces, SharedSessionContractImplementor session)Get results from the cache.List<?>QueryResultsCache. get(QueryKey key, Set<String> spaces, SharedSessionContractImplementor session)Get results from the cache.booleanQueryResultsCache. put(QueryKey key, List<?> result, SharedSessionContractImplementor session)Put a result into the query cache. -
Uses of HibernateException in org.hibernate.cache.spi.access
Subclasses of HibernateException in org.hibernate.cache.spi.access Modifier and Type Class Description classUnknownAccessTypeExceptionIndicates that an unknown AccessType external name was encountered or that an AccessType was requested that the underlying cache provider does not support. -
Uses of HibernateException in org.hibernate.cache.spi.entry
Methods in org.hibernate.cache.spi.entry that throw HibernateException Modifier and Type Method Description Object[]StandardCacheEntryImpl. assemble(Object instance, Object id, EntityPersister persister, Interceptor interceptor, EventSource session)Assemble the previously disassembled state represented by this entry into the given entity instance.Constructors in org.hibernate.cache.spi.entry that throw HibernateException Constructor Description StandardCacheEntryImpl(Object[] state, EntityPersister persister, Object version, SharedSessionContractImplementor session, Object owner)Constructs a StandardCacheEntryImpl -
Uses of HibernateException in org.hibernate.cfg
Subclasses of HibernateException in org.hibernate.cfg Modifier and Type Class Description classCannotForceNonNullableExceptionIndicates an internal attempt to mark a column as non-nullable (because its part of a PK, etc) but we cannot force that column to be non-nullable.classNotYetImplementedExceptionMapping not yet implementedclassRecoverableExceptionDeprecated.Was only ever referenced in a single place, in an extremely dubious way.Methods in org.hibernate.cfg that throw HibernateException Modifier and Type Method Description SessionFactoryConfiguration. buildSessionFactory()Create aSessionFactoryusing the properties and mappings in this configuration.SessionFactoryConfiguration. buildSessionFactory(ServiceRegistry serviceRegistry)Create aSessionFactoryusing the properties and mappings in this configuration.ConfigurationConfiguration. configure()Use the mappings and properties specified in an application resource namedhibernate.cfg.xml.ConfigurationConfiguration. configure(File configFile)Use the mappings and properties specified in the given application file.ConfigurationConfiguration. configure(String resource)Use the mappings and properties specified in the given application resource.ConfigurationConfiguration. configure(URL url)Use the mappings and properties specified in the given document. -
Uses of HibernateException in org.hibernate.cfg.beanvalidation
Subclasses of HibernateException in org.hibernate.cfg.beanvalidation Modifier and Type Class Description classIntegrationExceptionIndicates a problem integrating Hibernate and the Bean Validation spec. -
Uses of HibernateException in org.hibernate.collection.spi
Methods in org.hibernate.collection.spi that throw HibernateException Modifier and Type Method Description voidAbstractPersistentCollection. afterRowInsert(CollectionPersister persister, Object entry, int i)voidPersistentIdentifierBag. afterRowInsert(CollectionPersister persister, Object entry, int i)ObjectPersistentArrayHolder. disassemble(CollectionPersister persister)ObjectPersistentList. disassemble(CollectionPersister persister)ObjectPersistentMap. disassemble(CollectionPersister persister)ObjectPersistentSet. disassemble(CollectionPersister persister)booleanPersistentArrayHolder. equalsSnapshot(CollectionPersister persister)booleanPersistentBag. equalsSnapshot(CollectionPersister persister)booleanPersistentIdentifierBag. equalsSnapshot(CollectionPersister persister)booleanPersistentList. equalsSnapshot(CollectionPersister persister)booleanPersistentMap. equalsSnapshot(CollectionPersister persister)booleanPersistentSet. equalsSnapshot(CollectionPersister persister)voidAbstractPersistentCollection. forceInitialization()IteratorPersistentArrayHolder. getDeletes(CollectionPersister persister, boolean indexIsFormula)Iterator<?>PersistentBag. getDeletes(CollectionPersister persister, boolean indexIsFormula)Iterator<?>PersistentIdentifierBag. getDeletes(CollectionPersister persister, boolean indexIsFormula)Iterator<?>PersistentList. getDeletes(CollectionPersister persister, boolean indexIsFormula)Iterator<?>PersistentMap. getDeletes(CollectionPersister persister, boolean indexIsFormula)Iterator<?>PersistentSet. getDeletes(CollectionPersister persister, boolean indexIsFormula)abstract Collection<E>AbstractPersistentCollection. getOrphans(Serializable snapshot, String entityName)protected static <E> Collection<E>AbstractPersistentCollection. getOrphans(Collection<E> oldElements, Collection<E> currentElements, String entityName, SharedSessionContractImplementor session)Given a collection of entity instances that used to belong to the collection, and a collection of instances that currently belong, return a collection of orphansCollectionPersistentArrayHolder. getOrphans(Serializable snapshot, String entityName)Collection<E>PersistentBag. getOrphans(Serializable snapshot, String entityName)Collection<E>PersistentIdentifierBag. getOrphans(Serializable snapshot, String entityName)Collection<E>PersistentList. getOrphans(Serializable snapshot, String entityName)Collection<E>PersistentMap. getOrphans(Serializable snapshot, String entityName)Collection<E>PersistentSet. getOrphans(Serializable snapshot, String entityName)SerializablePersistentArrayHolder. getSnapshot(CollectionPersister persister)SerializablePersistentBag. getSnapshot(CollectionPersister persister)SerializablePersistentIdentifierBag. getSnapshot(CollectionPersister persister)SerializablePersistentList. getSnapshot(CollectionPersister persister)SerializablePersistentMap. getSnapshot(CollectionPersister persister)SerializablePersistentSet. getSnapshot(CollectionPersister persister)voidPersistentArrayHolder. initializeFromCache(CollectionPersister persister, Object disassembled, Object owner)voidPersistentBag. initializeFromCache(CollectionPersister collectionDescriptor, Object disassembled, Object owner)voidPersistentIdentifierBag. initializeFromCache(CollectionPersister persister, Object disassembled, Object owner)voidPersistentList. initializeFromCache(CollectionPersister persister, Object disassembled, Object owner)voidPersistentMap. initializeFromCache(CollectionPersister persister, Object disassembled, Object owner)voidPersistentSet. initializeFromCache(CollectionPersister persister, Object disassembled, Object owner)booleanPersistentArrayHolder. needsInserting(Object entry, int i, Type elemType)booleanPersistentBag. needsInserting(Object entry, int i, Type elemType)booleanPersistentIdentifierBag. needsInserting(Object entry, int i, Type elemType)booleanPersistentList. needsInserting(Object entry, int i, Type elemType)booleanPersistentMap. needsInserting(Object entry, int i, Type elemType)booleanPersistentSet. needsInserting(Object entry, int i, Type elemType)booleanPersistentArrayHolder. needsUpdating(Object entry, int i, Type elemType)booleanPersistentIdentifierBag. needsUpdating(Object entry, int i, Type elemType)booleanPersistentList. needsUpdating(Object entry, int i, Type elemType)booleanPersistentMap. needsUpdating(Object entry, int i, Type elemType)voidAbstractPersistentCollection. preInsert(CollectionPersister persister)voidPersistentIdentifierBag. preInsert(CollectionPersister persister)booleanAbstractPersistentCollection. setCurrentSession(SharedSessionContractImplementor session)booleanPersistentCollection. setCurrentSession(SharedSessionContractImplementor session)Associate the collection with the given session.protected SerializablePersistentSortedMap. snapshot(BasicCollectionPersister persister)protected SerializablePersistentSortedSet. snapshot(BasicCollectionPersister persister) -
Uses of HibernateException in org.hibernate.context
Subclasses of HibernateException in org.hibernate.context Modifier and Type Class Description classTenantIdentifierMismatchExceptionIndicates that tenant identifiers did not match in cases whereCurrentTenantIdentifierResolver.validateExistingCurrentSessions()returnstrueand there is a mismatch found. -
Uses of HibernateException in org.hibernate.context.spi
Methods in org.hibernate.context.spi that throw HibernateException Modifier and Type Method Description SessionCurrentSessionContext. currentSession()Retrieve the current session according to the scoping defined by this implementation. -
Uses of HibernateException in org.hibernate.dialect.lock
Subclasses of HibernateException in org.hibernate.dialect.lock Modifier and Type Class Description classLockingStrategyExceptionRepresents an error trying to apply aLockingStrategyto an entityclassOptimisticEntityLockExceptionRepresents an error trying to apply an optimisticLockingStrategyto an entityclassPessimisticEntityLockExceptionRepresents an error trying to apply a pessimisticLockingStrategyto an entity -
Uses of HibernateException in org.hibernate.engine.jdbc.dialect.spi
Methods in org.hibernate.engine.jdbc.dialect.spi that throw HibernateException Modifier and Type Method Description DialectDialectFactory. buildDialect(Map<String,Object> configValues, DialectResolutionInfoSource resolutionInfoSource)Builds an appropriate Dialect instance. -
Uses of HibernateException in org.hibernate.engine.jndi
Subclasses of HibernateException in org.hibernate.engine.jndi Modifier and Type Class Description classJndiExceptionAn exception indicating trouble accessing JNDIclassJndiNameExceptionIndicates a problem with a given JNDI name being deemed as not valid. -
Uses of HibernateException in org.hibernate.engine.query
Subclasses of HibernateException in org.hibernate.engine.query Modifier and Type Class Description classParameterRecognitionExceptionIndicates a problem during parameter recognition viaParameterRecognizer -
Uses of HibernateException in org.hibernate.engine.spi
Methods in org.hibernate.engine.spi with parameters of type HibernateException Modifier and Type Method Description RuntimeExceptionExceptionConverter. convert(HibernateException e)Converts a Hibernate-specific exception into a JPA-specified exception; note that the JPA specification makes use of exceptions outside its exception hierarchy, though they are all runtime exceptions.RuntimeExceptionExceptionConverter. convert(HibernateException e, LockOptions lockOptions)Converts a Hibernate-specific exception into a JPA-specified exception; note that the JPA specification makes use of exceptions outside its exception hierarchy, though they are all runtime exceptions.Methods in org.hibernate.engine.spi that throw HibernateException Modifier and Type Method Description booleanSessionDelegatorBaseImpl. autoFlushIfRequired(Set<String> querySpaces)booleanSharedSessionContractImplementor. autoFlushIfRequired(Set<String> querySpaces)detect in-memory changes, determine if the changes are to tables named in the query and, if so, complete execution the flushvoidSessionDelegatorBaseImpl. cancelQuery()voidCascadingAction. cascade(EventSource session, Object child, String entityName, T anything, boolean isCascadeDeleteEnabled)Cascade the action to the child object.voidSessionDelegatorBaseImpl. close()voidSessionFactoryDelegatingImpl. close()<T> TSessionDelegatorBaseImpl. doReturningWork(ReturningWork<T> work)voidSessionDelegatorBaseImpl. doWork(Work work)voidActionQueue. executeActions()Perform all currently queued actions.voidActionQueue. executeInserts()Perform all currently queued entity-insertion actions.voidSessionDelegatorBaseImpl. forceFlush(EntityEntry e)voidSessionImplementor. forceFlush(EntityEntry e)SessionSessionFactoryDelegatingImpl. getCurrentSession()EntityPersisterSessionDelegatorBaseImpl. getEntityPersister(String entityName, Object object)EntityPersisterSharedSessionContractImplementor. getEntityPersister(String entityName, Object object)Get theEntityPersisterfor any instanceObjectSessionDelegatorBaseImpl. getEntityUsingInterceptor(EntityKey key)ObjectSharedSessionContractImplementor. getEntityUsingInterceptor(EntityKey key)Get the entity instance associated with the givenKey, calling the Interceptor if necessaryFilterDefinitionSessionFactoryDelegatingImpl. getFilterDefinition(String filterName)Collection<?>CollectionEntry. getOrphans(String entityName, PersistentCollection<?> collection)Get the collection orphans (entities which were removed from the collection)StringSessionDelegatorBaseImpl. guessEntityName(Object entity)StringSharedSessionContractImplementor. guessEntityName(Object entity)The guessed entity name for an entity not in an associationObjectSessionDelegatorBaseImpl. immediateLoad(String entityName, Object id)ObjectSharedSessionContractImplementor. immediateLoad(String entityName, Object id)Load an instance immediately.voidSessionDelegatorBaseImpl. initializeCollection(PersistentCollection<?> collection, boolean writing)voidSharedSessionContractImplementor. initializeCollection(PersistentCollection<?> collection, boolean writing)Initialize the collection (if not already initialized)voidPersistenceContext. initializeNonLazyCollections()Force initialization of all non-lazy collections encountered during the current two-phase load (actually, this is a no-op, unless this is the "outermost" load)ObjectSessionDelegatorBaseImpl. instantiate(String entityName, Object id)ObjectSessionDelegatorBaseImpl. instantiate(EntityPersister persister, Object id)ObjectSessionImplementor. instantiate(EntityPersister persister, Object id)ObjectSharedSessionContractImplementor. instantiate(String entityName, Object id)Instantiate the entity class, initializing with the given identifierObjectSharedSessionContractImplementor. instantiate(EntityPersister persister, Object id)Instantiate the entity class of an EntityPersister, initializing with the given identifier.ObjectSessionDelegatorBaseImpl. internalLoad(String entityName, Object id, boolean eager, boolean nullable)ObjectSharedSessionContractImplementor. internalLoad(String entityName, Object id, boolean eager, boolean nullable)Load an instance without checking if it was deleted.booleanSessionDelegatorBaseImpl. isDirty()voidSessionDelegatorBaseImpl. merge(String entityName, Object object, MergeContext copiedAlready)voidSessionImplementor. merge(String entityName, Object object, MergeContext copiedAlready)Deprecated.OperationalContext should cover this overload I believeSessionSessionFactoryDelegatingImpl. openSession()SessionSessionFactoryDelegatingImpl. openTemporarySession()SessionSessionFactoryImplementor. openTemporarySession()Get a non-transactional "current" session (used by hibernate-envers)voidSessionDelegatorBaseImpl. persist(String entityName, Object object, PersistContext createdAlready)voidSessionImplementor. persist(String entityName, Object object, PersistContext createdAlready)Deprecated.OperationalContext should cover this overload I believevoidCollectionEntry. postFlush(PersistentCollection<?> collection)Called after a successful flushvoidCollectionEntry. postInitialize(PersistentCollection<?> collection)voidCollectionEntry. preFlush(PersistentCollection<?> collection)voidActionQueue. prepareActions()Prepares the internal action queues for execution.voidSessionDelegatorBaseImpl. refresh(String entityName, Object object, RefreshContext refreshedAlready)voidSessionImplementor. refresh(String entityName, Object object, RefreshContext refreshedAlready)Deprecated.OperationalContext should cover this overload I believe -
Uses of HibernateException in org.hibernate.engine.transaction.jta.platform.spi
Subclasses of HibernateException in org.hibernate.engine.transaction.jta.platform.spi Modifier and Type Class Description classJtaPlatformExceptionIndicates a problem interacting with the underlying JTA platform. -
Uses of HibernateException in org.hibernate.engine.transaction.spi
Methods in org.hibernate.engine.transaction.spi that throw HibernateException Modifier and Type Method Description <T> TIsolationDelegate. delegateCallable(Callable<T> callable, boolean transacted)Invoke the given callable in isolation from current transaction.<T> TIsolationDelegate. delegateWork(WorkExecutorVisitable<T> work, boolean transacted)Perform the given work in isolation from current transaction. -
Uses of HibernateException in org.hibernate.event.service.spi
Subclasses of HibernateException in org.hibernate.event.service.spi Modifier and Type Class Description classEventListenerRegistrationExceptionIndicates a problem registering an event listener. -
Uses of HibernateException in org.hibernate.event.spi
Methods in org.hibernate.event.spi that throw HibernateException Modifier and Type Method Description voidEventSource. forceFlush(EntityEntry e)Force an immediate flushObjectEventSource. instantiate(EntityPersister persister, Object id)Instantiate an entity instance, using either an interceptor, or the given persistervoidEventSource. merge(String entityName, Object object, MergeContext copiedAlready)Cascade merge an entity instancevoidAutoFlushEventListener. onAutoFlush(AutoFlushEvent event)Handle the given auto-flush event.voidDeleteEventListener. onDelete(DeleteEvent event)Handle the given delete event.voidDeleteEventListener. onDelete(DeleteEvent event, DeleteContext transientEntities)voidDirtyCheckEventListener. onDirtyCheck(DirtyCheckEvent event)Handle the given dirty-check event.voidEvictEventListener. onEvict(EvictEvent event)Handle the given evict event.voidFlushEventListener. onFlush(FlushEvent event)Handle the given flush event.voidFlushEntityEventListener. onFlushEntity(FlushEntityEvent event)voidInitializeCollectionEventListener. onInitializeCollection(InitializeCollectionEvent event)voidLoadEventListener. onLoad(LoadEvent event, LoadEventListener.LoadType loadType)Handle the given load event.voidLockEventListener. onLock(LockEvent event)Handle the given lock event.voidMergeEventListener. onMerge(MergeEvent event)Handle the given merge event.voidMergeEventListener. onMerge(MergeEvent event, MergeContext copiedAlready)Handle the given merge event.voidPersistEventListener. onPersist(PersistEvent event)Handle the given create event.voidPersistEventListener. onPersist(PersistEvent event, PersistContext createdAlready)Handle the given create event.voidRefreshEventListener. onRefresh(RefreshEvent event)Handle the given refresh event.voidRefreshEventListener. onRefresh(RefreshEvent event, RefreshContext refreshedAlready)voidReplicateEventListener. onReplicate(ReplicateEvent event)Handle the given replicate event.voidResolveNaturalIdEventListener. onResolveNaturalId(ResolveNaturalIdEvent event)Handle the given resolve natural id event.voidSaveOrUpdateEventListener. onSaveOrUpdate(SaveOrUpdateEvent event)Handle the given update event.voidEventSource. persist(String entityName, Object object, PersistContext createdAlready)Cascade persist an entity instancevoidEventSource. refresh(String entityName, Object object, RefreshContext refreshedAlready)Cascade refresh an entity instance -
Uses of HibernateException in org.hibernate.exception
Subclasses of HibernateException in org.hibernate.exception Modifier and Type Class Description classConstraintViolationExceptionImplementation of JDBCException indicating that the requested DML operation resulted in a violation of a defined integrity constraint.classDataExceptionImplementation of JDBCException indicating that evaluation of the valid SQL statement against the given data resulted in some illegal operation, mismatched types or incorrect cardinality.classGenericJDBCExceptionGeneric, non-specific JDBCException.classJDBCConnectionExceptionImplementation of JDBCException indicating problems with communicating with the database (can also include incorrect JDBC setup).classLockAcquisitionExceptionImplementation of JDBCException indicating a problem acquiring lock on the database.classLockTimeoutExceptionclassSQLGrammarExceptionImplementation of JDBCException indicating that the SQL sent to the database server was invalid (syntax error, invalid object references, etc). -
Uses of HibernateException in org.hibernate.graph
Subclasses of HibernateException in org.hibernate.graph Modifier and Type Class Description classCannotBecomeEntityGraphExceptionIndicates an illegal attempt to make aGraphbecome anEntityGraphviaGraph.makeRootGraph(String, boolean).classCannotContainSubGraphExceptionIndicates an attempt was made to add a (key)? sub-graph to an attribute type that does not support (key)? sub-graphs.classInvalidGraphExceptionThrown byGraphParserto indicate textual entity graph representation parsing errors. -
Uses of HibernateException in org.hibernate.id
Subclasses of HibernateException in org.hibernate.id Modifier and Type Class Description classIdentifierGenerationExceptionThrown byIdentifierGeneratorimplementation class when ID generation fails.Methods in org.hibernate.id that throw HibernateException Modifier and Type Method Description ObjectAssigned. generate(SharedSessionContractImplementor session, Object obj)ObjectCompositeNestedGeneratedValueGenerator. generate(SharedSessionContractImplementor session, Object object)ObjectGUIDGenerator. generate(SharedSessionContractImplementor session, Object obj)Deprecated.ObjectIdentifierGenerator. generate(SharedSessionContractImplementor session, Object object)Generate a new identifier.ObjectIncrementGenerator. generate(SharedSessionContractImplementor session, Object object)ObjectUUIDGenerator. generate(SharedSessionContractImplementor session, Object object)Deprecated.static ObjectIdentifierGeneratorHelper. getGeneratedIdentity(ResultSet rs, String identifier, Type type, Dialect dialect)Get the generated identifier when using identity columnsInsertGeneratedIdentifierDelegateIdentityGenerator. getInsertGeneratedIdentifierDelegate(PostInsertIdentityPersister persister, Dialect dialect, boolean isGetGeneratedKeysEnabled)InsertGeneratedIdentifierDelegatePostInsertIdentifierGenerator. getInsertGeneratedIdentifierDelegate(PostInsertIdentityPersister persister, Dialect dialect, boolean isGetGeneratedKeysEnabled)InsertGeneratedIdentifierDelegateSelectGenerator. getInsertGeneratedIdentifierDelegate(PostInsertIdentityPersister persister, Dialect dialect, boolean isGetGeneratedKeysEnabled) -
Uses of HibernateException in org.hibernate.id.enhanced
Methods in org.hibernate.id.enhanced that throw HibernateException Modifier and Type Method Description ObjectSequenceStyleGenerator. generate(SharedSessionContractImplementor session, Object object) -
Uses of HibernateException in org.hibernate.id.uuid
Methods in org.hibernate.id.uuid that throw HibernateException Modifier and Type Method Description ObjectUuidGenerator. generate(SharedSessionContractImplementor session, Object object) -
Uses of HibernateException in org.hibernate.jdbc
Subclasses of HibernateException in org.hibernate.jdbc Modifier and Type Class Description classBatchedTooManyRowsAffectedExceptionMuch likeTooManyRowsAffectedException, indicates that more rows than what we were expecting were affected.classBatchFailedExceptionIndicates a failed batch entry (-3 return).classTooManyRowsAffectedExceptionIndicates that more rows were affected then we were expecting to be.Methods in org.hibernate.jdbc that throw HibernateException Modifier and Type Method Description intExpectation. prepare(PreparedStatement statement)Perform any special statement preparation.intExpectations.BasicExpectation. prepare(PreparedStatement statement)intExpectations.BasicParamExpectation. prepare(PreparedStatement statement)voidExpectation. verifyOutcome(int rowCount, PreparedStatement statement, int batchPosition, String statementSQL)Perform verification of the outcome of the RDBMS operation based on the type of expectation defined. -
Uses of HibernateException in org.hibernate.loader
Subclasses of HibernateException in org.hibernate.loader Modifier and Type Class Description classMultipleBagFetchExceptionException used to indicate that a query is attempting to simultaneously fetch multiple bagsclassNonUniqueDiscoveredSqlAliasException -
Uses of HibernateException in org.hibernate.loader.entity
Methods in org.hibernate.loader.entity that throw HibernateException Modifier and Type Method Description CacheEntityLoaderHelper.PersistenceContextEntryCacheEntityLoaderHelper. loadFromSessionCache(LoadEvent event, EntityKey keyToLoad, LoadEventListener.LoadType options)Attempts to locate the entity in the session-level cache. -
Uses of HibernateException in org.hibernate.mapping
Methods in org.hibernate.mapping that throw HibernateException Modifier and Type Method Description StringColumn. getSqlType(TypeConfiguration typeConfiguration, Dialect dialect, Mapping mapping)Iterator<String>Table. sqlAlterStrings(Dialect dialect, Metadata metadata, TableInformation tableInfo, SqlStringGenerationContext sqlStringGenerationContext)StringIndex. sqlCreateString(Mapping mapping, SqlStringGenerationContext context, String defaultCatalog, String defaultSchema)StringRelationalModel. sqlCreateString(Mapping p, SqlStringGenerationContext context, String defaultCatalog, String defaultSchema)Deprecated. -
Uses of HibernateException in org.hibernate.metadata
Methods in org.hibernate.metadata that throw HibernateException Modifier and Type Method Description default ObjectClassMetadata. getIdentifier(Object object)Deprecated.TypeClassMetadata. getPropertyType(String propertyName)Deprecated.Get the type of a particular (named) propertyObjectClassMetadata. getPropertyValue(Object object, String propertyName)Deprecated.Get the value of a particular (named) propertyObject[]ClassMetadata. getPropertyValues(Object entity)Deprecated.Extract the property values from the given entity.default Object[]ClassMetadata. getPropertyValuesToInsert(Object entity, Map<Object,Object> mergeMap, SessionImplementor session)Deprecated.Use the form accepting SharedSessionContractImplementor insteadObject[]ClassMetadata. getPropertyValuesToInsert(Object entity, Map<Object,Object> mergeMap, SharedSessionContractImplementor session)Deprecated.Return the values of the mapped properties of the objectObjectClassMetadata. getVersion(Object object)Deprecated.Get the version number (or timestamp) from the object's version property (or return null if not versioned)voidClassMetadata. setPropertyValue(Object object, String propertyName, Object value)Deprecated.Set the value of a particular (named) propertyvoidClassMetadata. setPropertyValues(Object object, Object[] values)Deprecated.Set the given values to the mapped properties of the given object -
Uses of HibernateException in org.hibernate.metamodel
Subclasses of HibernateException in org.hibernate.metamodel Modifier and Type Class Description classUnsupportedMappingException -
Uses of HibernateException in org.hibernate.metamodel.mapping.ordering.ast
Subclasses of HibernateException in org.hibernate.metamodel.mapping.ordering.ast Modifier and Type Class Description classOrderByComplianceViolationclassPathResolutionExceptionIndicates a problem resolving a domain-path occurring in an order-by fragment -
Uses of HibernateException in org.hibernate.metamodel.model.domain
Methods in org.hibernate.metamodel.model.domain that throw HibernateException Modifier and Type Method Description default booleanBasicDomainType. areEqual(J x, J y) -
Uses of HibernateException in org.hibernate.metamodel.relational
Subclasses of HibernateException in org.hibernate.metamodel.relational Modifier and Type Class Description classIllegalIdentifierExceptionIndicates an attempted use of a name that was deemed illegal -
Uses of HibernateException in org.hibernate.persister.collection
Methods in org.hibernate.persister.collection that throw HibernateException Modifier and Type Method Description voidAbstractCollectionPersister. deleteRows(PersistentCollection<?> collection, Object id, SharedSessionContractImplementor session)protected abstract voidAbstractCollectionPersister. doProcessQueuedOps(PersistentCollection<?> collection, Object key, SharedSessionContractImplementor session)protected voidOneToManyPersister. doProcessQueuedOps(PersistentCollection<?> collection, Object id, SharedSessionContractImplementor session)protected intBasicCollectionPersister. doUpdateRows(Object id, PersistentCollection<?> collection, SharedSessionContractImplementor session)voidAbstractCollectionPersister. initialize(Object key, SharedSessionContractImplementor session)voidCollectionPersister. initialize(Object key, SharedSessionContractImplementor session)Initialize the given collection with the given keyvoidAbstractCollectionPersister. insertRows(PersistentCollection<?> collection, Object id, SharedSessionContractImplementor session)voidOneToManyPersister. insertRows(PersistentCollection<?> collection, Object id, SharedSessionContractImplementor session)voidAbstractCollectionPersister. recreate(PersistentCollection<?> collection, Object id, SharedSessionContractImplementor session)voidOneToManyPersister. recreate(PersistentCollection<?> collection, Object id, SharedSessionContractImplementor session)voidAbstractCollectionPersister. remove(Object id, SharedSessionContractImplementor session)voidAbstractCollectionPersister. updateRows(PersistentCollection<?> collection, Object id, SharedSessionContractImplementor session)protected intAbstractCollectionPersister. writeElement(PreparedStatement st, Object elt, int i, SharedSessionContractImplementor session)Write the element to a JDBCPreparedStatementprotected intAbstractCollectionPersister. writeElementToWhere(PreparedStatement st, Object elt, int i, SharedSessionContractImplementor session)Write the element to a JDBCPreparedStatementintAbstractCollectionPersister. writeIdentifier(PreparedStatement st, Object id, int i, SharedSessionContractImplementor session)Write the identifier to a JDBCPreparedStatementprotected intAbstractCollectionPersister. writeIndex(PreparedStatement st, Object index, int i, SharedSessionContractImplementor session)Write the index to a JDBCPreparedStatementprotected intAbstractCollectionPersister. writeIndexToWhere(PreparedStatement st, Object index, int i, SharedSessionContractImplementor session)Write the index to a JDBCPreparedStatementprotected intAbstractCollectionPersister. writeKey(PreparedStatement st, Object key, int i, SharedSessionContractImplementor session)Write the key to a JDBCPreparedStatement -
Uses of HibernateException in org.hibernate.persister.entity
Methods in org.hibernate.persister.entity that throw HibernateException Modifier and Type Method Description protected booleanAbstractEntityPersister. check(int rows, Object id, int tableNumber, Expectation expectation, PreparedStatement statement, String statementSQL)ObjectAbstractEntityPersister. createProxy(Object id, SharedSessionContractImplementor session)ObjectDiscriminatorType. deepCopy(Object value, SessionFactoryImplementor factory)intAbstractEntityPersister. dehydrate(Object id, Object[] fields, boolean[] includeProperty, boolean[][] includeColumns, int j, PreparedStatement st, SharedSessionContractImplementor session, boolean isUpdate)intAbstractEntityPersister. dehydrate(Object id, Object[] fields, Object rowId, boolean[] includeProperty, boolean[][] includeColumns, int j, PreparedStatement ps, SharedSessionContractImplementor session, int index, boolean isUpdate)Marshall the fields of a persistent instance to a prepared statementvoidAbstractEntityPersister. delete(Object id, Object version, int j, Object object, String sql, SharedSessionContractImplementor session, Object[] loadedState)Perform an SQL DELETEvoidAbstractEntityPersister. delete(Object id, Object version, Object object, SharedSessionContractImplementor session)Delete an objectint[]AbstractEntityPersister. findDirty(Object[] currentState, Object[] previousState, Object entity, SharedSessionContractImplementor session)Locate the property-indices of all properties considered to be dirty.int[]AbstractEntityPersister. findModified(Object[] old, Object[] current, Object entity, SharedSessionContractImplementor session)Locate the property-indices of all properties considered to be dirty.ObjectEntityPersister. forceVersionIncrement(Object id, Object currentVersion, SharedSessionContractImplementor session)ObjectAbstractEntityPersister. getCurrentVersion(Object id, SharedSessionContractImplementor session)Retrieve the version numberObjectEntityPersister. getCurrentVersion(Object id, SharedSessionContractImplementor session)Get the current version of the object, or return null if there is no row for the given identifier.Object[]AbstractEntityPersister. getDatabaseSnapshot(Object id, SharedSessionContractImplementor session)Object[]EntityPersister. getDatabaseSnapshot(Object id, SharedSessionContractImplementor session)Get the current database state of the object, in a "hydrated" form, without resolving identifiersIdentifierGeneratorAbstractEntityPersister. getIdentifierGenerator()ObjectEntityPersister. getPropertyValue(Object object, int i)Deprecated.UseEntityPersister.getValue(java.lang.Object, int)insteadObject[]AbstractEntityPersister. getPropertyValuesToInsert(Object entity, Map<Object,Object> mergeMap, SharedSessionContractImplementor session)ObjectEntityPersister. getVersion(Object object)Get the version number (or timestamp) from the object's version property (or return null if not versioned)ObjectAbstractEntityPersister. insert(Object[] fields, boolean[] notNull, String sql, Object object, SharedSessionContractImplementor session)Perform an SQL INSERT, and then retrieve a generated identifier.ObjectAbstractEntityPersister. insert(Object[] fields, Object object, SharedSessionContractImplementor session)voidAbstractEntityPersister. insert(Object id, Object[] fields, boolean[] notNull, int j, String sql, Object object, SharedSessionContractImplementor session)Perform an SQL INSERT.booleanDiscriminatorType. isDirty(Object old, Object current, boolean[] checkable, SharedSessionContractImplementor session)BooleanAbstractEntityPersister. isTransient(Object entity, SharedSessionContractImplementor session)ObjectAbstractEntityPersister. load(Object id, Object optionalObject, LockOptions lockOptions, SharedSessionContractImplementor session)Load an instance using either theforUpdateLoaderor the outer joiningloader, depending upon the value of thelockparameterObjectAbstractEntityPersister. load(Object id, Object optionalObject, LockOptions lockOptions, SharedSessionContractImplementor session, Boolean readOnly)default ObjectEntityPersister. load(Object id, Object optionalObject, LockMode lockMode, SharedSessionContractImplementor session, Boolean readOnly)default ObjectEntityPersister. load(Object id, Object optionalObject, LockOptions lockOptions, SharedSessionContractImplementor session, Boolean readOnly)ObjectAbstractEntityPersister. loadByUniqueKey(String propertyName, Object uniqueKey, Boolean readOnly, SharedSessionContractImplementor session)ObjectAbstractEntityPersister. loadByUniqueKey(String propertyName, Object uniqueKey, SharedSessionContractImplementor session)voidAbstractEntityPersister. lock(Object id, Object version, Object object, LockMode lockMode, SharedSessionContractImplementor session)voidAbstractEntityPersister. lock(Object id, Object version, Object object, LockOptions lockOptions, SharedSessionContractImplementor session)voidDiscriminatorType. nullSafeSet(PreparedStatement st, Object value, int index, boolean[] settable, SharedSessionContractImplementor session)voidDiscriminatorType. nullSafeSet(PreparedStatement st, Object value, int index, SharedSessionContractImplementor session)ObjectDiscriminatorType. replace(Object original, Object target, SharedSessionContractImplementor session, Object owner, Map<Object,Object> copyCache)StringDiscriminatorType. toLoggableString(Object value, SessionFactoryImplementor factory)voidAbstractEntityPersister. update(Object id, Object[] fields, int[] dirtyFields, boolean hasDirtyCollection, Object[] oldFields, Object oldVersion, Object object, Object rowId, SharedSessionContractImplementor session)Update an objectbooleanAbstractEntityPersister. update(Object id, Object[] fields, Object[] oldFields, Object rowId, boolean[] includeProperty, int j, Object oldVersion, Object object, String sql, SharedSessionContractImplementor session)voidAbstractEntityPersister. updateOrInsert(Object id, Object[] fields, Object[] oldFields, Object rowId, boolean[] includeProperty, int j, Object oldVersion, Object object, String sql, SharedSessionContractImplementor session)Perform an SQL UPDATE or SQL INSERT -
Uses of HibernateException in org.hibernate.persister.spi
Subclasses of HibernateException in org.hibernate.persister.spi Modifier and Type Class Description classUnknownPersisterExceptionIndicates that the persister to use is not known and could not be determined.Methods in org.hibernate.persister.spi that throw HibernateException Modifier and Type Method Description EntityPersisterPersisterFactory. createEntityPersister(PersistentClass entityBinding, EntityDataAccess entityCacheAccessStrategy, NaturalIdDataAccess naturalIdCacheAccessStrategy, PersisterCreationContext creationContext) -
Uses of HibernateException in org.hibernate.procedure
Subclasses of HibernateException in org.hibernate.procedure Modifier and Type Class Description classNamedParametersNotSupportedExceptionThrown to indicate that an attempt was made to register a stored procedure named parameter, but the underlying database reports to not support named parameters.classNoSuchParameterExceptionclassParameterMisuseExceptionThrown to indicate a misuse of a parameterclassParameterStrategyException -
Uses of HibernateException in org.hibernate.property.access.spi
Subclasses of HibernateException in org.hibernate.property.access.spi Modifier and Type Class Description classPropertyAccessBuildingExceptionIndicates a problem while building a PropertyAccessclassPropertyAccessExceptionIndicates a problem reading or writing value from/to a persistent property.classPropertyAccessSerializationException -
Uses of HibernateException in org.hibernate.proxy
Methods in org.hibernate.proxy that throw HibernateException Modifier and Type Method Description ObjectAbstractLazyInitializer. getImplementation(SharedSessionContractImplementor s)ObjectLazyInitializer. getImplementation(SharedSessionContractImplementor session)Return the underlying persistent object in the given session, or null if not contained in this session's persistence context.HibernateProxyProxyFactory. getProxy(Object id, SharedSessionContractImplementor session)Create a new proxy instancevoidAbstractLazyInitializer. initialize()voidLazyInitializer. initialize()Initialize the proxy, fetching the target entity if necessary.voidProxyFactory. postInstantiate(String entityName, Class<?> persistentClass, Set<Class<?>> interfaces, Method getIdentifierMethod, Method setIdentifierMethod, CompositeType componentIdType)Called immediately after instantiation of this factory.voidAbstractLazyInitializer. setSession(SharedSessionContractImplementor s)voidLazyInitializer. setSession(SharedSessionContractImplementor session)Associate the proxy with the given session. -
Uses of HibernateException in org.hibernate.proxy.pojo.bytebuddy
Methods in org.hibernate.proxy.pojo.bytebuddy that throw HibernateException Modifier and Type Method Description HibernateProxyByteBuddyProxyFactory. getProxy(Object id, SharedSessionContractImplementor session)voidByteBuddyProxyFactory. postInstantiate(String entityName, Class<?> persistentClass, Set<Class<?>> interfaces, Method getIdentifierMethod, Method setIdentifierMethod, CompositeType componentIdType) -
Uses of HibernateException in org.hibernate.query
Subclasses of HibernateException in org.hibernate.query Modifier and Type Class Description classIllegalMutationQueryExceptionIndicates an attempt to callQueryProducer.createMutationQuery(String),QueryProducer.createNamedMutationQuery(String)orQueryProducer.createNativeMutationQuery(String)with a non-mutation query (generally a select query)classIllegalNamedQueryOptionsExceptionIndicates a named-query has specified options that are not legalclassIllegalQueryOperationExceptionIndicates an attempt to perform some operation on a Query that is illegal based on its state, e.g., attempt to callQuery.executeUpdate()on a SELECT query.classIllegalSelectQueryExceptionIndicates an attempt to callQueryProducer.createSelectionQuery(String)with a non-selection query (generally a mutation query)classNotIndexedCollectionExceptionIndicates an attempt to use a non-indexed collection as indexed.classPathExceptionIndicates an attempt to use a path in an unsupported wayclassQueryTypeMismatchExceptionIndicates a mismatch between a Query's expected and actual result typesclassSemanticExceptionRepresents an error in the semantics (meaning) of the passed query.classUnknownNamedQueryExceptionIndicates a request for a named-query when no query is registered under that nameclassUnknownParameterExceptionIndicates an attempt to find an unknown query parameter or an attempt to bind a value to an unknown query parameterclassUnknownSqlResultSetMappingExceptionIndicates a request for named ResultSet mapping which could not be foundMethods in org.hibernate.query with parameters of type HibernateException Modifier and Type Method Description voidQueryLogging. namedQueryError(String queryName, HibernateException e) -
Uses of HibernateException in org.hibernate.query.hql
Subclasses of HibernateException in org.hibernate.query.hql Modifier and Type Class Description classHqlInterpretationExceptionBase of exception hierarchy for exceptions stemming from producing SQM AST treesMethods in org.hibernate.query.hql with parameters of type HibernateException Modifier and Type Method Description voidHqlLogging. namedQueryError(String queryName, HibernateException e) -
Uses of HibernateException in org.hibernate.query.named
Methods in org.hibernate.query.named that return types with arguments of type HibernateException Modifier and Type Method Description Map<String,HibernateException>NamedObjectRepository. checkNamedQueries(QueryEngine queryPlanCache)Perform a validity check on all named queries -
Uses of HibernateException in org.hibernate.query.results
Subclasses of HibernateException in org.hibernate.query.results Modifier and Type Class Description classMissingSqlSelectionExceptionIndicates that a column defined as part of a SQL ResultSet mapping was not part of the query's ResultSetclassPositionalSelectionsNotAllowedException -
Uses of HibernateException in org.hibernate.query.spi
Methods in org.hibernate.query.spi that throw HibernateException Modifier and Type Method Description intAbstractQuery. executeUpdate() -
Uses of HibernateException in org.hibernate.query.sqm
Subclasses of HibernateException in org.hibernate.query.sqm Modifier and Type Class Description classAliasCollisionExceptionclassInterpretationExceptionRepresents a general uncaught problem performing the interpretation.classLiteralNumberFormatExceptionclassParsingExceptionThe root exception for errors (potential bugs) in the sqm parser code itself, as opposed toSemanticExceptionwhich indicates problems with the query itself.classStrictJpaComplianceViolationIndicates violations of strict JPQL syntax while strict JPQL syntax checking was enabled.classUnknownEntityExceptionIndicates we were not able to resolve a given "path structure" as an entity name.classUnknownPathExceptiontodo (6.0) : account for this in the "exception conversion" handling -
Uses of HibernateException in org.hibernate.query.sqm.sql
Subclasses of HibernateException in org.hibernate.query.sqm.sql Modifier and Type Class Description classConversionExceptionIndicates a problem converting an SQM tree to a SQL AST -
Uses of HibernateException in org.hibernate.query.sqm.tree.from
Subclasses of HibernateException in org.hibernate.query.sqm.tree.from Modifier and Type Class Description static classSqmAttributeJoin.NotJoinableException -
Uses of HibernateException in org.hibernate.resource.transaction
Subclasses of HibernateException in org.hibernate.resource.transaction Modifier and Type Class Description classLocalSynchronizationExceptionWraps an exception thrown from a "local synchronization" (one registered in the SynchronizationRegistry).classNullSynchronizationExceptionIndicates an attempt to register a null synchronization.classTransactionRequiredForJoinExceptionIndicates a call toTransactionCoordinator.explicitJoin()that requires an active transaction where there currently is none. -
Uses of HibernateException in org.hibernate.result
Subclasses of HibernateException in org.hibernate.result Modifier and Type Class Description classNoMoreReturnsException -
Uses of HibernateException in org.hibernate.service
Subclasses of HibernateException in org.hibernate.service Modifier and Type Class Description classNullServiceExceptionclassUnknownServiceExceptionIndicates that an unknown service was requested from the registry.classUnknownUnwrapTypeException -
Uses of HibernateException in org.hibernate.service.spi
Subclasses of HibernateException in org.hibernate.service.spi Modifier and Type Class Description classServiceExceptionIndicates a problem with a service. -
Uses of HibernateException in org.hibernate.sql.ast
Subclasses of HibernateException in org.hibernate.sql.ast Modifier and Type Class Description classSqlTreeCreationExceptionBase exception type for problems building a SQL tree. -
Uses of HibernateException in org.hibernate.sql.ast.tree.from
Subclasses of HibernateException in org.hibernate.sql.ast.tree.from Modifier and Type Class Description classUnknownTableReferenceExceptionThrown when aTableReferencecannot be resolved for a table-name. -
Uses of HibernateException in org.hibernate.sql.exec
Subclasses of HibernateException in org.hibernate.sql.exec Modifier and Type Class Description classExecutionExceptionIndicates an exception performing execution -
Uses of HibernateException in org.hibernate.sql.results
Subclasses of HibernateException in org.hibernate.sql.results Modifier and Type Class Description classDomainResultCreationExceptionBase for problems creatingDomainResultinstancesclassNoMoreOutputsException -
Uses of HibernateException in org.hibernate.tool.schema.extract.spi
Subclasses of HibernateException in org.hibernate.tool.schema.extract.spi Modifier and Type Class Description classSchemaExtractionException -
Uses of HibernateException in org.hibernate.tool.schema.spi
Subclasses of HibernateException in org.hibernate.tool.schema.spi Modifier and Type Class Description classCommandAcceptanceExceptionIndicates a problem accepting/executing a schema management command.classSchemaManagementExceptionIndicates a problem in performing schema management.classSqlScriptExceptionIndicates a problem -
Uses of HibernateException in org.hibernate.tuple.entity
Subclasses of HibernateException in org.hibernate.tuple.entity Modifier and Type Class Description static classEntityMetamodel.ValueGenerationStrategyException -
Uses of HibernateException in org.hibernate.type
Subclasses of HibernateException in org.hibernate.type Modifier and Type Class Description classSerializationExceptionThrown when a property cannot be serialized/deserializedMethods in org.hibernate.type that throw HibernateException Modifier and Type Method Description ObjectAbstractStandardBasicType. assemble(Serializable cached, SharedSessionContractImplementor session, Object owner)ObjectAbstractType. assemble(Serializable cached, SharedSessionContractImplementor session, Object owner)ObjectAnyType. assemble(Serializable cached, SharedSessionContractImplementor session, Object owner)ObjectCollectionType. assemble(Serializable cached, SharedSessionContractImplementor session, Object owner)ObjectComponentType. assemble(Serializable object, SharedSessionContractImplementor session, Object owner)TEnumType. assemble(Serializable cached, Object owner)ObjectManyToOneType. assemble(Serializable oid, SharedSessionContractImplementor session, Object owner)ObjectOneToOneType. assemble(Serializable oid, SharedSessionContractImplementor session, Object owner)ObjectSerializableToBlobType. assemble(Serializable cached, SharedSessionContractImplementor session, Object owner)ObjectSpecialOneToOneType. assemble(Serializable oid, SharedSessionContractImplementor session, Object owner)ObjectType. assemble(Serializable cached, SharedSessionContractImplementor session, Object owner)Reconstruct the object from its disassembled state.ObjectCustomType. deepCopy(Object value, SessionFactoryImplementor factory)TEnumType. deepCopy(T value)ObjectMetaType. deepCopy(Object value, SessionFactoryImplementor factory)ObjectType. deepCopy(Object value, SessionFactoryImplementor factory)Return a deep copy of the persistent state, stopping at entities and at collections.SerializableAbstractStandardBasicType. disassemble(Object value, SharedSessionContractImplementor session, Object owner)SerializableAbstractType. disassemble(Object value, SharedSessionContractImplementor session, Object owner)SerializableAnyType. disassemble(Object value, SharedSessionContractImplementor session, Object owner)SerializableCollectionType. disassemble(Object value, SharedSessionContractImplementor session, Object owner)SerializableComponentType. disassemble(Object value, SharedSessionContractImplementor session, Object owner)SerializableEnumType. disassemble(T value)SerializableManyToOneType. disassemble(Object value, SharedSessionContractImplementor session, Object owner)SerializableOneToOneType. disassemble(Object value, SharedSessionContractImplementor session, Object owner)SerializableSerializableToBlobType. disassemble(Object value, SharedSessionContractImplementor session, Object owner)SerializableSpecialOneToOneType. disassemble(Object value, SharedSessionContractImplementor session, Object owner)SerializableType. disassemble(Object value, SharedSessionContractImplementor session, Object owner)Return a disassembled representation of the object.booleanEnumType. equals(T x, T y)ObjectMetaType. fromXMLString(String xml, Mapping factory)intType. getHashCode(Object x)Get a hash code, consistent with persistence "equality".intType. getHashCode(Object x, SessionFactoryImplementor factory)Get a hash code, consistent with persistence "equality".protected ObjectEntityType. getIdentifier(Object value, SharedSessionContractImplementor session)ObjectAnyType. getPropertyValue(Object component, int i, SharedSessionContractImplementor session)ObjectComponentType. getPropertyValue(Object component, int i, SharedSessionContractImplementor session)ObjectCompositeType. getPropertyValue(Object component, int index, SharedSessionContractImplementor session)Extract a particular component property value indicated by index.Object[]AnyType. getPropertyValues(Object component, SharedSessionContractImplementor session)Object[]CompositeType. getPropertyValues(Object component)Extract the values of the component properties from the given component instance without access to the session.Object[]CompositeType. getPropertyValues(Object component, SharedSessionContractImplementor session)Extract the values of the component properties from the given component instanceintEnumType. hashCode(T x)PersistentCollection<?>ArrayType. instantiate(SharedSessionContractImplementor session, CollectionPersister persister, Object key)PersistentCollection<?>BagType. instantiate(SharedSessionContractImplementor session, CollectionPersister persister, Object key)PersistentCollection<?>CustomCollectionType. instantiate(SharedSessionContractImplementor session, CollectionPersister persister, Object key)PersistentCollection<?>IdentifierBagType. instantiate(SharedSessionContractImplementor session, CollectionPersister persister, Object key)booleanAbstractType. isDirty(Object old, Object current, SharedSessionContractImplementor session)booleanAnyType. isDirty(Object old, Object current, boolean[] checkable, SharedSessionContractImplementor session)booleanCollectionType. isDirty(Object old, Object current, boolean[] checkable, SharedSessionContractImplementor session)booleanCollectionType. isDirty(Object old, Object current, SharedSessionContractImplementor session)booleanComponentType. isDirty(Object x, Object y, boolean[] checkable, SharedSessionContractImplementor session)booleanComponentType. isDirty(Object x, Object y, SharedSessionContractImplementor session)booleanCustomType. isDirty(Object old, Object current, boolean[] checkable, SharedSessionContractImplementor session)booleanManyToOneType. isDirty(Object old, Object current, boolean[] checkable, SharedSessionContractImplementor session)booleanManyToOneType. isDirty(Object old, Object current, SharedSessionContractImplementor session)booleanMetaType. isDirty(Object old, Object current, boolean[] checkable, SharedSessionContractImplementor session)booleanType. isDirty(Object oldState, Object currentState, boolean[] checkable, SharedSessionContractImplementor session)Should the parent be considered dirty, given both the old and current value?booleanType. isDirty(Object old, Object current, SharedSessionContractImplementor session)Should the parent be considered dirty, given both the old and current value?booleanComponentType. isEqual(Object x, Object y)booleanComponentType. isEqual(Object x, Object y, SessionFactoryImplementor factory)booleanCustomType. isEqual(Object x, Object y)booleanType. isEqual(Object x, Object y)Compare two instances of the class mapped by this type for persistence "equality" (equality of persistent state).booleanType. isEqual(Object x, Object y, SessionFactoryImplementor factory)Compare two instances of the class mapped by this type for persistence "equality" (equality of persistent state).booleanAbstractType. isModified(Object old, Object current, boolean[] checkable, SharedSessionContractImplementor session)booleanAnyType. isModified(Object old, Object current, boolean[] checkable, SharedSessionContractImplementor session)booleanComponentType. isModified(Object old, Object current, boolean[] checkable, SharedSessionContractImplementor session)booleanManyToOneType. isModified(Object old, Object current, boolean[] checkable, SharedSessionContractImplementor session)booleanType. isModified(Object dbState, Object currentState, boolean[] checkable, SharedSessionContractImplementor session)Has the value been modified compared to the current database state? The difference between this and theType.isDirty(java.lang.Object, java.lang.Object, org.hibernate.engine.spi.SharedSessionContractImplementor)methods is that here we need to account for "partially" built values.booleanAbstractType. isSame(Object x, Object y)booleanAnyType. isSame(Object x, Object y)booleanComponentType. isSame(Object x, Object y)booleanType. isSame(Object x, Object y)Compare two instances of the class mapped by this type for persistence "equality" (equality of persistent state) taking a shortcut for entity references.ObjectEntityType. loadByUniqueKey(String entityName, String uniqueKeyPropertyName, Object key, SharedSessionContractImplementor session)Load an instance by a unique key that is not the primary key.voidAbstractSingleColumnStandardBasicType. nullSafeSet(PreparedStatement st, Object value, int index, boolean[] settable, SharedSessionContractImplementor session)voidAnyType. nullSafeSet(PreparedStatement st, Object value, int index, boolean[] settable, SharedSessionContractImplementor session)voidAnyType. nullSafeSet(PreparedStatement st, Object value, int index, SharedSessionContractImplementor session)voidCollectionType. nullSafeSet(PreparedStatement st, Object value, int index, boolean[] settable, SharedSessionContractImplementor session)voidCollectionType. nullSafeSet(PreparedStatement st, Object value, int index, SharedSessionContractImplementor session)voidComponentType. nullSafeSet(PreparedStatement st, Object value, int begin, boolean[] settable, SharedSessionContractImplementor session)voidComponentType. nullSafeSet(PreparedStatement st, Object value, int begin, SharedSessionContractImplementor session)voidEnumType. nullSafeSet(PreparedStatement st, T value, int index, SharedSessionContractImplementor session)voidMetaType. nullSafeSet(PreparedStatement st, Object value, int index, boolean[] settable, SharedSessionContractImplementor session)voidMetaType. nullSafeSet(PreparedStatement st, Object value, int index, SharedSessionContractImplementor session)voidSerializableToBlobType. nullSafeSet(PreparedStatement st, Object value, int index, boolean[] settable, SharedSessionContractImplementor session)voidType. nullSafeSet(PreparedStatement st, Object value, int index, boolean[] settable, SharedSessionContractImplementor session)Bind a value represented by an instance of themapped classto the JDBC prepared statement, ignoring some columns as dictated by the 'settable' parameter.voidType. nullSafeSet(PreparedStatement st, Object value, int index, SharedSessionContractImplementor session)Bind a value represented by an instance of themapped classto the JDBC prepared statement.protected StringCollectionType. renderLoggableString(Object value, SessionFactoryImplementor factory)protected StringCustomCollectionType. renderLoggableString(Object value, SessionFactoryImplementor factory)ObjectAbstractType. replace(Object original, Object target, SharedSessionContractImplementor session, Object owner, Map<Object,Object> copyCache, ForeignKeyDirection foreignKeyDirection)ObjectAnyType. replace(Object original, Object target, SharedSessionContractImplementor session, Object owner, Map<Object,Object> copyCache)ObjectCollectionType. replace(Object original, Object target, SharedSessionContractImplementor session, Object owner, Map<Object,Object> copyCache)ObjectCustomType. replace(Object original, Object target, SharedSessionContractImplementor session, Object owner, Map<Object,Object> copyCache)ObjectEntityType. replace(Object original, Object target, SharedSessionContractImplementor session, Object owner, Map<Object,Object> copyCache)TEnumType. replace(T original, T target, Object owner)ObjectType. replace(Object original, Object target, SharedSessionContractImplementor session, Object owner, Map<Object,Object> copyCache)During merge, replace the existing (target) value in the entity we are merging to with a new (original) value from the detached entity we are merging.ObjectType. replace(Object original, Object target, SharedSessionContractImplementor session, Object owner, Map<Object,Object> copyCache, ForeignKeyDirection foreignKeyDirection)During merge, replace the existing (target) value in the entity we are merging to with a new (original) value from the detached entity we are merging.ObjectArrayType. replaceElements(Object original, Object target, Object owner, Map copyCache, SharedSessionContractImplementor session)ObjectCustomCollectionType. replaceElements(Object original, Object target, Object owner, Map copyCache, SharedSessionContractImplementor session)ObjectMapType. replaceElements(Object original, Object target, Object owner, Map copyCache, SharedSessionContractImplementor session)protected ObjectEntityType. resolveIdentifier(Object id, SharedSessionContractImplementor session)protected ObjectEntityType. resolveIdentifier(Object id, SharedSessionContractImplementor session, Boolean overridingEager)Resolve an identifier via a load.voidCompositeType. setPropertyValues(Object component, Object[] values)Inject property values onto the given component instanceStringAnyType. toLoggableString(Object value, SessionFactoryImplementor factory)StringArrayType. toLoggableString(Object value, SessionFactoryImplementor factory)StringCollectionType. toLoggableString(Object value, SessionFactoryImplementor factory)StringComponentType. toLoggableString(Object value, SessionFactoryImplementor factory)StringMetaType. toLoggableString(Object value, SessionFactoryImplementor factory)StringType. toLoggableString(Object value, SessionFactoryImplementor factory)Generate a representation of the value for logging purposes.StringMetaType. toXMLString(Object value, SessionFactoryImplementor factory) -
Uses of HibernateException in org.hibernate.type.descriptor.java
Subclasses of HibernateException in org.hibernate.type.descriptor.java Modifier and Type Class Description classCoercionExceptionMethods in org.hibernate.type.descriptor.java that return HibernateException Modifier and Type Method Description protected HibernateExceptionAbstractClassJavaType. unknownUnwrap(Class<?> conversionType)protected HibernateExceptionAbstractJavaType. unknownUnwrap(Class<?> conversionType)protected static <T extends JavaType<?>>
HibernateExceptionJavaTypeHelper. unknownUnwrap(Class<?> sourceType, Class<?> targetType, T jtd)protected HibernateExceptionAbstractClassJavaType. unknownWrap(Class<?> conversionType)protected HibernateExceptionAbstractJavaType. unknownWrap(Class<?> conversionType)protected static <T extends JavaType<?>>
HibernateExceptionJavaTypeHelper. unknownWrap(Class<?> valueType, Class<?> sourceType, T jtd) -
Uses of HibernateException in org.hibernate.type.descriptor.java.spi
Subclasses of HibernateException in org.hibernate.type.descriptor.java.spi Modifier and Type Class Description classJdbcTypeRecommendationExceptionException indicatingJavaType.getRecommendedJdbcType(org.hibernate.type.descriptor.jdbc.JdbcTypeIndicators)could not determine a recommended JDBC type descriptor -
Uses of HibernateException in org.hibernate.usertype
Methods in org.hibernate.usertype that throw HibernateException Modifier and Type Method Description TBaseUserTypeSupport. assemble(Serializable cached, Object owner)TStaticUserTypeSupport. assemble(Serializable cached, Object owner)TBaseUserTypeSupport. deepCopy(T value)TStaticUserTypeSupport. deepCopy(T value)SerializableBaseUserTypeSupport. disassemble(T value)SerializableStaticUserTypeSupport. disassemble(T value)booleanBaseUserTypeSupport. equals(T x, T y)booleanStaticUserTypeSupport. equals(T x, T y)JEnhancedUserType. fromStringValue(CharSequence sequence)Consume the given string representation back into this types java form.ObjectCompositeUserType. getPropertyValue(J component, int property)Get the value of a property.intBaseUserTypeSupport. hashCode(T x)intStaticUserTypeSupport. hashCode(T x)PersistentCollection<?>UserCollectionType. instantiate(SharedSessionContractImplementor session, CollectionPersister persister)Instantiate an uninitialized instance of the collection wrapperTBaseUserTypeSupport. replace(T original, T target, Object owner)TStaticUserTypeSupport. replace(T original, T target, Object owner)ObjectUserCollectionType. replaceElements(Object original, Object target, CollectionPersister persister, Object owner, Map copyCache, SharedSessionContractImplementor session)Replace the elements of a collection with the elements of another collectionStringEnhancedUserType. toString(J value)Render the value to the string representation.
-