Uses of Interface
org.hibernate.sql.ast.tree.expression.Expression
-
Packages that use Expression Package Description org.hibernate.dialect This package abstracts over the multifarious dialects of SQL understood by the databases supported by Hibernate.org.hibernate.dialect.aggregate Support forDialect-specific aggregate column types, including user-defined composite types, and JSON or XML types.org.hibernate.dialect.function Contains implementations ofSqmFunctionDescriptordescribing a range of relatively-sophisticated SQL functions available in various dialects.org.hibernate.dialect.function.array org.hibernate.internal An internal package containing implementations of central Hibernate APIs, mostly defined inorg.hibernate.org.hibernate.loader.ast.internal org.hibernate.metamodel.mapping Defines the runtime mapping metamodel, which describes the mapping of the application's domain model parts (entities, attributes) to relational database objects (tables, columns).org.hibernate.metamodel.mapping.internal org.hibernate.metamodel.mapping.ordering.ast org.hibernate.persister.internal Built-in implementation of the SPI for integrating entity and collection persisters.org.hibernate.query.results Support for defining result set mappings used inNativeQuery,ProcedureCall, andStoredProcedureQuery.org.hibernate.query.sqm.function An SPI for defining, registering, and rendering functions in HQL.org.hibernate.query.sqm.internal Package for the SQM-backed Query implementation detailsorg.hibernate.query.sqm.mutation.internal org.hibernate.query.sqm.mutation.internal.cte org.hibernate.query.sqm.mutation.internal.inline org.hibernate.query.sqm.mutation.internal.temptable Support for multi-table SQM mutation (insert, update, delete) operations using a table to temporarily hold the matching ids.org.hibernate.query.sqm.sql Package for the translation of SQM into SQL ASTorg.hibernate.query.sqm.sql.internal org.hibernate.query.sqm.tree.expression Nodes representing expressions in the SQM tree.org.hibernate.sql.ast.spi Package defining support for creating and consuming a SQL AST.org.hibernate.sql.ast.tree.cte Support for common table expressions (CTE) in a SQL tree.org.hibernate.sql.ast.tree.expression AST nodes representing expressions in a SQL tree.org.hibernate.sql.ast.tree.from AST nodes representing root tables and joins in a SQL tree.org.hibernate.sql.ast.tree.insert AST nodes representinginsertstatements in a SQL tree.org.hibernate.sql.ast.tree.predicate AST nodes representing logical predicates in a SQL tree.org.hibernate.sql.ast.tree.select AST nodes representingselectstatements in a SQL tree.org.hibernate.sql.ast.tree.update AST nodes representingupdatestatements in a SQL tree.org.hibernate.sql.exec.internal Implementation of the SPI for execution of SQL statements via JDBC.org.hibernate.sql.model.ast SQL AST extensions for model mutations.org.hibernate.sql.results.internal org.hibernate.type.descriptor.jdbc Defines handling of almost the full range of standard JDBC-defined SQL data types. -
-
Uses of Expression in org.hibernate.dialect
Methods in org.hibernate.dialect that return Expression Modifier and Type Method Description protected ExpressionSybaseSqmToSqlAstConverter. resolveGroupOrOrderByExpression(SqmExpression<?> groupByClauseExpression)ExpressionPostgreSQLCastingIntervalSecondJdbcType. wrapTopLevelSelectionExpression(Expression expression)Methods in org.hibernate.dialect with parameters of type Expression Modifier and Type Method Description protected voidDB2iSqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidDB2SqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidDB2zSqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidDerbySqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidHANASqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidHSQLSqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidMariaDBSqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidMySQLSqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidOracleSqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidPostgreSQLSqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidSpannerSqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidSQLServerSqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidSybaseASESqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidSybaseSqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidTiDBSqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidDB2SqlAstTranslator. renderComparisonStandard(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidCockroachSqlAstTranslator. renderExpressionAsClauseItem(Expression expression)protected voidDB2SqlAstTranslator. renderExpressionAsClauseItem(Expression expression)protected voidDerbySqlAstTranslator. renderExpressionAsClauseItem(Expression expression)protected voidH2SqlAstTranslator. renderExpressionAsClauseItem(Expression expression)protected voidHSQLSqlAstTranslator. renderExpressionAsClauseItem(Expression expression)protected voidMariaDBSqlAstTranslator. renderExpressionAsClauseItem(Expression expression)protected voidMySQLSqlAstTranslator. renderExpressionAsClauseItem(Expression expression)protected voidPostgreSQLSqlAstTranslator. renderExpressionAsClauseItem(Expression expression)protected voidTiDBSqlAstTranslator. renderExpressionAsClauseItem(Expression expression)protected voidDB2SqlAstTranslator. renderFetchExpression(Expression fetchExpression)protected voidDerbySqlAstTranslator. renderFetchExpression(Expression fetchExpression)protected voidSybaseASESqlAstTranslator. renderFetchExpression(Expression fetchExpression)protected voidSybaseASESqlAstTranslator. renderFetchPlusOffsetExpression(Expression fetchClauseExpression, Expression offsetClauseExpression, int offset)protected voidDB2SqlAstTranslator. renderOffsetExpression(Expression offsetExpression)protected voidDerbySqlAstTranslator. renderOffsetExpression(Expression offsetExpression)protected voidSybaseASESqlAstTranslator. renderOffsetExpression(Expression offsetExpression)protected voidCockroachSqlAstTranslator. renderPartitionItem(Expression expression)protected voidDerbySqlAstTranslator. renderPartitionItem(Expression expression)protected voidH2SqlAstTranslator. renderPartitionItem(Expression expression)protected voidHANASqlAstTranslator. renderPartitionItem(Expression expression)protected voidHSQLSqlAstTranslator. renderPartitionItem(Expression expression)protected voidMariaDBSqlAstTranslator. renderPartitionItem(Expression expression)protected voidMySQLSqlAstTranslator. renderPartitionItem(Expression expression)protected voidOracleSqlAstTranslator. renderPartitionItem(Expression expression)protected voidPostgreSQLSqlAstTranslator. renderPartitionItem(Expression expression)protected voidSpannerSqlAstTranslator. renderPartitionItem(Expression expression)protected voidSQLServerSqlAstTranslator. renderPartitionItem(Expression expression)protected voidSybaseASESqlAstTranslator. renderPartitionItem(Expression expression)protected voidSybaseSqlAstTranslator. renderPartitionItem(Expression expression)protected voidTiDBSqlAstTranslator. renderPartitionItem(Expression expression)protected voidDB2SqlAstTranslator. renderSelectExpression(Expression expression)protected voidDerbySqlAstTranslator. renderSelectExpression(Expression expression)protected voidHSQLSqlAstTranslator. renderSelectExpression(Expression expression)protected voidMariaDBSqlAstTranslator. renderStringContainsExactlyPredicate(Expression haystack, Expression needle)protected voidMySQLSqlAstTranslator. renderStringContainsExactlyPredicate(Expression haystack, Expression needle)protected voidSQLServerSqlAstTranslator. renderStringContainsExactlyPredicate(Expression haystack, Expression needle)protected voidTiDBSqlAstTranslator. renderStringContainsExactlyPredicate(Expression haystack, Expression needle)protected voidDB2SqlAstTranslator. visitArithmeticOperand(Expression expression)protected voidDerbySqlAstTranslator. visitArithmeticOperand(Expression expression)protected voidH2SqlAstTranslator. visitArithmeticOperand(Expression expression)protected voidHANASqlAstTranslator. visitArithmeticOperand(Expression expression)protected voidHSQLSqlAstTranslator. visitArithmeticOperand(Expression expression)protected voidHSQLSqlAstTranslator. visitRecursivePath(Expression recursivePath, int sizeEstimate)protected voidMariaDBSqlAstTranslator. visitRecursivePath(Expression recursivePath, int sizeEstimate)protected voidMySQLSqlAstTranslator. visitRecursivePath(Expression recursivePath, int sizeEstimate)ExpressionPostgreSQLCastingIntervalSecondJdbcType. wrapTopLevelSelectionExpression(Expression expression)Method parameters in org.hibernate.dialect with type arguments of type Expression Modifier and Type Method Description protected voidDB2SqlAstTranslator. visitAnsiCaseSearchedExpression(CaseSearchedExpression caseSearchedExpression, Consumer<Expression> resultRenderer)protected voidDerbySqlAstTranslator. visitAnsiCaseSearchedExpression(CaseSearchedExpression caseSearchedExpression, Consumer<Expression> resultRenderer)protected voidHSQLSqlAstTranslator. visitAnsiCaseSearchedExpression(CaseSearchedExpression expression, Consumer<Expression> resultRenderer)protected voidSybaseASESqlAstTranslator. visitAnsiCaseSearchedExpression(CaseSearchedExpression caseSearchedExpression, Consumer<Expression> resultRenderer)protected voidSybaseSqlAstTranslator. visitAnsiCaseSearchedExpression(CaseSearchedExpression caseSearchedExpression, Consumer<Expression> resultRenderer)protected voidDB2SqlAstTranslator. visitAnsiCaseSimpleExpression(CaseSimpleExpression caseSimpleExpression, Consumer<Expression> resultRenderer)protected voidDerbySqlAstTranslator. visitAnsiCaseSimpleExpression(CaseSimpleExpression caseSimpleExpression, Consumer<Expression> resultRenderer)protected voidHSQLSqlAstTranslator. visitAnsiCaseSimpleExpression(CaseSimpleExpression expression, Consumer<Expression> resultRenderer)protected voidSybaseASESqlAstTranslator. visitAnsiCaseSimpleExpression(CaseSimpleExpression caseSimpleExpression, Consumer<Expression> resultRenderer)protected voidSybaseSqlAstTranslator. visitAnsiCaseSimpleExpression(CaseSimpleExpression caseSimpleExpression, Consumer<Expression> resultRenderer) -
Uses of Expression in org.hibernate.dialect.aggregate
Methods in org.hibernate.dialect.aggregate that return Expression Modifier and Type Method Description ExpressionAggregateSupport.AggregateColumnWriteExpression. getValueExpression(SelectableMapping selectableMapping)Returns the value expression to assign to the given selectable mapping, or throws anIllegalArgumentExceptionwhen an invalid selectable mapping is passed. -
Uses of Expression in org.hibernate.dialect.function
Methods in org.hibernate.dialect.function that return Expression Modifier and Type Method Description ExpressionFormatFunction.FormatSqmFunction. convertToSqlAst(SqmToSqlAstConverter walker) -
Uses of Expression in org.hibernate.dialect.function.array
Methods in org.hibernate.dialect.function.array with parameters of type Expression Modifier and Type Method Description static booleanArrayHelper. isNullable(Expression expression) -
Uses of Expression in org.hibernate.internal
Classes in org.hibernate.internal that implement Expression Modifier and Type Class Description classFilterJdbcParameter -
Uses of Expression in org.hibernate.loader.ast.internal
Methods in org.hibernate.loader.ast.internal that return Expression Modifier and Type Method Description protected ExpressionAbstractNaturalIdLoader. resolveColumnReference(TableGroup rootTableGroup, SelectableMapping selectableMapping, SqlExpressionResolver sqlExpressionResolver, SessionFactoryImplementor sessionFactory)Helper to resolve ColumnReferences -
Uses of Expression in org.hibernate.metamodel.mapping
Methods in org.hibernate.metamodel.mapping that return Expression Modifier and Type Method Description ExpressionDiscriminatorMapping. resolveSqlExpression(NavigablePath navigablePath, JdbcMapping jdbcMappingToUse, TableGroup tableGroup, SqlAstCreationState creationState)Create the appropriate SQL expression for this discriminator -
Uses of Expression in org.hibernate.metamodel.mapping.internal
Classes in org.hibernate.metamodel.mapping.internal that implement Expression Modifier and Type Class Description classCaseStatementDiscriminatorMappingImpl.CaseStatementDiscriminatorExpressionMethods in org.hibernate.metamodel.mapping.internal that return Expression Modifier and Type Method Description static ExpressionMappingModelCreationHelper. buildColumnReferenceExpression(TableGroup tableGroup, ModelPart modelPart, SqlExpressionResolver sqlExpressionResolver, SessionFactoryImplementor sessionFactory)ExpressionAbstractDomainPath. resolve(ModelPart referenceModelPart, QuerySpec ast, TableGroup tableGroup, String modelPartName, SqlAstCreationState creationState)ExpressionAnyDiscriminatorPart. resolveSqlExpression(NavigablePath navigablePath, JdbcMapping jdbcMappingToUse, TableGroup tableGroup, SqlAstCreationState creationState)ExpressionCaseStatementDiscriminatorMappingImpl. resolveSqlExpression(NavigablePath navigablePath, JdbcMapping jdbcMappingToUse, TableGroup tableGroup, SqlAstCreationState creationState)ExpressionExplicitColumnDiscriminatorMappingImpl. resolveSqlExpression(NavigablePath navigablePath, JdbcMapping jdbcMappingToUse, TableGroup tableGroup, SqlAstCreationState creationState) -
Uses of Expression in org.hibernate.metamodel.mapping.ordering.ast
Classes in org.hibernate.metamodel.mapping.ordering.ast that implement Expression Modifier and Type Class Description classSelfRenderingOrderingExpressionRepresents a self rendering expression i.e.Methods in org.hibernate.metamodel.mapping.ordering.ast that return Expression Modifier and Type Method Description static ExpressionOrderingExpression. applyCollation(Expression expression, String collation, SqlAstCreationState creationState)ExpressionColumnReference. resolve(QuerySpec ast, TableGroup tableGroup, String modelPartName, SqlAstCreationState creationState)ExpressionSelfRenderingOrderingExpression. resolve(QuerySpec ast, TableGroup tableGroup, String modelPartName, SqlAstCreationState creationState)Methods in org.hibernate.metamodel.mapping.ordering.ast with parameters of type Expression Modifier and Type Method Description static ExpressionOrderingExpression. applyCollation(Expression expression, String collation, SqlAstCreationState creationState) -
Uses of Expression in org.hibernate.persister.internal
Classes in org.hibernate.persister.internal that implement Expression Modifier and Type Class Description classSqlFragmentPredicatePredicate based on a SQL fragment -
Uses of Expression in org.hibernate.query.results
Classes in org.hibernate.query.results that implement Expression Modifier and Type Class Description classResultSetMappingSqlSelectionSqlSelection used inResultSetMappingresolution.classTableGroupImplA TableGroup created with regards to a SQL ResultSet mappingMethods in org.hibernate.query.results that return Expression Modifier and Type Method Description ExpressionResultSetMappingSqlSelection. getExpression()ExpressionResultSetMappingSqlSelection. getSqlExpression()ExpressionDomainResultCreationStateImpl. resolveSqlExpression(SqlExpressionResolver.ColumnReferenceKey key, Function<SqlAstProcessingState,Expression> creator)static ExpressionResultsHelper. resolveSqlExpression(DomainResultCreationStateImpl resolver, TableReference tableReference, SelectableMapping selectableMapping, int valuesArrayPosition)static ExpressionResultsHelper. resolveSqlExpression(DomainResultCreationStateImpl resolver, JdbcValuesMetadata jdbcValuesMetadata, TableReference tableReference, SelectableMapping selectableMapping, String columnAlias)Methods in org.hibernate.query.results with parameters of type Expression Modifier and Type Method Description SqlSelectionDomainResultCreationStateImpl. resolveSqlSelection(Expression expression, JavaType<?> javaType, FetchParent fetchParent, TypeConfiguration typeConfiguration)Method parameters in org.hibernate.query.results with type arguments of type Expression Modifier and Type Method Description ExpressionDomainResultCreationStateImpl. resolveSqlExpression(SqlExpressionResolver.ColumnReferenceKey key, Function<SqlAstProcessingState,Expression> creator) -
Uses of Expression in org.hibernate.query.sqm.function
Classes in org.hibernate.query.sqm.function that implement Expression Modifier and Type Class Description classSelfRenderingAggregateFunctionSqlAstExpressionRepresentation of an aggregate function call in the SQL AST for impls that know how to render themselves.classSelfRenderingFunctionSqlAstExpressionRepresentation of a function call in the SQL AST for impls that know how to render themselves.classSelfRenderingOrderedSetAggregateFunctionSqlAstExpressionRepresentation of an aggregate function call in the SQL AST for impls that know how to render themselves.classSelfRenderingWindowFunctionSqlAstExpressionRepresentation of a window function call in the SQL AST for impls that know how to render themselves.Methods in org.hibernate.query.sqm.function that return Expression Modifier and Type Method Description ExpressionSelfRenderingSqmAggregateFunction. convertToSqlAst(SqmToSqlAstConverter walker)ExpressionSelfRenderingSqmFunction. convertToSqlAst(SqmToSqlAstConverter walker)ExpressionSelfRenderingSqmOrderedSetAggregateFunction. convertToSqlAst(SqmToSqlAstConverter walker)ExpressionSelfRenderingSqmWindowFunction. convertToSqlAst(SqmToSqlAstConverter walker) -
Uses of Expression in org.hibernate.query.sqm.internal
Methods in org.hibernate.query.sqm.internal with parameters of type Expression Modifier and Type Method Description protected static intConcreteSqmSelectQueryPlan. interpretIntExpression(Expression expression, JdbcParameterBindings jdbcParameterBindings) -
Uses of Expression in org.hibernate.query.sqm.mutation.internal
Classes in org.hibernate.query.sqm.mutation.internal that implement Expression Modifier and Type Class Description classExpressionDomainResultProducerA wrapper around a basicExpressionthat produces aBasicResultas domain result.Methods in org.hibernate.query.sqm.mutation.internal that return Expression Modifier and Type Method Description ExpressionSelectableMappingExpressionConverter. apply(SemanticQueryWalker semanticQueryWalker)ExpressionTableKeyExpressionCollector. buildKeyExpression()static ExpressionSqmInsertStrategyHelper. createRowNumberingExpression(QuerySpec querySpec, SessionFactoryImplementor sessionFactory)Creates a row numbering expression, that can be added to the select clause of the query spec.Constructors in org.hibernate.query.sqm.mutation.internal with parameters of type Expression Constructor Description ExpressionDomainResultProducer(Expression expression) -
Uses of Expression in org.hibernate.query.sqm.mutation.internal.cte
Methods in org.hibernate.query.sqm.mutation.internal.cte that return Expression Modifier and Type Method Description protected ExpressionAbstractCteMutationHandler. createCountStar(SessionFactoryImplementor factory, MultiTableSqmMutationConverter sqmConverter)Used by Hibernate Reactiveprotected ExpressionCteInsertHandler. createCountStar(SessionFactoryImplementor factory, MultiTableSqmMutationConverter sqmConverter)Method parameters in org.hibernate.query.sqm.mutation.internal.cte with type arguments of type Expression Modifier and Type Method Description protected PredicateAbstractCteMutationHandler. createIdSubQueryPredicate(List<? extends Expression> lhsExpressions, CteStatement idSelectCte, SessionFactoryImplementor factory)protected PredicateAbstractCteMutationHandler. createIdSubQueryPredicate(List<? extends Expression> lhsExpressions, CteStatement idSelectCte, ModelPart fkModelPart, SessionFactoryImplementor factory) -
Uses of Expression in org.hibernate.query.sqm.mutation.internal.inline
Methods in org.hibernate.query.sqm.mutation.internal.inline that return types with arguments of type Expression Modifier and Type Method Description List<Expression>InPredicateRestrictionProducer. produceIdExpressionList(List<Object> idsAndFks, EntityMappingType entityDescriptor)List<Expression>MatchingIdRestrictionProducer. produceIdExpressionList(List<Object> idsAndFks, EntityMappingType entityDescriptor)Produces a list of expression for which a restriction can be produced per-table.Method parameters in org.hibernate.query.sqm.mutation.internal.inline with type arguments of type Expression Modifier and Type Method Description InListPredicateInPredicateRestrictionProducer. produceRestriction(List<Expression> matchingIdValueExpressions, EntityMappingType entityDescriptor, int valueIndex, ModelPart valueModelPart, TableReference mutatingTableReference, Supplier<Consumer<SelectableConsumer>> columnsToMatchVisitationSupplier, ExecutionContext executionContext)PredicateMatchingIdRestrictionProducer. produceRestriction(List<Expression> idExpressions, EntityMappingType entityDescriptor, int valueIndex, ModelPart valueModelPart, TableReference mutatingTableReference, Supplier<Consumer<SelectableConsumer>> columnsToMatchVisitationSupplier, ExecutionContext executionContext)Produce the restriction predicate -
Uses of Expression in org.hibernate.query.sqm.mutation.internal.temptable
Methods in org.hibernate.query.sqm.mutation.internal.temptable that return Expression Modifier and Type Method Description protected ExpressionUpdateExecutionDelegate. asExpression(SelectClause selectClause)protected ExpressionUpdateExecutionDelegate. resolveMutatingTableKeyExpression(String tableExpression, Supplier<Consumer<SelectableConsumer>> tableKeyColumnVisitationSupplier) -
Uses of Expression in org.hibernate.query.sqm.sql
Methods in org.hibernate.query.sqm.sql that return types with arguments of type Expression Modifier and Type Method Description List<Expression>BaseSqmToSqlAstConverter. expandSelfRenderingFunctionMultiValueParameter(SqmParameter<?> sqmParameter)List<Expression>FakeSqmToSqlAstConverter. expandSelfRenderingFunctionMultiValueParameter(SqmParameter<?> sqmParameter)List<Expression>SqmToSqlAstConverter. expandSelfRenderingFunctionMultiValueParameter(SqmParameter<?> sqmParameter)List<Expression>BaseSqmToSqlAstConverter. visitGroupByClause(List<SqmExpression<?>> groupByClauseExpressions)Methods in org.hibernate.query.sqm.sql with parameters of type Expression Modifier and Type Method Description SqlSelectionBaseSqmToSqlAstConverter.DelegatingSqmAliasedNodeCollector. resolveSqlSelection(Expression expression, JavaType<?> javaType, FetchParent fetchParent, TypeConfiguration typeConfiguration)SqlSelectionBaseSqmToSqlAstConverter.SqmAliasedNodePositionTracker. resolveSqlSelection(Expression expression, JavaType<?> javaType, FetchParent fetchParent, TypeConfiguration typeConfiguration)Method parameters in org.hibernate.query.sqm.sql with type arguments of type Expression Modifier and Type Method Description ExpressionBaseSqmToSqlAstConverter.DelegatingSqmAliasedNodeCollector. resolveSqlExpression(SqlExpressionResolver.ColumnReferenceKey key, Function<SqlAstProcessingState,Expression> creator)ExpressionBaseSqmToSqlAstConverter.SqmAliasedNodePositionTracker. resolveSqlExpression(SqlExpressionResolver.ColumnReferenceKey key, Function<SqlAstProcessingState,Expression> creator)Constructors in org.hibernate.query.sqm.sql with parameters of type Expression Constructor Description AdditionalInsertValues(Expression versionExpression, Expression discriminatorExpression, Generator identifierGenerator, BasicEntityIdentifierMapping identifierMapping) -
Uses of Expression in org.hibernate.query.sqm.sql.internal
Subinterfaces of Expression in org.hibernate.query.sqm.sql.internal Modifier and Type Interface Description interfaceSqmPathInterpretation<T>Interpretation of aSqmPathas part of the translation to SQL AST.Classes in org.hibernate.query.sqm.sql.internal that implement Expression Modifier and Type Class Description classAbstractSqmPathInterpretation<T>classAnyDiscriminatorPathInterpretation<T>classAsWrappedExpression<B>classBasicValuedPathInterpretation<T>classDiscriminatedAssociationPathInterpretation<T>SqmPathInterpretation for discriminated association (ANY) mappingsclassDiscriminatorPathInterpretation<T>SqmPathInterpretation and DomainResultProducer implementation for entity discriminatorclassEmbeddableValuedExpression<T>A computed expression that produces an embeddable valued model part.classEmbeddableValuedPathInterpretation<T>classEntityValuedPathInterpretation<T>classNonAggregatedCompositeValuedPathInterpretation<T>classPluralValuedSimplePathInterpretation<T>classSqmParameterInterpretationMethods in org.hibernate.query.sqm.sql.internal that return Expression Modifier and Type Method Description static <T> ExpressionEmbeddableValuedPathInterpretation. from(SqmEmbeddedValuedSimplePath<T> sqmPath, SqmToSqlAstConverter sqlAstCreationState, boolean jpaQueryComplianceEnabled)Static factoryExpressionSqmParameterInterpretation. getResolvedExpression()ExpressionBasicValuedPathInterpretation. getSqlExpression()ExpressionEntityValuedPathInterpretation. getSqlExpression()ExpressionPluralValuedSimplePathInterpretation. getSqlExpression()default ExpressionSqmPathInterpretation. getSqlExpression()ExpressionSqlAstProcessingStateImpl. resolveSqlExpression(SqlExpressionResolver.ColumnReferenceKey key, Function<SqlAstProcessingState,Expression> creator)Methods in org.hibernate.query.sqm.sql.internal with parameters of type Expression Modifier and Type Method Description SqlSelectionSqlAstProcessingStateImpl. resolveSqlSelection(Expression expression, JavaType<?> javaType, FetchParent fetchParent, TypeConfiguration typeConfiguration)SqlSelectionSqlAstQueryPartProcessingStateImpl. resolveSqlSelection(Expression expression, JavaType<?> javaType, FetchParent fetchParent, TypeConfiguration typeConfiguration)Method parameters in org.hibernate.query.sqm.sql.internal with type arguments of type Expression Modifier and Type Method Description ExpressionSqlAstProcessingStateImpl. resolveSqlExpression(SqlExpressionResolver.ColumnReferenceKey key, Function<SqlAstProcessingState,Expression> creator)Constructors in org.hibernate.query.sqm.sql.internal with parameters of type Expression Constructor Description AnyDiscriminatorPathInterpretation(NavigablePath navigablePath, ModelPart mapping, TableGroup tableGroup, Expression expression)AsWrappedExpression(Expression wrappedExpression, BasicType<B> expressionType)EntityValuedPathInterpretation(Expression sqlExpression, NavigablePath navigablePath, TableGroup tableGroup, EntityValuedModelPart mapping) -
Uses of Expression in org.hibernate.query.sqm.tree.expression
Classes in org.hibernate.query.sqm.tree.expression that implement Expression Modifier and Type Class Description classConversionA conversion of a duration to a given temporal unit, as a result of applying the 'by unit' operator.Methods in org.hibernate.query.sqm.tree.expression that return Expression Modifier and Type Method Description abstract ExpressionSqmFunction. convertToSqlAst(SqmToSqlAstConverter walker)Constructor parameters in org.hibernate.query.sqm.tree.expression with type arguments of type Expression Constructor Description SqmSelfRenderingExpression(Function<SemanticQueryWalker,Expression> renderer, SqmExpressible<T> type, NodeBuilder criteriaBuilder) -
Uses of Expression in org.hibernate.sql.ast.spi
Classes in org.hibernate.sql.ast.spi with type parameters of type Expression Modifier and Type Interface Description protected static interfaceAbstractSqlAstTranslator.SubQueryRelationalRestrictionEmulationRenderer<X extends Expression>Methods in org.hibernate.sql.ast.spi with type parameters of type Expression Modifier and Type Method Description protected <X extends Expression>
voidAbstractSqlAstTranslator. emulateSubQueryRelationalRestrictionPredicate(Predicate predicate, boolean negated, SelectStatement selectStatement, X lhsTuple, AbstractSqlAstTranslator.SubQueryRelationalRestrictionEmulationRenderer<X> renderer, ComparisonOperator tupleComparisonOperator)Methods in org.hibernate.sql.ast.spi that return Expression Modifier and Type Method Description protected ExpressionAbstractSqlAstTranslator. castNumberToString(Expression expression, int precision, int scale)Casts a number expression to a string with the given precision and scale.ExpressionSqlSelection. getExpression()The underlying expression.protected ExpressionAbstractSqlAstTranslator. getLeftHandExpression(Predicate predicate)ExpressionSqlExpressionAccess. getSqlExpression()protected ExpressionAbstractSqlAstTranslator. resolveAliasedExpression(List<SqlSelection> sqlSelections, Expression expression)protected ExpressionAbstractSqlAstTranslator. resolveAliasedExpression(Expression expression)protected ExpressionAbstractSqlAstTranslator. resolveExpressionToAlias(Expression expression)ExpressionSqlExpressionResolver. resolveSqlExpression(SqlExpressionResolver.ColumnReferenceKey key, Function<SqlAstProcessingState,Expression> creator)Given a qualifier + a qualifiableSqlExpressible, resolve the (Sql)Expression reference.default ExpressionSqlExpressionResolver. resolveSqlExpression(TableReference tableReference, SelectableMapping selectableMapping)Methods in org.hibernate.sql.ast.spi with parameters of type Expression Modifier and Type Method Description protected ExpressionAbstractSqlAstTranslator. castNumberToString(Expression expression, int precision, int scale)Casts a number expression to a string with the given precision and scale.protected voidAbstractSqlAstTranslator. emulateFetchOffsetWithWindowFunctions(QueryPart queryPart, Expression offsetExpression, Expression fetchExpression, FetchClauseType fetchClauseType, boolean emulateFetchClause)protected voidAbstractSqlAstTranslator. emulateSortSpecificationNullPrecedence(Expression sortExpression, NullPrecedence nullPrecedence)<X> XAbstractSqlAstTranslator. getLiteralValue(Expression expression)protected SqlSelectionExpressionAbstractSqlAstTranslator. getSelectItemReference(Expression expression)static booleanAggregateFunctionChecker. hasAggregateFunctions(Expression expression)protected <R> RAbstractSqlAstTranslator. interpretExpression(Expression expression, JdbcParameterBindings jdbcParameterBindings)protected booleanAbstractSqlAstTranslator. isLiteral(Expression expression)protected booleanAbstractSqlAstTranslator. isParameter(Expression expression)protected voidAbstractSqlAstTranslator. renderBackslashEscapedLikePattern(Expression pattern, Expression escapeCharacter, boolean noBackslashEscapes)protected voidAbstractSqlAstTranslator. renderCaseInsensitiveLikeEmulation(Expression lhs, Expression rhs, Expression escapeCharacter, boolean negated)protected voidAbstractSqlAstTranslator. renderCasted(Expression expression)protected voidAbstractSqlAstTranslator. renderCombinedLimitClause(Expression offsetExpression, Expression fetchExpression)protected voidAbstractSqlAstTranslator. renderComparison(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidAbstractSqlAstTranslator. renderComparisonDistinctOperator(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidAbstractSqlAstTranslator. renderComparisonEmulateCase(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidAbstractSqlAstTranslator. renderComparisonEmulateDecode(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidAbstractSqlAstTranslator. renderComparisonEmulateDecode(Expression lhs, ComparisonOperator operator, Expression rhs, SqlAstNodeRenderingMode firstArgRenderingMode)protected voidAbstractSqlAstTranslator. renderComparisonEmulateIntersect(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidAbstractSqlAstTranslator. renderComparisonStandard(Expression lhs, ComparisonOperator operator, Expression rhs)protected voidAbstractSqlAstTranslator. renderExpressionAsClauseItem(Expression expression)protected voidAbstractSqlAstTranslator. renderExpressionAsLiteral(Expression expression, JdbcParameterBindings jdbcParameterBindings)protected voidAbstractSqlAstTranslator. renderFetch(Expression fetchExpression, Expression offsetExpressionToAdd, FetchClauseType fetchClauseType)protected voidAbstractSqlAstTranslator. renderFetchExpression(Expression fetchExpression)protected voidAbstractSqlAstTranslator. renderFetchPlusOffsetExpression(Expression fetchClauseExpression, Expression offsetClauseExpression, int offset)protected voidAbstractSqlAstTranslator. renderFetchPlusOffsetExpressionAsLiteral(Expression fetchClauseExpression, Expression offsetClauseExpression, int offset)protected voidAbstractSqlAstTranslator. renderFetchPlusOffsetExpressionAsSingleParameter(Expression fetchClauseExpression, Expression offsetClauseExpression, int offset)protected voidAbstractSqlAstTranslator. renderFirstClause(Expression offsetExpression, Expression fetchExpression)protected voidAbstractSqlAstTranslator. renderFirstSkipClause(Expression offsetExpression, Expression fetchExpression)protected voidAbstractSqlAstTranslator. renderLimitOffsetClause(Expression offsetExpression, Expression fetchExpression)protected voidAbstractSqlAstTranslator. renderOffset(Expression offsetExpression, boolean renderOffsetRowsKeyword)protected voidAbstractSqlAstTranslator. renderOffsetExpression(Expression offsetExpression)protected voidAbstractSqlAstTranslator. renderOffsetFetchClause(Expression offsetExpression, Expression fetchExpression, FetchClauseType fetchClauseType, boolean renderOffsetRowsKeyword)protected voidAbstractSqlAstTranslator. renderPartitionItem(Expression expression)protected voidAbstractSqlAstTranslator. renderSelectExpression(Expression expression)protected voidAbstractSqlAstTranslator. renderSelectExpressionWithCastedOrInlinedPlainParameters(Expression expression)protected voidAbstractSqlAstTranslator. renderSelectSimpleComparison(List<SqlSelection> lhsExpressions, Expression expression, ComparisonOperator operator)protected voidAbstractSqlAstTranslator. renderSkipFirstClause(Expression offsetExpression, Expression fetchExpression)protected voidAbstractSqlAstTranslator. renderSortExpression(Expression sortExpression, boolean ignoreCase)protected voidAbstractSqlAstTranslator. renderStringContainsExactlyPredicate(Expression haystack, Expression needle)protected voidAbstractSqlAstTranslator. renderTopClause(Expression offsetExpression, Expression fetchExpression, FetchClauseType fetchClauseType, boolean addOffset, boolean needsParenthesis)protected voidAbstractSqlAstTranslator. renderTopStartAtClause(Expression offsetExpression, Expression fetchExpression, FetchClauseType fetchClauseType)protected ExpressionAbstractSqlAstTranslator. resolveAliasedExpression(List<SqlSelection> sqlSelections, Expression expression)protected ExpressionAbstractSqlAstTranslator. resolveAliasedExpression(Expression expression)protected ExpressionAbstractSqlAstTranslator. resolveExpressionToAlias(Expression expression)SqlSelectionSqlExpressionResolver. resolveSqlSelection(Expression expression, JavaType<?> javaType, FetchParent fetchParent, TypeConfiguration typeConfiguration)Resolve the SqlSelection for the given expressionprotected voidAbstractSqlAstTranslator. visitArithmeticOperand(Expression expression)protected voidAbstractSqlAstTranslator. visitOverClause(List<Expression> partitionExpressions, List<SortSpecification> sortSpecifications, FrameMode mode, FrameKind startKind, Expression startExpression, FrameKind endKind, Expression endExpression, FrameExclusion exclusion, boolean orderedSetAggregate)protected voidAbstractSqlAstTranslator. visitRecursivePath(Expression recursivePath, int sizeEstimate)Renders the recursive path, possibly wrapping a cast expression around it, to make sure a type with proper size is chosen.protected voidAbstractSqlAstTranslator. visitSortSpecification(Expression sortExpression, SortDirection sortOrder, NullPrecedence nullPrecedence, boolean ignoreCase)protected voidAbstractSqlAstTranslator. visitSqlSelectExpression(Expression expression)Method parameters in org.hibernate.sql.ast.spi with type arguments of type Expression Modifier and Type Method Description protected voidAbstractSqlAstTranslator. renderExpressionsAsSubquery(List<? extends Expression> expressions)ExpressionSqlExpressionResolver. resolveSqlExpression(SqlExpressionResolver.ColumnReferenceKey key, Function<SqlAstProcessingState,Expression> creator)Given a qualifier + a qualifiableSqlExpressible, resolve the (Sql)Expression reference.protected voidAbstractSqlAstTranslator. visitAnsiCaseSearchedExpression(CaseSearchedExpression caseSearchedExpression, Consumer<Expression> resultRenderer)protected voidAbstractSqlAstTranslator. visitAnsiCaseSimpleExpression(CaseSimpleExpression caseSimpleExpression, Consumer<Expression> resultRenderer)protected voidAbstractSqlAstTranslator. visitOverClause(List<Expression> partitionExpressions, List<SortSpecification> sortSpecifications)protected voidAbstractSqlAstTranslator. visitOverClause(List<Expression> partitionExpressions, List<SortSpecification> sortSpecifications, FrameMode mode, FrameKind startKind, Expression startExpression, FrameKind endKind, Expression endExpression, FrameExclusion exclusion, boolean orderedSetAggregate)protected voidAbstractSqlAstTranslator. visitPartitionByClause(List<Expression> partitionExpressions)protected voidAbstractSqlAstTranslator. visitPartitionExpressions(List<Expression> partitionExpressions, Function<Expression,Expression> resolveAliasExpression, boolean inlineParametersOfAliasedExpressions)protected voidAbstractSqlAstTranslator. visitPartitionExpressions(List<Expression> partitionExpressions, Function<Expression,Expression> resolveAliasExpression, boolean inlineParametersOfAliasedExpressions)protected voidAbstractSqlAstTranslator. visitPartitionExpressions(List<Expression> partitionExpressions, Function<Expression,Expression> resolveAliasExpression, boolean inlineParametersOfAliasedExpressions)protected voidAbstractSqlAstTranslator. visitPartitionExpressions(List<Expression> partitionExpressions, SelectItemReferenceStrategy referenceStrategy) -
Uses of Expression in org.hibernate.sql.ast.tree.cte
Classes in org.hibernate.sql.ast.tree.cte that implement Expression Modifier and Type Class Description classCteTableGroupWraps aNamedTableReferencerepresenting the CTE and adapts it toTableGroupfor use in SQL AST -
Uses of Expression in org.hibernate.sql.ast.tree.expression
Subinterfaces of Expression in org.hibernate.sql.ast.tree.expression Modifier and Type Interface Description interfaceAggregateFunctionExpressionModels an aggregate function expression at the SQL AST level.interfaceFunctionExpressionModels a function expression at the SQL AST level.interfaceJdbcParameterinterfaceLiteralinterfaceOrderedSetAggregateFunctionExpressionModels an ordered set-aggregate function expression at the SQL AST level.interfaceSelfRenderingExpressioninterfaceWindowFunctionExpressionModels a window function expression at the SQL AST level.Classes in org.hibernate.sql.ast.tree.expression that implement Expression Modifier and Type Class Description classAggregateColumnWriteExpressionclassAliasedExpressionA wrapper for an expression that also renders an alias.classAnyclassBinaryArithmeticExpressionclassCaseSearchedExpressionclassCaseSimpleExpressionclassCastTargetclassColumnReferenceModels a reference to a Column in a SQL ASTclassDistinctclassDurationA duration expressed in terms of a given temporal unit.classDurationUnitclassEmbeddableTypeLiteralclassEntityTypeLiteralclassEveryclassExtractUnitATemporalUnitpassed as an argument to theExtractFunction.classJdbcLiteral<T>Represents a literal in the SQL AST.classLiteralAsParameter<T>A wrapper for a literal to render as parameter through a cast function.classModifiedSubQueryExpressionclassNestedColumnReferenceModel a column which is relative to a base expression e.g.classOver<T>classOverflowclassQueryLiteral<T>Represents a literal in the SQL AST.classSelfRenderingSqlFragmentExpressionRepresents a self rendering expression that renders a SQL fragment.classSqlSelectionExpressionRepresents a selection that is "re-used" in certain parts of the query other than the select-clause (mainly important for order-by, group-by and having).classSqlTupleclassStarclassSummarizationclassUnaryOperationclassUnparsedNumericLiteral<N extends Number>A numeric literal coming from an HQL query, which needs special handlingMethods in org.hibernate.sql.ast.tree.expression that return Expression Modifier and Type Method Description ExpressionNestedColumnReference. getBaseExpression()ExpressionCaseSimpleExpression.WhenFragment. getCheckValue()ExpressionOver. getEndExpression()ExpressionDistinct. getExpression()ExpressionOver. getExpression()ExpressionOverflow. getFillerExpression()ExpressionCaseSimpleExpression. getFixture()ExpressionBinaryArithmeticExpression. getLeftHandOperand()Get the left-hand operand.ExpressionDuration. getMagnitude()ExpressionUnaryOperation. getOperand()ExpressionCaseSearchedExpression. getOtherwise()ExpressionCaseSimpleExpression. getOtherwise()ExpressionCaseSearchedExpression.WhenFragment. getResult()ExpressionCaseSimpleExpression.WhenFragment. getResult()ExpressionBinaryArithmeticExpression. getRightHandOperand()Get the right-hand operand.ExpressionOverflow. getSeparatorExpression()ExpressionOver. getStartExpression()ExpressionAggregateColumnWriteExpression. getValueExpression(SelectableMapping selectableMapping)Expression[]AggregateColumnWriteExpression. getValueExpressions()Methods in org.hibernate.sql.ast.tree.expression that return types with arguments of type Expression Modifier and Type Method Description List<? extends Expression>SqlTuple. getExpressions()List<Expression>Summarization. getGroupings()List<Expression>Over. getPartitions()Methods in org.hibernate.sql.ast.tree.expression with parameters of type Expression Modifier and Type Method Description voidSqlTuple.Builder. addSubExpression(Expression expression)voidCaseSearchedExpression. otherwise(Expression otherwiseExpression)voidCaseSimpleExpression. otherwise(Expression otherwiseExpression)voidCaseSearchedExpression. when(Predicate predicate, Expression result)voidCaseSimpleExpression. when(Expression test, Expression result)Constructor parameters in org.hibernate.sql.ast.tree.expression with type arguments of type Expression Constructor Description Over(Expression expression, List<Expression> partitions, List<SortSpecification> orderList)Over(Expression expression, List<Expression> partitions, List<SortSpecification> orderList, FrameMode mode, FrameKind startKind, Expression startExpression, FrameKind endKind, Expression endExpression, FrameExclusion exclusion)SqlTuple(List<? extends Expression> expressions, MappingModelExpressible valueMapping)Summarization(Summarization.Kind kind, List<Expression> groupings) -
Uses of Expression in org.hibernate.sql.ast.tree.from
Subinterfaces of Expression in org.hibernate.sql.ast.tree.from Modifier and Type Interface Description interfacePluralTableGroupinterfaceTableGroupGroup togetherTableReferencereferences related to a single entity or collection, along with joins to other TableGroupsinterfaceVirtualTableGroupMarker interface for TableGroup impls that are virtual - should not be rendered into the SQL.Classes in org.hibernate.sql.ast.tree.from that implement Expression Modifier and Type Class Description classAbstractTableGroupclassCollectionTableGroupA table group for collection tables of plural attributes.classCorrelatedPluralTableGroupA table group for correlated plural attributes.classCorrelatedTableGroupA virtualTableReferencefor correlated roots.classDelegatingTableGroupclassEmbeddableFunctionTableGroupA table group for functions that produce embeddable typed results.classFunctionTableGroupA special table group for a table valued functions.classLazyTableGroupThe purpose of this table group is to defer creating the actual table group until it is really needed.classMappedByTableGroupclassMutatingTableReferenceGroupWrapperActs as a TableGroup for DML query operations.classOneToManyTableGroupA table group for one-to-many plural attributes.classQueryPartTableGroupA special table group for a sub-queries.classStandardTableGroupclassStandardVirtualTableGroupclassUnionTableGroupclassValuesTableGroupA special table group for a VALUES clause.Methods in org.hibernate.sql.ast.tree.from that return Expression Modifier and Type Method Description ExpressionEmbeddableFunctionTableReference. getExpression()ExpressionDelegatingTableGroup. getSqlExpression()Constructors in org.hibernate.sql.ast.tree.from with parameters of type Expression Constructor Description EmbeddableFunctionTableGroup(NavigablePath navigablePath, EmbeddableMappingType embeddableMappingType, Expression expression)EmbeddableFunctionTableReference(NavigablePath navigablePath, EmbeddableMappingType embeddableMappingType, Expression expression) -
Uses of Expression in org.hibernate.sql.ast.tree.insert
Methods in org.hibernate.sql.ast.tree.insert that return types with arguments of type Expression Modifier and Type Method Description List<Expression>Values. getExpressions()Constructor parameters in org.hibernate.sql.ast.tree.insert with type arguments of type Expression Constructor Description Values(List<Expression> expressions) -
Uses of Expression in org.hibernate.sql.ast.tree.predicate
Subinterfaces of Expression in org.hibernate.sql.ast.tree.predicate Modifier and Type Interface Description interfacePredicateModels a predicate in the SQL ASTClasses in org.hibernate.sql.ast.tree.predicate that implement Expression Modifier and Type Class Description classAbstractPredicateclassBetweenPredicateclassBooleanExpressionPredicateclassComparisonPredicateclassExistsPredicateclassFilterPredicateCollection ofFilterPredicate.FilterFragmentPredicatesub-predicates, each representing one enabled filter restriction.static classFilterPredicate.FilterFragmentPredicateclassGroupedPredicateclassInArrayPredicateclassInListPredicateclassInSubQueryPredicateclassJunctionclassLikePredicateclassNegatedPredicateclassNullnessPredicateclassSelfRenderingPredicateclassThruthnessPredicateMethods in org.hibernate.sql.ast.tree.predicate that return Expression Modifier and Type Method Description ExpressionLikePredicate. getEscapeCharacter()ExpressionBetweenPredicate. getExpression()ExpressionBooleanExpressionPredicate. getExpression()ExpressionNullnessPredicate. getExpression()ExpressionThruthnessPredicate. getExpression()ExpressionComparisonPredicate. getLeftHandExpression()ExpressionBetweenPredicate. getLowerBound()ExpressionLikePredicate. getMatchExpression()ExpressionLikePredicate. getPattern()ExpressionComparisonPredicate. getRightHandExpression()ExpressionInArrayPredicate. getTestExpression()ExpressionInListPredicate. getTestExpression()ExpressionInSubQueryPredicate. getTestExpression()ExpressionBetweenPredicate. getUpperBound()Methods in org.hibernate.sql.ast.tree.predicate that return types with arguments of type Expression Modifier and Type Method Description List<Expression>InListPredicate. getListExpressions()Methods in org.hibernate.sql.ast.tree.predicate with parameters of type Expression Modifier and Type Method Description voidInListPredicate. addExpression(Expression expression)Constructors in org.hibernate.sql.ast.tree.predicate with parameters of type Expression Constructor Description BetweenPredicate(Expression expression, Expression lowerBound, Expression upperBound, boolean negated, JdbcMappingContainer expressionType)BooleanExpressionPredicate(Expression expression)BooleanExpressionPredicate(Expression expression, boolean negated, JdbcMappingContainer expressionType)ComparisonPredicate(Expression leftHandExpression, ComparisonOperator operator, Expression rightHandExpression)ComparisonPredicate(Expression leftHandExpression, ComparisonOperator operator, Expression rightHandExpression, JdbcMappingContainer expressionType)InArrayPredicate(Expression testExpression, JdbcParameter arrayParameter)InArrayPredicate(Expression testExpression, JdbcParameter arrayParameter, JdbcMappingContainer expressionType)InListPredicate(Expression testExpression)InListPredicate(Expression testExpression, boolean negated, JdbcMappingContainer expressionType)InListPredicate(Expression testExpression, List<Expression> listExpressions)InListPredicate(Expression testExpression, List<Expression> listExpressions, boolean negated, JdbcMappingContainer expressionType)InListPredicate(Expression testExpression, Expression... listExpressions)InSubQueryPredicate(Expression testExpression, QueryPart subQuery, boolean negated)InSubQueryPredicate(Expression testExpression, SelectStatement subQuery, boolean negated, JdbcMappingContainer expressionType)LikePredicate(Expression matchExpression, Expression pattern)LikePredicate(Expression matchExpression, Expression pattern, Expression escapeCharacter)LikePredicate(Expression matchExpression, Expression pattern, Expression escapeCharacter, boolean negated)LikePredicate(Expression matchExpression, Expression pattern, Expression escapeCharacter, boolean negated, boolean isCaseSensitive, JdbcMappingContainer expressionType)NullnessPredicate(Expression expression)NullnessPredicate(Expression expression, boolean negated)NullnessPredicate(Expression expression, boolean negated, JdbcMappingContainer expressionType)ThruthnessPredicate(Expression expression, boolean value, boolean negated, JdbcMappingContainer expressionType)Constructor parameters in org.hibernate.sql.ast.tree.predicate with type arguments of type Expression Constructor Description InListPredicate(Expression testExpression, List<Expression> listExpressions)InListPredicate(Expression testExpression, List<Expression> listExpressions, boolean negated, JdbcMappingContainer expressionType) -
Uses of Expression in org.hibernate.sql.ast.tree.select
Classes in org.hibernate.sql.ast.tree.select that implement Expression Modifier and Type Class Description classSelectStatementMethods in org.hibernate.sql.ast.tree.select that return Expression Modifier and Type Method Description ExpressionQueryPart. getFetchClauseExpression()ExpressionQueryPart. getOffsetClauseExpression()ExpressionSortSpecification. getSortExpression()Methods in org.hibernate.sql.ast.tree.select that return types with arguments of type Expression Modifier and Type Method Description List<Expression>QuerySpec. getGroupByClauseExpressions()Methods in org.hibernate.sql.ast.tree.select with parameters of type Expression Modifier and Type Method Description voidQueryPart. setFetchClauseExpression(Expression fetchClauseExpression, FetchClauseType fetchClauseType)voidQueryPart. setOffsetClauseExpression(Expression offsetClauseExpression)Method parameters in org.hibernate.sql.ast.tree.select with type arguments of type Expression Modifier and Type Method Description voidQuerySpec. setGroupByClauseExpressions(List<Expression> groupByClauseExpressions)Constructors in org.hibernate.sql.ast.tree.select with parameters of type Expression Constructor Description SortSpecification(Expression sortExpression, SortDirection sortOrder)SortSpecification(Expression sortExpression, SortDirection sortOrder, NullPrecedence nullPrecedence)SortSpecification(Expression sortExpression, SortDirection sortOrder, NullPrecedence nullPrecedence, boolean ignoreCase) -
Uses of Expression in org.hibernate.sql.ast.tree.update
Methods in org.hibernate.sql.ast.tree.update that return Expression Modifier and Type Method Description ExpressionAssignment. getAssignedValue()Constructors in org.hibernate.sql.ast.tree.update with parameters of type Expression Constructor Description Assignment(Assignable assignable, Expression assignedValue) -
Uses of Expression in org.hibernate.sql.exec.internal
Classes in org.hibernate.sql.exec.internal that implement Expression Modifier and Type Class Description classAbstractJdbcParameterclassJdbcParameterImplclassSqlTypedMappingJdbcParameterclassVersionTypeSeedParameterSpecificationParameter bind specification used for optimistic lock version seeding (from insert statements). -
Uses of Expression in org.hibernate.sql.model.ast
Classes in org.hibernate.sql.model.ast that implement Expression Modifier and Type Class Description classColumnValueParameterParameter descriptor specific to mutations.classColumnWriteFragmentModels a column's value expression within the SQL AST. -
Uses of Expression in org.hibernate.sql.results.internal
Methods in org.hibernate.sql.results.internal that return Expression Modifier and Type Method Description ExpressionSqlSelectionImpl. getExpression()ExpressionSqlSelectionImpl. getSqlExpression()Constructors in org.hibernate.sql.results.internal with parameters of type Expression Constructor Description ResolvedSqlSelection(int jdbcPosition, int valuesArrayPosition, Expression sqlExpression, BasicType<Object> resolvedType)ResolvedSqlSelection(int valuesArrayPosition, Expression sqlExpression, BasicType<Object> resolvedType)SqlSelectionImpl(int jdbcPosition, int valuesArrayPosition, Expression sqlExpression, boolean virtual)SqlSelectionImpl(int jdbcPosition, int valuesArrayPosition, Expression sqlExpression, JavaType<?> jdbcJavaType, boolean virtual, ValueExtractor valueExtractor)SqlSelectionImpl(int jdbcPosition, int valuesArrayPosition, JavaType<?> jdbcJavaType, Expression sqlExpression, boolean virtual)SqlSelectionImpl(int valuesArrayPosition, Expression sqlExpression)SqlSelectionImpl(Expression sqlExpression) -
Uses of Expression in org.hibernate.type.descriptor.jdbc
Methods in org.hibernate.type.descriptor.jdbc that return Expression Modifier and Type Method Description default ExpressionJdbcType. wrapTopLevelSelectionExpression(Expression expression)Wraps the top level selection expression to be able to read values with this JdbcType's ValueExtractor.Methods in org.hibernate.type.descriptor.jdbc with parameters of type Expression Modifier and Type Method Description default ExpressionJdbcType. wrapTopLevelSelectionExpression(Expression expression)Wraps the top level selection expression to be able to read values with this JdbcType's ValueExtractor.
-