Uses of Class
org.h2.expression.Expression
Packages that use Expression
Package
Description
This package contains the parser and the base classes for prepared SQL statements.
Contains DDL (data definition language) and related SQL statements.
Contains DML (data manipulation language) and related SQL statements.
Contains queries.
Database constraints such as check constraints, unique constraints, and referential constraints.
Expressions include mathematical operations, simple values, and others.
Aggregate functions.
Base classes for data analysis operations and implementations of window functions.
Condition expressions.
Functions.
Table value functions.
The native full text search implementation, and the wrapper for the Lucene full text search implementation.
Various table index implementations, as well as cursors to navigate in an index.
Utility classes for compatibility with other database, for example MySQL.
Helper classes to use the MVStore in the H2 database.
Implementation of row and internal result sets.
Schema implementation and objects that are stored in a schema (for example, sequences and constants).
Classes related to a table and table meta data.
-
Uses of Expression in org.h2.command
Methods in org.h2.command that return ExpressionModifier and TypeMethodDescriptionprivate Expression
Parser.addJoinColumn
(Expression on, TableFilter filter1, TableFilter filter2, Column column1, Column column2, boolean rightJoin) private Expression
Parser.parseDB2SpecialRegisters
(String name) Parser.parseDomainConstraintExpression
(String sql) Parse a SQL code snippet that represents an expression for a domain constraint.Parser.parseExpression
(String sql) Parse a SQL code snippet that represents an expression.private Expression
Parser.readAggregate
(AggregateType aggregateType, String aggregateName) private Expression
Parser.readAnd
(Expression r) private Expression
Parser.readBuiltinFunctionIf
(String upperName) private Expression
Parser.readCase()
private Expression
Parser.readCoalesceFunction
(int function) private Expression
Parser.readColumnIfNotFunction()
private Expression
Parser.readComparison
(Expression left, int compareType, boolean whenOperand) private Expression
Parser.readCompatibilityCase
(Expression when) private Expression
Parser.readCompatibilityFunction
(String name) private Expression
Parser.readCompatibilitySequenceValueFunction
(boolean current) private Expression
Parser.readConcat()
private Expression
Parser.readConcatFunction
(int function) private Expression
Parser.readCondition()
private Expression
Parser.readConditionIs
(Expression left, boolean whenOperand) private Expression
Parser.readConditionRightHandSide
(Expression r, boolean not, boolean whenOperand) private Expression
Parser.readCurrentDateTimeValueFunction
(int function, boolean hasParen, String name) private Expression
Parser.readCurrentGeneralValueSpecification
(int specification) private Expression
Parser.readDateTimeFormatFunction
(int function) private Expression
Parser.readExpression()
private Expression
Parser.readExpressionOrDefault()
private Expression
Parser.readExpressionOrIdentifier()
private Expression
Parser.readExpressionPart2
(Expression r1) private Expression
Parser.readExpressionWithGlobalConditions()
private Expression
Parser.readFactor()
private Expression
Parser.readFetchOrLimit()
private Expression
Parser.readFunction
(Schema schema, String name) private Expression
Parser.readFunctionWithSchema
(Schema schema, String name, String upperName) private Expression
Parser.readIfArgument()
private Expression
Parser.readIfSingleArgument()
private Expression
Parser.readIfWildcardRowidOrSequencePseudoColumn
(String schema, String objectName) private Expression
Parser.readInPredicate
(Expression left, boolean not, boolean whenOperand) private Expression
Parser.readInterval()
private Expression
Parser.readJoinSpecification
(TableFilter filter1, TableFilter filter2, boolean rightJoin) private Expression
private Expression
Parser.readLastArgument()
private Expression
Parser.readLikePredicate
(Expression left, CompareLike.LikeType likeType, boolean not, boolean whenOperand) private Expression
Parser.readNextArgument()
private Expression
Parser.readOnDuplicateKeyValues
(Table table, Update update) private Expression
Parser.readSetFunction()
private Expression
Parser.readSingleArgument()
private Expression
Parser.readSubstringFunction()
private Expression
Parser.readSum()
private Expression
Parser.readTerm()
private Expression
Parser.readTermObjectDot
(String objectName) private Expression
Parser.readTermWithIdentifier
(String name, boolean quoted) private Expression
Parser.readTildeCondition
(Expression r, boolean not) private Expression
Parser.readTrimFunction()
private Expression
Parser.readUserDefinedFunctionIf
(Schema schema, String functionName) private Expression
Parser.readWhenOperand
(Expression caseOperand) Methods in org.h2.command that return types with arguments of type ExpressionModifier and TypeMethodDescriptionprivate ArrayList
<Expression> Parser.parseValuesRow
(ArrayList<Expression> row) Methods in org.h2.command with parameters of type ExpressionModifier and TypeMethodDescriptionprivate void
Parser.addJoin
(TableFilter top, TableFilter join, boolean outer, Expression on) Add one join to another.private Expression
Parser.addJoinColumn
(Expression on, TableFilter filter1, TableFilter filter2, Column column1, Column column2, boolean rightJoin) private SimpleCase.SimpleWhen
Parser.decodeToWhen
(Expression caseOperand, boolean canOptimize, Expression whenOperand, Expression result) static String
Prepared.getSimpleSQL
(Expression[] list) Get the SQL snippet of the expression list.private void
Parser.readAggregateOrder
(Aggregate r, Expression expr, boolean parseSortType) private Expression
Parser.readAnd
(Expression r) private Expression
Parser.readComparison
(Expression left, int compareType, boolean whenOperand) private Expression
Parser.readCompatibilityCase
(Expression when) private Expression
Parser.readConditionIs
(Expression left, boolean whenOperand) private Expression
Parser.readConditionRightHandSide
(Expression r, boolean not, boolean whenOperand) private Expression
Parser.readExpressionPart2
(Expression r1) private Expression
Parser.readInPredicate
(Expression left, boolean not, boolean whenOperand) private IsJsonPredicate
Parser.readJsonPredicate
(Expression left, boolean not, boolean whenOperand) private Expression
Parser.readLikePredicate
(Expression left, CompareLike.LikeType likeType, boolean not, boolean whenOperand) private SimpleCase.SimpleWhen
Parser.readSimpleWhenClause
(Expression caseOperand) private Expression
Parser.readTildeCondition
(Expression r, boolean not) private TypePredicate
Parser.readTypePredicate
(Expression left, boolean not, boolean whenOperand) private Expression
Parser.readWhenOperand
(Expression caseOperand) private Aggregate
Parser.readWithinGroup
(AggregateType aggregateType, Expression[] args, boolean distinct, Object extraArguments, boolean forHypotheticalSet, boolean simple) Method parameters in org.h2.command with type arguments of type ExpressionModifier and TypeMethodDescriptionprivate ArrayList
<Expression> Parser.parseValuesRow
(ArrayList<Expression> row) -
Uses of Expression in org.h2.command.ddl
Fields in org.h2.command.ddl declared as ExpressionModifier and TypeFieldDescriptionprivate Expression
SequenceOptions.cacheSize
private Expression
AlterDomainAddConstraint.checkExpression
private Expression
AlterTableAddConstraint.checkExpression
private Expression
AlterTableAlterColumn.defaultExpression
Default or on update expression.private Expression
CreateDomain.defaultExpression
private Expression
SetComment.expr
private Expression
AlterDomainExpressions.expression
private Expression
CreateConstant.expression
private Expression
AlterUser.hash
private Expression
CreateUser.hash
private Expression
SequenceOptions.increment
private Expression
SequenceOptions.maxValue
private Expression
SequenceOptions.minValue
private Expression
AlterTableAlterColumn.newSelectivity
private Expression
CreateDomain.onUpdateExpression
private Expression
AlterUser.password
private Expression
CreateUser.password
private Expression
SequenceOptions.restart
private Expression
AlterUser.salt
private Expression
CreateUser.salt
private Expression
SequenceOptions.start
private Expression
AlterTableAlterColumn.usingExpression
Methods in org.h2.command.ddl with parameters of type ExpressionModifier and TypeMethodDescriptionprivate static void
AlterTableAlterColumn.checkDefaultReferencesTable
(Table table, Expression defaultExpression) private static byte[]
CreateUser.getByteArray
(SessionLocal session, Expression e) private static Long
SequenceOptions.getLong
(SessionLocal session, Expression expr) void
SequenceOptions.setCacheSize
(Expression cacheSize) Sets cache size.void
AlterDomainAddConstraint.setCheckExpression
(Expression expression) void
AlterTableAddConstraint.setCheckExpression
(Expression expression) void
SetComment.setCommentExpression
(Expression expr) void
AlterTableAlterColumn.setDefaultExpression
(Expression defaultExpression) Set default or on update expression.void
CreateDomain.setDefaultExpression
(Expression defaultExpression) void
AlterDomainExpressions.setExpression
(Expression expression) void
CreateConstant.setExpression
(Expression expr) void
AlterUser.setHash
(Expression e) void
CreateUser.setHash
(Expression e) void
SequenceOptions.setIncrement
(Expression increment) Sets increment value expression.void
SequenceOptions.setMaxValue
(Expression maxValue) Sets max value expression.void
SequenceOptions.setMinValue
(Expression minValue) Sets min value expression.void
CreateDomain.setOnUpdateExpression
(Expression onUpdateExpression) void
AlterUser.setPassword
(Expression password) (package private) static void
CreateUser.setPassword
(User user, SessionLocal session, Expression password) Set the password for the given user.void
CreateUser.setPassword
(Expression password) void
SequenceOptions.setRestartValue
(Expression restart) Sets restart value expression, orValueExpression.DEFAULT
.void
AlterUser.setSalt
(Expression e) void
CreateUser.setSalt
(Expression e) (package private) static void
CreateUser.setSaltAndHash
(User user, SessionLocal session, Expression salt, Expression hash) Set the salt and hash for the given user.void
AlterTableAlterColumn.setSelectivity
(Expression selectivity) void
SequenceOptions.setStartValue
(Expression start) Sets start value expression.void
AlterTableAlterColumn.setUsingExpression
(Expression usingExpression) Set using expression. -
Uses of Expression in org.h2.command.dml
Fields in org.h2.command.dml declared as ExpressionModifier and TypeFieldDescription(package private) Expression
MergeUsing.When.andCondition
AND condition of the command.(package private) Expression
FilteredDataChangeStatement.condition
The WHERE criteria.private Expression
Call.expression
private Expression
Set.expression
(package private) Expression
SetClauseList.RowExpression.expression
private Expression
SetClauseList.SetSimple.expression
private Expression[]
Call.expressions
private final Expression[]
Help.expressions
(package private) Expression
FilteredDataChangeStatement.fetchExpr
The expression with optional maximum number of rows.private Expression
BackupCommand.fileNameExpr
private Expression
ScriptBase.fileNameExpr
The file name (if set).(package private) Expression
MergeUsing.onCondition
ON condition expression.private Expression
ScriptBase.password
private Expression
ExecuteImmediate.statement
private final Expression[]
MergeUsing.WhenNotMatched.values
Fields in org.h2.command.dml with type parameters of type ExpressionModifier and TypeFieldDescriptionprivate HashMap
<Column, Expression> Insert.duplicateKeyAssignmentMap
For MySQL-style INSERT ...private final ArrayList
<Expression> ExecuteProcedure.expressions
Methods in org.h2.command.dml that return ExpressionModifier and TypeMethodDescriptionfinal Expression
FilteredDataChangeStatement.getCondition()
MergeUsing.getOnCondition()
private Expression
Insert.prepareUpdateCondition
(Index foundIndex, Expression[] row) Methods in org.h2.command.dml with parameters of type ExpressionModifier and TypeMethodDescriptionvoid
Insert.addAssignmentForDuplicate
(Column column, Expression expression) Keep a collection of the columns to pass to update if a duplicate key happens, for MySQL-style INSERT ...void
SetClauseList.addMultiple
(ArrayList<Column> columns, Expression expression) Add multiple columns.void
CommandWithValues.addRow
(Expression[] expr) Add a row to this command.void
SetClauseList.addSingle
(Column column, Expression expression) Add a single column.private int
Merge.merge
(Row row, Expression[] expressions, ResultTarget deltaChangeCollector, DataChangeDeltaTable.ResultOption deltaChangeCollectionMode) Updates an existing row or inserts a new one.private Expression
Insert.prepareUpdateCondition
(Index foundIndex, Expression[] row) void
MergeUsing.When.setAndCondition
(Expression andCondition) Sets the specified AND condition.final void
FilteredDataChangeStatement.setCondition
(Expression condition) void
Call.setExpression
(Expression expression) void
ExecuteProcedure.setExpression
(int index, Expression expr) Set the expression at the given index.void
Set.setExpression
(Expression expression) void
FilteredDataChangeStatement.setFetch
(Expression fetch) void
BackupCommand.setFileName
(Expression fileName) void
ScriptBase.setFileNameExpr
(Expression file) void
MergeUsing.setOnCondition
(Expression condition) void
ScriptBase.setPassword
(Expression password) Constructors in org.h2.command.dml with parameters of type ExpressionModifierConstructorDescriptionExecuteImmediate
(SessionLocal session, Expression statement) (package private)
RowExpression
(Expression expression, int[] columns) (package private)
SetSimple
(Expression expression) WhenNotMatched
(Column[] columns, Boolean overridingSystem, Expression[] values) -
Uses of Expression in org.h2.command.query
Fields in org.h2.command.query declared as ExpressionModifier and TypeFieldDescriptionQueryOrderBy.columnIndexExpr
The column index expression.private final Expression
Optimizer.condition
private Expression
Select.condition
WHERE condition.private Expression[]
Select.distinctExpressions
DISTINCT ON(...)
expressions.QueryOrderBy.expression
The order by expression.(package private) Expression[]
Query.expressionArray
Array of expressions.private final Expression[]
SelectListColumnResolver.expressions
(package private) Expression
Query.fetchExpr
The fetch expression as specified in the FETCH, LIMIT, or TOP clause.private Expression
Select.having
HAVING condition.(package private) Expression
Query.offsetExpr
The offset expression as specified in the OFFSET clause.private Expression
Select.qualify
QUALIFY condition.Fields in org.h2.command.query with type parameters of type ExpressionModifier and TypeFieldDescription(package private) ArrayList
<Expression> Query.expressions
The column list, including invisible expressions such as order by expressions.(package private) final ArrayList
<Expression> SelectGroups.expressions
The query's column list, including invisible expressions such as order by expressions.private final HashMap
<Expression, Integer> SelectGroups.exprToIndexInGroupByData
Maps an expression object to an index, to use in accessing the Object[] pointed to by groupByData.private ArrayList
<Expression> Select.group
private final ArrayList
<ArrayList<Expression>> TableValueConstructor.rows
Methods in org.h2.command.query that return ExpressionModifier and TypeMethodDescriptionprivate static Expression
Select.addGlobalCondition
(Expression condition, Expression additional) Select.getCondition()
Query.getFetch()
Select.getHaving()
Query.getIfSingleRow()
If this query is determined as a single-row query, returns a replacement expression.Select.getIfSingleRow()
TableValueConstructor.getIfSingleRow()
Query.getOffset()
Select.getQualify()
SelectListColumnResolver.optimize
(ExpressionColumn expressionColumn, Column column) TableValueConstructor.TableValueColumnResolver.optimize
(ExpressionColumn expressionColumn, Column column) Methods in org.h2.command.query that return types with arguments of type ExpressionModifier and TypeMethodDescriptionQuery.getExpressions()
The the list of select expressions.Select.getGroupBy()
Methods in org.h2.command.query with parameters of type ExpressionModifier and TypeMethodDescriptionvoid
Select.addCondition
(Expression cond) Add a condition to the list of conditions.private static Expression
Select.addGlobalCondition
(Expression condition, Expression additional) (package private) void
Query.appendEndOfQueryToSQL
(StringBuilder builder, int sqlFlags, Expression[] expressions) Appends ORDER BY, OFFSET, and FETCH clauses to the plan.private static boolean
Query.checkOrderOther
(SessionLocal session, Expression expr, ArrayList<String> expressionSQL) An additional check for expression in ORDER BY list for DISTINCT selects that was not matched with selected expressions in regular way.private static boolean
Select.containsAggregate
(Expression expression) final Object
SelectGroups.getCurrentGroupExprData
(Expression expr) Get the group-by data for the current group and the passed in expression.private static void
Select.getFilterSQL
(StringBuilder builder, String sql, Expression[] exprList, Expression condition, int conditionIndex, int sqlFlags) private static void
Select.getFilterSQL
(StringBuilder builder, String sql, Expression condition, int sqlFlags) (package private) int
Query.initExpression
(ArrayList<String> expressionSQL, Expression e, boolean mustBeInResult, ArrayList<TableFilter> filters) Initialize the 'ORDER BY' or 'DISTINCT' expressions.final void
SelectGroups.setCurrentGroupExprData
(Expression expr, Object obj) Set the group-by data for the current group and the passed in expression.void
Select.setDistinct
(Expression[] distinctExpressions) Set the DISTINCT ON expressions.void
Query.setFetch
(Expression fetch) void
Select.setHaving
(Expression having) void
Query.setOffset
(Expression offset) void
Select.setQualify
(Expression qualify) Method parameters in org.h2.command.query with type arguments of type ExpressionModifier and TypeMethodDescriptionstatic SelectGroups
SelectGroups.getInstance
(SessionLocal session, ArrayList<Expression> expressions, boolean isGroupQuery, int[] groupIndex) Creates new instance of grouped data.static void
TableValueConstructor.getValuesSQL
(StringBuilder builder, int sqlFlags, ArrayList<ArrayList<Expression>> rows) Appends the SQL of the values to the specified string builder..static void
TableValueConstructor.getVisibleResult
(SessionLocal session, ResultTarget result, Column[] columns, ArrayList<ArrayList<Expression>> rows) Appends visible columns of all rows to the specified result.void
Select.setExpressions
(ArrayList<Expression> expressions) void
Select.setGroupBy
(ArrayList<Expression> group) Constructors in org.h2.command.query with parameters of type ExpressionModifierConstructorDescription(package private)
LazyResultGroupSorted
(Expression[] expressions, int columnCount) (package private)
LazyResultQueryFlat
(Expression[] expressions, int columnCount, boolean forUpdate) (package private)
LazyResultSelect
(Expression[] expressions, int columnCount) (package private)
LazyResultUnion
(Expression[] expressions, int columnCount) (package private)
Optimizer
(TableFilter[] filters, Expression condition, SessionLocal session) Constructor parameters in org.h2.command.query with type arguments of type ExpressionModifierConstructorDescription(package private)
Grouped
(SessionLocal session, ArrayList<Expression> expressions, int[] groupIndex) (package private)
Plain
(SessionLocal session, ArrayList<Expression> expressions) (package private)
SelectGroups
(SessionLocal session, ArrayList<Expression> expressions) TableValueConstructor
(SessionLocal session, ArrayList<ArrayList<Expression>> rows) Creates new instance of table value constructor. -
Uses of Expression in org.h2.constraint
Fields in org.h2.constraint declared as ExpressionModifier and TypeFieldDescriptionprivate Expression
ConstraintCheck.expr
private Expression
ConstraintDomain.expr
Methods in org.h2.constraint that return ExpressionModifier and TypeMethodDescriptionConstraintDomain.getCheckConstraint
(SessionLocal session, String columnName) Get the check constraint expression for this column.Constraint.getExpression()
Returns the CHECK expression or null.ConstraintCheck.getExpression()
ConstraintDomain.getExpression()
Methods in org.h2.constraint with parameters of type ExpressionModifier and TypeMethodDescriptionvoid
ConstraintCheck.setExpression
(Expression expr) void
ConstraintDomain.setExpression
(SessionLocal session, Expression expr) Set the expression. -
Uses of Expression in org.h2.expression
Subclasses of Expression in org.h2.expressionModifier and TypeClassDescriptionfinal class
A column alias as in SELECT 'Hello' AS NAME ...final class
Array value constructor by query.final class
Array element reference.class
A mathematical expression, or string concatenation.class
A compatibility mathematical operation with datetime values.final class
Character string concatenation as in'Hello' || 'World'
, binary string concatenation as inX'01' || X'AB'
or an array concatenation as inARRAY[1, 2] || 3
.final class
An expression representing a value for domain constraint.final class
A column reference expression that represents a column of a table or view.final class
A list of expressions, as in (ID, NAME).final class
Field reference.final class
A format clause such as FORMAT JSON.class
A mathematical operation with intervals.class
Operation without subexpressions.class
Operation with one argument.class
Operation with one or two arguments.class
Operation with two arguments.class
Operation with many arguments.final class
A parameter of a prepared statement.final class
Represents the ROWNUM function.final class
A searched case.final class
Wraps a sequence when used in a statement.final class
A simple case.final class
A query returning a single value.final class
A time zone specification (AT { TIME ZONE | LOCAL }).class
An expression representing a constant value with a type cast.class
Unary operation.class
An expression representing a constant value.final class
A user-defined variable, for example: @ID.final class
A wildcard expression as in SELECT * FROM TEST.Fields in org.h2.expression declared as ExpressionModifier and TypeFieldDescriptionprotected Expression
Operation1.arg
The argument of the operation.protected Expression[]
OperationN.args
The array of arguments.private Expression
SimpleCase.elseResult
private Expression
Alias.expr
private Expression
Subquery.expression
protected Expression
Operation1_2.left
The left part of the operation (the first argument).protected Expression
Operation2.left
The left part of the operation (the first argument).private final Expression[]
ExpressionList.list
private Expression
SimpleCase.operand
(package private) Expression[]
SimpleCase.SimpleWhen.operands
(package private) Expression
SimpleCase.SimpleWhen.result
protected Expression
Operation1_2.right
The right part of the operation (the second argument).protected Expression
Operation2.right
The right part of the operation (the second argument).Methods in org.h2.expression that return ExpressionModifier and TypeMethodDescriptionAlias.getNonAliasExpression()
Expression.getNonAliasExpression()
Returns the main expression, skipping aliases.Expression.getNotIfPossible
(SessionLocal session) If it is possible, return the negated expression.ExpressionColumn.getNotIfPossible
(SessionLocal session) Parameter.getNotIfPossible
(SessionLocal session) ValueExpression.getNotIfPossible
(SessionLocal session) Expression.getSubexpression
(int index) Returns subexpression with specified index.ExpressionList.getSubexpression
(int index) Operation1_2.getSubexpression
(int index) Operation1.getSubexpression
(int index) Operation2.getSubexpression
(int index) OperationN.getSubexpression
(int index) SimpleCase.getSubexpression
(int index) Alias.optimize
(SessionLocal session) ArrayConstructorByQuery.optimize
(SessionLocal session) ArrayElementReference.optimize
(SessionLocal session) BinaryOperation.optimize
(SessionLocal session) CompatibilityDatePlusTimeOperation.optimize
(SessionLocal session) ConcatenationOperation.optimize
(SessionLocal session) DomainValueExpression.optimize
(SessionLocal session) abstract Expression
Expression.optimize
(SessionLocal session) Try to optimize the expression.ExpressionColumn.optimize
(SessionLocal session) ExpressionList.optimize
(SessionLocal session) FieldReference.optimize
(SessionLocal session) Format.optimize
(SessionLocal session) IntervalOperation.optimize
(SessionLocal session) Operation0.optimize
(SessionLocal session) Parameter.optimize
(SessionLocal session) Rownum.optimize
(SessionLocal session) SearchedCase.optimize
(SessionLocal session) SimpleCase.optimize
(SessionLocal session) Subquery.optimize
(SessionLocal session) TimeZoneOperation.optimize
(SessionLocal session) UnaryOperation.optimize
(SessionLocal session) Wildcard.optimize
(SessionLocal session) final Expression
Expression.optimizeCondition
(SessionLocal session) Try to optimize or remove the condition.private Expression
BinaryOperation.optimizeDateTime
(SessionLocal session, int l, int r) private Expression
BinaryOperation.optimizeInterval
(int l, int r) private Expression
ExpressionColumn.optimizeOther()
Methods in org.h2.expression with parameters of type ExpressionModifier and TypeMethodDescriptionvoid
ExpressionWithVariableParameters.addParameter
(Expression param) Adds the parameter expression.void
OperationN.addParameter
(Expression param) (package private) static TypeInfo
SimpleCase.combineTypes
(TypeInfo typeInfo, Expression e) static StringBuilder
Expression.writeExpressions
(StringBuilder builder, Expression[] expressions, int sqlFlags) Get the SQL snippet for an array of expressions.Method parameters in org.h2.expression with type arguments of type ExpressionModifier and TypeMethodDescriptionstatic StringBuilder
Expression.writeExpressions
(StringBuilder builder, List<? extends Expression> expressions, int sqlFlags) Get the SQL snippet for a list of expressions.Constructors in org.h2.expression with parameters of type ExpressionModifierConstructorDescriptionAlias
(Expression expression, String alias, boolean aliasColumnName) ArrayElementReference
(Expression left, Expression right) BinaryOperation
(BinaryOperation.OpType opType, Expression left, Expression right) CompatibilityDatePlusTimeOperation
(Expression left, Expression right) ConcatenationOperation
(Expression op1, Expression op2) ExpressionList
(Expression[] list, boolean isArray) FieldReference
(Expression arg, String fieldName) Format
(Expression arg, Format.FormatEnum format) IntervalOperation
(IntervalOperation.IntervalOpType opType, Expression left, Expression right) IntervalOperation
(IntervalOperation.IntervalOpType opType, Expression left, Expression right, TypeInfo forcedType) protected
Operation1
(Expression arg) protected
Operation1_2
(Expression left, Expression right) protected
Operation2
(Expression left, Expression right) protected
OperationN
(Expression[] args) SearchedCase
(Expression[] args) SimpleCase
(Expression operand, SimpleCase.SimpleWhen when, Expression elseResult) SimpleWhen
(Expression[] operands, Expression result) SimpleWhen
(Expression operand, Expression result) TimeZoneOperation
(Expression left, Expression right) UnaryOperation
(Expression arg) -
Uses of Expression in org.h2.expression.aggregate
Subclasses of Expression in org.h2.expression.aggregateModifier and TypeClassDescriptionclass
A base class for aggregate functions.class
Implements the integrated aggregate functions, such as COUNT, MAX, SUM.class
This class wraps a user-defined aggregate.Fields in org.h2.expression.aggregate declared as ExpressionModifier and TypeFieldDescriptionprotected final Expression[]
AbstractAggregate.args
The arguments.protected Expression
AbstractAggregate.filterCondition
FILTER condition for aggregateMethods in org.h2.expression.aggregate that return ExpressionModifier and TypeMethodDescriptionAbstractAggregate.getSubexpression
(int index) AbstractAggregate.optimize
(SessionLocal session) Aggregate.optimize
(SessionLocal session) JavaAggregate.optimize
(SessionLocal session) Methods in org.h2.expression.aggregate with parameters of type ExpressionModifier and TypeMethodDescription(package private) static Index
Percentile.getColumnIndex
(Database database, Expression on) Get the index (if any) for the column specified in the inverse distribution function.(package private) static Value
Percentile.getFromIndex
(SessionLocal session, Expression expression, int dataType, ArrayList<QueryOrderBy> orderByList, BigDecimal percentile, boolean interpolate) Get the result from the index.(package private) static Index
AggregateDataEnvelope.getGeometryColumnIndex
(Expression on) Get the index (if any) for the column specified in the geometry aggregate.void
AbstractAggregate.setFilterCondition
(Expression filterCondition) Sets the FILTER condition.Constructors in org.h2.expression.aggregate with parameters of type ExpressionModifierConstructorDescription(package private)
AbstractAggregate
(Select select, Expression[] args, boolean distinct) Aggregate
(AggregateType aggregateType, Expression[] args, Select select, boolean distinct) Create a new aggregate object.JavaAggregate
(UserAggregate userAggregate, Expression[] args, Select select, boolean distinct) -
Uses of Expression in org.h2.expression.analysis
Subclasses of Expression in org.h2.expression.analysisModifier and TypeClassDescriptionclass
A base class for data analysis operations such as aggregates and window functions.class
A window function.Fields in org.h2.expression.analysis declared as ExpressionModifier and TypeFieldDescriptionprivate final Expression[]
WindowFunction.args
private Expression
WindowFrameBound.value
Fields in org.h2.expression.analysis with type parameters of type ExpressionMethods in org.h2.expression.analysis that return ExpressionModifier and TypeMethodDescriptionWindowFrameBound.getValue()
Returns the value.DataAnalysisOperation.optimize
(SessionLocal session) WindowFunction.optimize
(SessionLocal session) Constructors in org.h2.expression.analysis with parameters of type ExpressionModifierConstructorDescriptionWindowFrameBound
(WindowFrameBoundType type, Expression value) Creates new instance of window frame bound.WindowFunction
(WindowFunctionType type, Select select, Expression[] args) Creates new instance of a window function.Constructor parameters in org.h2.expression.analysis with type arguments of type ExpressionModifierConstructorDescriptionWindow
(String parent, ArrayList<Expression> partitionBy, ArrayList<QueryOrderBy> orderBy, WindowFrame frame) Creates a new instance of window clause. -
Uses of Expression in org.h2.expression.condition
Subclasses of Expression in org.h2.expression.conditionModifier and TypeClassDescriptionfinal class
BETWEEN predicate.final class
Boolean test (IS [NOT] { TRUE | FALSE | UNKNOWN }).final class
Pattern matching comparison expression: WHERE NAME LIKE ?final class
Example comparison expressions are ID=1, NAME=NAME, NAME IS NULL.(package private) class
Represents a condition returning a boolean value, or NULL.class
An 'and' or 'or' condition as in WHERE ID=1 AND NAME=?class
An 'and' or 'or' condition as in WHERE ID=1 AND NAME=? with N operands.final class
An 'in' condition with a list of values, as in WHERE NAME IN(...)final class
Used for optimised IN(...) queries where the contents of the IN list are all constant and of the same type.final class
A condition with parameter as= ANY(?)
.final class
An IN() condition with a subquery, as in WHERE ID IN(SELECT ...)class
A global condition or combination of local and global conditions.class
A NOT condition.class
Exists predicate as in EXISTS(SELECT ...)final class
IS JSON predicate.final class
Null predicate (IS [NOT] NULL).(package private) class
Base class for predicates with a subquery.class
Base class for simple predicates.final class
Type predicate (IS [NOT] OF).class
Unique predicate as in UNIQUE(SELECT ...)Fields in org.h2.expression.condition declared as ExpressionModifier and TypeFieldDescriptionprivate Expression
BetweenPredicate.a
private Expression
ConditionAndOr.added
Additional condition for index only.private Expression
BetweenPredicate.b
private Expression
ConditionNot.condition
private Expression
CompareLike.escape
private Expression
ConditionLocalAndGlobal.global
private Expression
BetweenPredicate.left
private Expression
CompareLike.left
private Expression
Comparison.left
private Expression
ConditionAndOr.left
private Expression
ConditionIn.left
private Expression
ConditionInConstantSet.left
private Expression
ConditionInParameter.left
private Expression
ConditionInQuery.left
private Expression
IsJsonPredicate.left
(package private) Expression
SimplePredicate.left
The left hand side of the expression.private Expression
ConditionLocalAndGlobal.local
private Expression
CompareLike.right
private Expression
Comparison.right
private Expression
ConditionAndOr.right
Fields in org.h2.expression.condition with type parameters of type ExpressionModifier and TypeFieldDescriptionprivate List
<Expression> ConditionAndOrN.added
Additional conditions for index only.private static final Comparator
<Expression> ConditionAndOrN.COMPARE_BY_COST
private final List
<Expression> ConditionAndOrN.expressions
Use an ArrayDeque because we primarily insert at the front.private final ArrayList
<Expression> ConditionIn.valueList
private final ArrayList
<Expression> ConditionInConstantSet.valueList
Methods in org.h2.expression.condition that return ExpressionModifier and TypeMethodDescription(package private) static Expression
Condition.castToBoolean
(SessionLocal session, Expression expression) Add a cast around the expression (if necessary) so that the type is boolean.ConditionInParameter.ParameterList.get
(int index) (package private) Expression
ConditionIn.getAdditional
(Comparison other) Add an additional element if possible.(package private) Expression
ConditionInConstantSet.getAdditional
(SessionLocal session, Comparison other) Add an additional element if possible.(package private) Expression
Comparison.getAdditionalAnd
(SessionLocal session, Comparison other) Get an additional condition if possible.(package private) Expression
Comparison.getIfEquals
(Expression match) Get the other expression if this is an equals comparison and the other expression matches.BetweenPredicate.getNotIfPossible
(SessionLocal session) BooleanTest.getNotIfPossible
(SessionLocal session) CompareLike.getNotIfPossible
(SessionLocal session) Comparison.getNotIfPossible
(SessionLocal session) ConditionAndOr.getNotIfPossible
(SessionLocal session) ConditionAndOrN.getNotIfPossible
(SessionLocal session) ConditionIn.getNotIfPossible
(SessionLocal session) ConditionInConstantSet.getNotIfPossible
(SessionLocal session) ConditionInParameter.getNotIfPossible
(SessionLocal session) ConditionInQuery.getNotIfPossible
(SessionLocal session) ConditionNot.getNotIfPossible
(SessionLocal session) IsJsonPredicate.getNotIfPossible
(SessionLocal session) NullPredicate.getNotIfPossible
(SessionLocal session) TypePredicate.getNotIfPossible
(SessionLocal session) BetweenPredicate.getSubexpression
(int index) CompareLike.getSubexpression
(int index) Comparison.getSubexpression
(int index) ConditionAndOr.getSubexpression
(int index) ConditionAndOrN.getSubexpression
(int index) ConditionIn.getSubexpression
(int index) ConditionInConstantSet.getSubexpression
(int index) ConditionLocalAndGlobal.getSubexpression
(int index) ConditionNot.getSubexpression
(int index) IsJsonPredicate.getSubexpression
(int index) SimplePredicate.getSubexpression
(int index) BetweenPredicate.optimize
(SessionLocal session) CompareLike.optimize
(SessionLocal session) Comparison.optimize
(SessionLocal session) ConditionAndOr.optimize
(SessionLocal session) ConditionAndOrN.optimize
(SessionLocal session) ConditionIn.optimize
(SessionLocal session) ConditionInConstantSet.optimize
(SessionLocal session) ConditionInParameter.optimize
(SessionLocal session) ConditionInQuery.optimize
(SessionLocal session) ConditionLocalAndGlobal.optimize
(SessionLocal session) ConditionNot.optimize
(SessionLocal session) IsJsonPredicate.optimize
(SessionLocal session) NullPredicate.optimize
(SessionLocal session) PredicateWithSubquery.optimize
(SessionLocal session) SimplePredicate.optimize
(SessionLocal session) TypePredicate.optimize
(SessionLocal session) UniquePredicate.optimize
(SessionLocal session) private Expression
ConditionIn.optimize2
(SessionLocal session, boolean constant, boolean allValuesConstant, boolean allValuesNull, ArrayList<Expression> values) (package private) static Expression
ConditionAndOr.optimizeConditionAndOr
(ConditionAndOr left, ConditionAndOr right) Optimize query according to the given condition.private static Expression
ConditionAndOr.optimizeConstant
(SessionLocal session, int andOrType, Value l, Expression right) (package private) static Expression
ConditionAndOr.optimizeIfConstant
(SessionLocal session, int andOrType, Expression left, Expression right) Optimize the condition if at least one part is constant.private static Expression
ConditionAndOr.optimizeN
(ConditionAndOr condition) (package private) Expression
Comparison.optimizeOr
(SessionLocal session, Comparison other) Replace the OR condition with IN condition if possible.Methods in org.h2.expression.condition with parameters of type ExpressionModifier and TypeMethodDescription(package private) void
ConditionAndOrN.addFirst
(Expression e) Add the expression at the beginning of the list.(package private) static Expression
Condition.castToBoolean
(SessionLocal session, Expression expression) Add a cast around the expression (if necessary) so that the type is boolean.(package private) static void
Comparison.createIndexConditions
(TableFilter filter, Expression left, Expression right, int compareType) private static ConditionIn
Comparison.getConditionIn
(Expression left, Expression value1, Expression value2) (package private) Expression
Comparison.getIfEquals
(Expression match) Get the other expression if this is an equals comparison and the other expression matches.private static Expression
ConditionAndOr.optimizeConstant
(SessionLocal session, int andOrType, Value l, Expression right) (package private) static Expression
ConditionAndOr.optimizeIfConstant
(SessionLocal session, int andOrType, Expression left, Expression right) Optimize the condition if at least one part is constant.Method parameters in org.h2.expression.condition with type arguments of type ExpressionModifier and TypeMethodDescriptionprivate Expression
ConditionIn.optimize2
(SessionLocal session, boolean constant, boolean allValuesConstant, boolean allValuesNull, ArrayList<Expression> values) Constructors in org.h2.expression.condition with parameters of type ExpressionModifierConstructorDescriptionBetweenPredicate
(Expression left, boolean not, boolean whenOperand, boolean symmetric, Expression a, Expression b) BooleanTest
(Expression left, boolean not, boolean whenOperand, Boolean right) CompareLike
(Database db, Expression left, boolean not, boolean whenOperand, Expression right, Expression escape, CompareLike.LikeType likeType) CompareLike
(CompareMode compareMode, String defaultEscape, Expression left, boolean not, boolean whenOperand, Expression right, Expression escape, CompareLike.LikeType likeType) Comparison
(int compareType, Expression left, Expression right, boolean whenOperand) ConditionAndOr
(int andOrType, Expression left, Expression right) ConditionAndOrN
(int andOrType, Expression expr1, Expression expr2, Expression expr3) ConditionIn
(Expression left, boolean not, boolean whenOperand, ArrayList<Expression> values) Create a new IN(..) condition.(package private)
ConditionInConstantSet
(SessionLocal session, Expression left, boolean not, boolean whenOperand, ArrayList<Expression> valueList) Create a new IN(..) condition.ConditionInParameter
(Expression left, boolean not, boolean whenOperand, Parameter parameter) Create a new= ANY(?)
condition.ConditionInQuery
(Expression left, boolean not, boolean whenOperand, Query query, boolean all, int compareType) ConditionLocalAndGlobal
(Expression local, Expression global) ConditionNot
(Expression condition) IsJsonPredicate
(Expression left, boolean not, boolean whenOperand, boolean withUniqueKeys, JSONItemType itemType) NullPredicate
(Expression left, boolean not, boolean whenOperand) (package private)
SimplePredicate
(Expression left, boolean not, boolean whenOperand) TypePredicate
(Expression left, boolean not, boolean whenOperand, TypeInfo[] typeList) Constructor parameters in org.h2.expression.condition with type arguments of type ExpressionModifierConstructorDescriptionConditionAndOrN
(int andOrType, List<Expression> expressions) ConditionIn
(Expression left, boolean not, boolean whenOperand, ArrayList<Expression> values) Create a new IN(..) condition.(package private)
ConditionInConstantSet
(SessionLocal session, Expression left, boolean not, boolean whenOperand, ArrayList<Expression> valueList) Create a new IN(..) condition. -
Uses of Expression in org.h2.expression.function
Subclasses of Expression in org.h2.expression.functionModifier and TypeClassDescriptionfinal class
An array function.final class
A bitwise function.final class
Cardinality expression.final class
A cast specification.final class
A COALESCE, GREATEST, or LEAST function.final class
NEXTVAL() and CURRVAL() compatibility functions.final class
A COMPRESS or EXPAND function.final class
A CONCAT or CONCAT_WS function.final class
An ENCRYPT or DECRYPT function.final class
A CSVWRITE function.final class
Current datetime value function.final class
Simple general value specifications.final class
DATA_TYPE_SQL() function.final class
A date-time format function.final class
A date-time function.final class
A DAYNAME() or MONTHNAME() function.final class
DB_OBJECT_ID() and DB_OBJECT_SQL() functions.final class
A FILE_READ or FILE_WRITE function.class
Function with one optional argument.class
Function with one argument.class
Function with two arguments.class
Function with two arguments.class
Function with many arguments.final class
A HASH or ORA_HASH function.final class
This class wraps a user-defined function.final class
JSON constructor function.final class
CHAR_LENGTH(), or OCTET_LENGTH() function.final class
A math function.final class
A math function with one argument and DOUBLE PRECISION result.final class
A math function with two arguments and DOUBLE PRECISION result.final class
A NULLIF function.final class
A RAND, SECURE_RAND, or RANDOM_UUID function.final class
A regular expression function.final class
An ABORT_SESSION() or CANCEL_SESSION() function.final class
A SET function.final class
A SIGNAL function.final class
A SOUNDEX or DIFFERENCE function.final class
An string function with multiple arguments.final class
A string function with one argument.final class
A string function with two arguments.final class
A SUBSTRING function.final class
Database or session information function.final class
A table information function.final class
Emulates Oracle's TO_CHAR function.final class
A TRIM function.final class
A TRUNCATE_VALUE function.final class
An XML function.Fields in org.h2.expression.function declared as ExpressionModifier and TypeFieldDescriptionprotected Expression
Function0_1.arg
The argument of the operation.private final Expression[]
JavaFunction.args
Methods in org.h2.expression.function that return ExpressionModifier and TypeMethodDescriptionFunction0_1.getSubexpression
(int index) JavaFunction.getSubexpression
(int index) ArrayFunction.optimize
(SessionLocal session) BitFunction.optimize
(SessionLocal session) CardinalityExpression.optimize
(SessionLocal session) CastSpecification.optimize
(SessionLocal session) CoalesceFunction.optimize
(SessionLocal session) CompatibilitySequenceValueFunction.optimize
(SessionLocal session) CompressFunction.optimize
(SessionLocal session) ConcatFunction.optimize
(SessionLocal session) CryptFunction.optimize
(SessionLocal session) CSVWriteFunction.optimize
(SessionLocal session) DataTypeSQLFunction.optimize
(SessionLocal session) DateTimeFormatFunction.optimize
(SessionLocal session) DateTimeFunction.optimize
(SessionLocal session) DayMonthNameFunction.optimize
(SessionLocal session) DBObjectFunction.optimize
(SessionLocal session) FileFunction.optimize
(SessionLocal session) HashFunction.optimize
(SessionLocal session) JavaFunction.optimize
(SessionLocal session) JsonConstructorFunction.optimize
(SessionLocal session) LengthFunction.optimize
(SessionLocal session) MathFunction.optimize
(SessionLocal session) MathFunction1.optimize
(SessionLocal session) MathFunction2.optimize
(SessionLocal session) NullIfFunction.optimize
(SessionLocal session) RandFunction.optimize
(SessionLocal session) RegexpFunction.optimize
(SessionLocal session) SessionControlFunction.optimize
(SessionLocal session) SetFunction.optimize
(SessionLocal session) SignalFunction.optimize
(SessionLocal session) SoundexFunction.optimize
(SessionLocal session) StringFunction.optimize
(SessionLocal session) StringFunction1.optimize
(SessionLocal session) StringFunction2.optimize
(SessionLocal session) SubstringFunction.optimize
(SessionLocal session) TableInfoFunction.optimize
(SessionLocal session) ToCharFunction.optimize
(SessionLocal session) TrimFunction.optimize
(SessionLocal session) TruncateValueFunction.optimize
(SessionLocal session) XMLFunction.optimize
(SessionLocal session) private Expression
BitFunction.optimizeNot
(SessionLocal session) private Expression
MathFunction.optimizeRound
(int scale, boolean scaleIsKnown, boolean scaleIsNull, boolean possibleRoundUp) Optimizes rounding and truncation functions.private Expression
MathFunction.optimizeRoundWithScale
(SessionLocal session, boolean possibleRoundUp) Methods in org.h2.expression.function with parameters of type ExpressionModifier and TypeMethodDescriptionstatic TypeInfo
BitFunction.checkArgType
(Expression arg) Checks the type of an argument of bitwise function (one ofBitFunction.BITAND
,BitFunction.BITOR
,BitFunction.BITXOR
,BitFunction.BITNOT
,BitFunction.BITNAND
,BitFunction.BITNOR
,BitFunction.BITXNOR
).private static TypeInfo
BitFunction.getCommonType
(Expression arg1, Expression arg2) private Value
JsonConstructorFunction.jsonArray
(SessionLocal session, Expression[] args) private Value
JsonConstructorFunction.jsonObject
(SessionLocal session, Expression[] args) Constructors in org.h2.expression.function with parameters of type ExpressionModifierConstructorDescriptionArrayFunction
(Expression arg1, Expression arg2, Expression arg3, int function) BitFunction
(Expression arg1, Expression arg2, int function) CardinalityExpression
(Expression arg, boolean max) Creates new instance of cardinality expression.CastSpecification
(Expression arg, Column column) CastSpecification
(Expression arg, TypeInfo type) CoalesceFunction
(int function, Expression... args) CompatibilitySequenceValueFunction
(Expression left, Expression right, boolean current) CompressFunction
(Expression arg1, Expression arg2, int function) ConcatFunction
(int function, Expression... args) CryptFunction
(Expression arg1, Expression arg2, Expression arg3, int function) DataTypeSQLFunction
(Expression objectSchema, Expression objectName, Expression objectType, Expression typeIdentifier) DateTimeFunction
(int function, int field, Expression arg1, Expression arg2) DayMonthNameFunction
(Expression arg, int function) DBObjectFunction
(Expression objectType, Expression arg1, Expression arg2, int function) FileFunction
(Expression arg1, Expression arg2, int function) protected
Function0_1
(Expression arg) protected
Function1
(Expression arg) protected
Function1_2
(Expression left, Expression right) protected
Function2
(Expression left, Expression right) protected
FunctionN
(Expression[] args) HashFunction
(Expression arg, int function) HashFunction
(Expression arg1, Expression arg2, Expression arg3, int function) JavaFunction
(FunctionAlias functionAlias, Expression[] args) LengthFunction
(Expression arg, int function) MathFunction
(Expression arg1, Expression arg2, int function) MathFunction1
(Expression arg, int function) MathFunction2
(Expression arg1, Expression arg2, int function) NullIfFunction
(Expression arg1, Expression arg2) RandFunction
(Expression arg, int function) SessionControlFunction
(Expression arg, int function) SetFunction
(Expression arg1, Expression arg2) SignalFunction
(Expression arg1, Expression arg2) SoundexFunction
(Expression arg1, Expression arg2, int function) StringFunction
(Expression[] args, int function) StringFunction
(Expression arg1, Expression arg2, Expression arg3, int function) StringFunction
(Expression arg1, Expression arg2, Expression arg3, Expression arg4, int function) StringFunction1
(Expression arg, int function) StringFunction2
(Expression arg1, Expression arg2, int function) TableInfoFunction
(Expression arg1, Expression arg2, int function) ToCharFunction
(Expression arg1, Expression arg2, Expression arg3) TrimFunction
(Expression from, Expression space, int flags) TruncateValueFunction
(Expression arg1, Expression arg2, Expression arg3) -
Uses of Expression in org.h2.expression.function.table
Fields in org.h2.expression.function.table declared as ExpressionMethods in org.h2.expression.function.table with parameters of type ExpressionModifier and TypeMethodDescriptionvoid
TableFunction.addParameter
(Expression param) private static String
CSVReadFunction.getValue
(SessionLocal session, Expression[] args, int index) Constructors in org.h2.expression.function.table with parameters of type ExpressionModifierConstructorDescriptionJavaTableFunction
(FunctionAlias functionAlias, Expression[] args) protected
TableFunction
(Expression[] args) -
Uses of Expression in org.h2.fulltext
Methods in org.h2.fulltext with parameters of type ExpressionModifier and TypeMethodDescriptionprivate static void
FullText.addColumnData
(SessionLocal session, ArrayList<String> columns, ArrayList<String> data, Expression expr) -
Uses of Expression in org.h2.index
Fields in org.h2.index declared as ExpressionFields in org.h2.index with type parameters of type ExpressionMethods in org.h2.index that return ExpressionMethods in org.h2.index that return types with arguments of type ExpressionMethods in org.h2.index with parameters of type ExpressionModifier and TypeMethodDescriptionstatic IndexCondition
IndexCondition.get
(int compareType, ExpressionColumn column, Expression expression) Create an index condition with the given parameters.Method parameters in org.h2.index with type arguments of type ExpressionModifier and TypeMethodDescriptionstatic IndexCondition
IndexCondition.getInList
(ExpressionColumn column, List<Expression> list) Create an index condition with the compare type IN_LIST and with the given parameters.Constructors in org.h2.index with parameters of type ExpressionModifierConstructorDescriptionprivate
IndexCondition
(int compareType, ExpressionColumn column, Expression expression) -
Uses of Expression in org.h2.mode
Subclasses of Expression in org.h2.modeModifier and TypeClassDescriptionfinal class
Functions forMode.ModeEnum.DB2
andMode.ModeEnum.Derby
compatibility modes.class
This class implements some legacy functions not available in Regular mode.final class
Functions forMode.ModeEnum.MSSQLServer
compatibility mode.final class
This class implements some MySQL-specific functions.final class
Functions forMode.ModeEnum.Oracle
compatibility mode.final class
Functions forMode.ModeEnum.PostgreSQL
compatibility mode.class
Base class for mode-specific functions.final class
VALUES(column) function for ON DUPLICATE KEY UPDATE clause.final class
A ::regclass expression.Methods in org.h2.mode that return ExpressionModifier and TypeMethodDescriptionFunctionsDB2Derby.optimize
(SessionLocal session) FunctionsLegacy.optimize
(SessionLocal session) FunctionsMSSQLServer.optimize
(SessionLocal session) FunctionsMySQL.optimize
(SessionLocal session) FunctionsOracle.optimize
(SessionLocal session) FunctionsPostgreSQL.optimize
(SessionLocal session) Regclass.optimize
(SessionLocal session) Methods in org.h2.mode with parameters of type ExpressionModifier and TypeMethodDescription(package private) final Value[]
ModeFunction.getArgumentsValues
(SessionLocal session, Expression[] args) Gets values of arguments and checks them for NULL values if function returns NULL on NULL argument.(package private) static Value
ModeFunction.getNullOrValue
(SessionLocal session, Expression[] args, Value[] values, int i) Get value transformed by expression, or null if i is out of range or the input value is null.Constructors in org.h2.mode with parameters of type Expression -
Uses of Expression in org.h2.mvstore.db
Fields in org.h2.mvstore.db declared as ExpressionModifier and TypeFieldDescription(package private) final Expression[]
MVTempResult.expressions
Column expressions.Methods in org.h2.mvstore.db with parameters of type ExpressionModifier and TypeMethodDescriptionstatic ResultExternal
MVTempResult.of
(Database database, Expression[] expressions, boolean distinct, int[] distinctIndexes, int visibleColumnCount, int resultColumnCount, SortOrder sort) Creates MVStore-based temporary result.Constructors in org.h2.mvstore.db with parameters of type ExpressionModifierConstructorDescription(package private)
MVPlainTempResult
(Database database, Expression[] expressions, int visibleColumnCount, int resultColumnCount) Creates a new plain temporary result.(package private)
MVSortedTempResult
(Database database, Expression[] expressions, boolean distinct, int[] distinctIndexes, int visibleColumnCount, int resultColumnCount, SortOrder sort) Creates a new sorted temporary result.(package private)
MVTempResult
(Database database, Expression[] expressions, int visibleColumnCount, int resultColumnCount) Creates a new temporary result. -
Uses of Expression in org.h2.result
Fields in org.h2.result declared as ExpressionModifier and TypeFieldDescriptionprivate final Expression[]
LazyResult.expressions
private Expression[]
LocalResult.expressions
Methods in org.h2.result with parameters of type ExpressionModifier and TypeMethodDescriptionSortOrder.getSQL
(StringBuilder builder, Expression[] list, int visible, int sqlFlags) Create the SQL snippet that describes this sort order.Constructors in org.h2.result with parameters of type ExpressionModifierConstructorDescriptionLazyResult
(SessionLocal session, Expression[] expressions) LocalResult
(SessionLocal session, Expression[] expressions, int visibleColumnCount, int resultColumnCount) Construct a local result object. -
Uses of Expression in org.h2.schema
Fields in org.h2.schema declared as ExpressionModifier and TypeFieldDescriptionprivate Expression
Domain.defaultExpression
private Expression
Domain.onUpdateExpression
Methods in org.h2.schema that return ExpressionModifier and TypeMethodDescriptionDomain.getDefaultExpression()
Domain.getEffectiveDefaultExpression()
Domain.getEffectiveOnUpdateExpression()
Domain.getOnUpdateExpression()
Methods in org.h2.schema with parameters of type ExpressionModifier and TypeMethodDescriptionprivate Object
FunctionAlias.JavaMethod.execute
(SessionLocal session, Expression[] args, boolean columnList) FunctionAlias.findJavaMethod
(Expression[] args) Find the Java method that matches the arguments.FunctionAlias.JavaMethod.getTableValue
(SessionLocal session, Expression[] args, boolean columnList) Call the table user-defined function and return the value.FunctionAlias.JavaMethod.getValue
(SessionLocal session, Expression[] args, boolean columnList) Call the user-defined function and return the value.void
Domain.setDefaultExpression
(SessionLocal session, Expression defaultExpression) void
Domain.setOnUpdateExpression
(SessionLocal session, Expression onUpdateExpression) -
Uses of Expression in org.h2.table
Fields in org.h2.table declared as ExpressionModifier and TypeFieldDescriptionprivate final Expression[]
Plan.allConditions
private Expression
Column.defaultExpression
private final Expression[]
DataChangeDeltaTable.expressions
private Expression
TableFilter.filterCondition
Additional conditions that can't be used for index lookup, but for row filter for this table (ID=ID, NAME LIKE '%X%')private Expression
TableFilter.fullCondition
private Expression
TableFilter.joinCondition
The complete join condition.private Expression
RangeTable.max
private Expression
RangeTable.min
private final Expression
TableFilter.MapColumnsVisitor.on
private Expression
Column.onUpdateExpression
private Expression
RangeTable.step
Fields in org.h2.table with type parameters of type ExpressionModifier and TypeFieldDescriptionprivate final ArrayList
<ArrayList<Expression>> TableValueConstructorTable.rows
Methods in org.h2.table that return ExpressionModifier and TypeMethodDescriptionColumn.getDefaultExpression()
ColumnTemplate.getDefaultExpression()
Column.getEffectiveDefaultExpression()
ColumnTemplate.getEffectiveDefaultExpression()
Column.getEffectiveOnUpdateExpression()
ColumnTemplate.getEffectiveOnUpdateExpression()
TableFilter.getFilterCondition()
TableFilter.getJoinCondition()
Column.getOnUpdateExpression()
ColumnTemplate.getOnUpdateExpression()
default Expression
ColumnResolver.optimize
(ExpressionColumn expressionColumn, Column column) Get the expression that represents this column.Methods in org.h2.table with parameters of type ExpressionModifier and TypeMethodDescriptionvoid
TableFilter.addFilterCondition
(Expression condition, boolean isJoin) Add a filter condition.void
TableFilter.addJoin
(TableFilter filter, boolean outer, Expression on) Add a joined table.(package private) boolean
TableFilter.isOk
(Expression condition) Whether the current value of the condition is true, or there is no condition.void
TableFilter.mapAndAddFilter
(Expression on) Map the columns and add the join condition.void
Column.setDefaultExpression
(SessionLocal session, Expression defaultExpression) void
ColumnTemplate.setDefaultExpression
(SessionLocal session, Expression defaultExpression) Set the default expression.void
TableFilter.setFullCondition
(Expression condition) void
Column.setGeneratedExpression
(Expression expression) Set the default value in the form of a generated expression of other columns.void
Column.setOnUpdateExpression
(SessionLocal session, Expression onUpdateExpression) void
ColumnTemplate.setOnUpdateExpression
(SessionLocal session, Expression onUpdateExpression) Set the on update expression.Constructors in org.h2.table with parameters of type ExpressionModifierConstructorDescription(package private)
Plan
(TableFilter[] filters, int count, Expression condition) Create a query plan with the given order.RangeTable
(Schema schema, Expression min, Expression max) Create a new range with the given start and end expressions.RangeTable
(Schema schema, Expression min, Expression max, Expression step) Constructor parameters in org.h2.table with type arguments of type ExpressionModifierConstructorDescriptionTableValueConstructorTable
(Schema schema, SessionLocal session, Column[] columns, ArrayList<ArrayList<Expression>> rows)